Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abort() - Method in interface org.apache.pulsar.client.api.transaction.Transaction
- 
Abort the transaction.
- abort(TxnID) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Abort txn.
- abortAsync(TxnID) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Abort txn asynchronously.
- ABORTED - Enum constant in enum class org.apache.pulsar.client.api.transaction.Transaction.State
- 
When a client receives a response to an abort, the transaction state is changed from `ABORTING` to `ABORTED`.
- ABORTING - Enum constant in enum class org.apache.pulsar.client.api.transaction.Transaction.State
- 
When a client invokes an abort, the transaction state is changed from `OPEN` to `ABORTING`.
- abortTxnOnSubscription(String, String, long, long, long) - Method in interface org.apache.pulsar.client.api.transaction.TransactionBufferClient
- 
Abort the transaction associated with the topic subscription.
- abortTxnOnTopic(String, long, long, long) - Method in interface org.apache.pulsar.client.api.transaction.TransactionBufferClient
- 
Abort the transaction associated with the topic.
- accessMode(ProducerAccessMode) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Configure the type of access mode that the producer requires on the topic.
- acknowledge(List<MessageId>) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
Acknowledge the consumption of a list of message.
- acknowledge(Message<?>) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- acknowledge(MessageId) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
Acknowledge the consumption of a single message.
- acknowledge(Messages<?>) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- acknowledgeAsync(List<MessageId>) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledge(List).
- acknowledgeAsync(List<MessageId>, Transaction) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledge(List)with transaction support.
- acknowledgeAsync(Message<?>) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledge(Message).
- acknowledgeAsync(MessageId) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledge(MessageId).
- acknowledgeAsync(MessageId, Transaction) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledge(MessageId)with transaction support.
- acknowledgeAsync(Messages<?>) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledge(Messages).
- acknowledgeAsync(Messages<?>, Transaction) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledge(Messages)with transaction support.
- acknowledgeCumulative(Message<?>) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- acknowledgeCumulative(MessageId) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.
- acknowledgeCumulativeAsync(Message<?>) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledgeCumulative(Message).
- acknowledgeCumulativeAsync(MessageId) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledgeCumulative(MessageId).
- acknowledgeCumulativeAsync(MessageId, Transaction) - Method in interface org.apache.pulsar.client.api.MessageAcknowledger
- 
The asynchronous version ofMessageAcknowledger.acknowledgeCumulative(MessageId)with transaction support.
- acknowledgmentGroupTime(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets amount of time for group consumer acknowledgments.
- ackTimeout(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the timeout for unacknowledged messages, truncated to the nearest millisecond.
- ackTimeoutRedeliveryBackoff(RedeliveryBackoff) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
redeliveryBackoff doesn't work with `consumer.negativeAcknowledge(MessageId messageId)` because we are unable to get the redelivery count from the message ID.
- ackTimeoutTickTime(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Define the granularity of the ack-timeout redelivery.
- addEncryptionKey(String) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Add public encryption key, used by producer to encrypt the data key.
- addProperty(String, String) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema info properties.
- addPublicKeyCipher(Set<String>, CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.MessageCrypto
- addPublishPartitionToTxn(TxnID, List<String>) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Add publish partition to txn.
- addPublishPartitionToTxnAsync(TxnID, List<String>) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Add publish partition to txn asynchronously.
- addSubscriptionToTxn(TxnID, String, String) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Add ack subscription to txn.
- addSubscriptionToTxnAsync(TxnID, String, String) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Add ack subscription to txn asynchronously.
- aliases(String...) - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
- 
The optional name aliases of this field.
- allowOutOfOrderDelivery - Variable in class org.apache.pulsar.client.api.KeySharedPolicy
- allowTlsInsecureConnection(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Configure whether the Pulsar client accept untrusted TLS certificate from broker (default: false).
- AllTopics - Enum constant in enum class org.apache.pulsar.client.api.RegexSubscriptionMode
- 
Subscribe to both persistent and non-persistent topics.
- AlreadyClosedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AlreadyClosedException
- 
Constructs anAlreadyClosedExceptionwith the specified detail message.
- AlreadyClosedException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AlreadyClosedException
- 
Constructs anAlreadyClosedExceptionwith the specified detail message.
- asSingleMessage(MessagePayload, Schema<T>) - Method in interface org.apache.pulsar.client.api.MessagePayloadContext
- 
Convert the given payload to a single message if the entry is not a batch.
- AuthData - Class in org.apache.pulsar.common.api
- 
Authentication data.
- AuthData() - Constructor for class org.apache.pulsar.common.api.AuthData
- authenticate(AuthData) - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- 
For mutual authentication, This method use passed in `data` to evaluate and challenge, then returns null if authentication has completed; returns authenticated data back to server side, if authentication has not completed.
- authentication(String, String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Configure the authentication provider to use in the Pulsar client instance.
- authentication(String, Map<String, String>) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Configure the authentication provider to use in the Pulsar client instance using a config map.
- authentication(Authentication) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the authentication provider to use in the Pulsar client instance.
- Authentication - Interface in org.apache.pulsar.client.api
- 
Interface of authentication providers.
- AuthenticationDataProvider - Interface in org.apache.pulsar.client.api
- 
Interface for accessing data which are used in variety of authentication schemes on client side.
- AuthenticationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AuthenticationException
- 
Constructs anAuthenticationExceptionwith the specified detail message.
- AuthenticationFactory - Class in org.apache.pulsar.client.api
- 
Factory class that allows to createAuthenticationinstances for all the supported authentication methods.
- AuthenticationFactory() - Constructor for class org.apache.pulsar.client.api.AuthenticationFactory
- authenticationStage(String, AuthenticationDataProvider, Map<String, String>, CompletableFuture<Map<String, String>>) - Method in interface org.apache.pulsar.client.api.Authentication
- 
An authentication Stage.
- AuthorizationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AuthorizationException
- 
Constructs anAuthorizationExceptionwith the specified detail message.
- AUTO - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Deprecated.
- AUTO() - Static method in interface org.apache.pulsar.client.api.Schema
- 
Deprecated.
- AUTO_CONSUME - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Auto Consume Type.
- AUTO_CONSUME() - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a schema instance that automatically deserialize messages based on the current topic schema.
- AUTO_PRODUCE_BYTES() - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a schema instance that accepts a serialized payload and validates it against the topic schema.
- AUTO_PRODUCE_BYTES(Schema<?>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a schema instance that accepts a serialized payload and validates it against the schema specified.
- AUTO_PUBLISH - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Auto Publish Type.
- AUTO_SPLIT - Enum constant in enum class org.apache.pulsar.client.api.KeySharedMode
- 
Auto split while new consumer connected.
- autoAckOldestChunkedMessageOnQueueFull(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Buffering large number of outstanding uncompleted chunked messages can create memory pressure and it can be guarded by providing this @maxPendingChunkedMessage threshold.
- autoAckOldestChunkedMessageOnQueueFull(boolean) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Buffering large number of outstanding uncompleted chunked messages can create memory pressure and it can be guarded by providing this @maxPendingChunkedMessage threshold.
- AutoClusterFailoverBuilder - Interface in org.apache.pulsar.client.api
- 
AutoClusterFailoverBuilderis used to configure and create instance ofServiceUrlProvider.
- AutoClusterFailoverBuilder.FailoverPolicy - Enum Class in org.apache.pulsar.client.api
- autoScaledReceiverQueueSizeEnabled(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
If this is enabled, the consumer receiver queue size is initialized as a very small value, 1 by default, and will double itself until it reaches either the value set byConsumerBuilder.receiverQueueSize(int)or the client memory limit set byClientBuilder.memoryLimit(long, SizeUnit).
- autoSplitHashRange() - Static method in class org.apache.pulsar.client.api.KeySharedPolicy
- autoUpdatePartitions(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
If enabled, the consumer auto-subscribes for partition increases.
- autoUpdatePartitions(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
If enabled, partitioned producer will automatically discover new partitions at runtime.
- autoUpdatePartitions(boolean) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
If enabled, the reader will auto subscribe for partitions increasement.
- autoUpdatePartitionsInterval(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the interval of updating partitions (default: 1 minute).
- autoUpdatePartitionsInterval(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the interval of updating partitions.
- autoUpdatePartitionsInterval(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Set the interval of updating partitions (default: 1 minute).
- autoUpdatePartitionsInterval(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Set the interval of updating partitions (default: 1 minute).
- AVRO - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Serialize and deserialize via avro.
- AVRO(Class<T>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a Avro schema type by default configuration of the class.
- AVRO(SchemaDefinition<T>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a Avro schema type with schema definition.
B
- batcherBuilder(BatcherBuilder) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the batcher builderBatcherBuilderof the producer.
- BatcherBuilder - Interface in org.apache.pulsar.client.api
- 
Batcher builder.
- batchingMaxBytes(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the maximum number of bytes permitted in a batch.
- batchingMaxMessages(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the maximum number of messages permitted in a batch.
- batchingMaxPublishDelay(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the time period within which messages sent will be batched if batch messages are enabled.
- BatchMessageContainer - Interface in org.apache.pulsar.client.api
- 
Batch message container for individual messages being published until they are batched and sent to broker.
- batchReceive() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Batch receiving messages.
- batchReceiveAsync() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Batch receiving messages.
- batchReceivePolicy(BatchReceivePolicy) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
SetsBatchReceivePolicyfor the consumer.
- BatchReceivePolicy - Class in org.apache.pulsar.client.api
- 
Configuration for message batch receiveConsumer.batchReceive()Consumer.batchReceiveAsync().
- BatchReceivePolicy.Builder - Class in org.apache.pulsar.client.api
- 
Builder of BatchReceivePolicy.
- becameActive(Consumer<?>, int) - Method in interface org.apache.pulsar.client.api.ConsumerEventListener
- 
Notified when the consumer group is changed, and the consumer becomes the active consumer.
- becameInactive(Consumer<?>, int) - Method in interface org.apache.pulsar.client.api.ConsumerEventListener
- 
Notified when the consumer group is changed, and the consumer is still inactive or becomes inactive.
- beforeConsume(Consumer<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.ConsumerInterceptor
- 
This is called just before the message is returned byConsumer.receive(),MessageListener.received(Consumer, Message)or theCompletableFuturereturned byConsumer.receiveAsync()completes.
- beforeRead(Reader<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.ReaderInterceptor
- 
This is called just before the message is returned byReader.readNext(),ReaderListener.received(Reader, Message)or theCompletableFuturereturned byReader.readNextAsync()completes.
- beforeSend(Producer<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.ProducerInterceptor
- 
Deprecated.This is called fromProducer.send(Object)andProducer.sendAsync(Object)methods, before send the message to the brokers.
- beforeSend(Producer, Message) - Method in interface org.apache.pulsar.client.api.interceptor.ProducerInterceptor
- 
This is called fromProducer.send(Object)andProducer.sendAsync(Object)methods, before send the message to the brokers.
- beforeSend(Producer, Message) - Method in class org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
- blockIfQueueFull(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set whether theProducer.send(T)andProducer.sendAsync(T)operations should block when the outgoing message queue is full.
- BOOL - Static variable in interface org.apache.pulsar.client.api.Schema
- 
Boolean Schema.
- BOOLEAN - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
boolean schema defined.
- BrokerMetadataException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.BrokerMetadataException
- 
Constructs anBrokerMetadataExceptionwith the specified detail message.
- BrokerPersistenceException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.BrokerPersistenceException
- 
Constructs anBrokerPersistenceExceptionwith the specified detail message.
- build() - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Build the ServiceUrlProvider instance.
- build() - Method in interface org.apache.pulsar.client.api.BatcherBuilder
- 
Build a new batch message container.
- build() - Method in class org.apache.pulsar.client.api.BatchReceivePolicy.Builder
- build() - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Construct the finalPulsarClientinstance.
- build() - Method in interface org.apache.pulsar.client.api.ControlledClusterFailoverBuilder
- 
Build the ServiceUrlProvider instance.
- build() - Method in interface org.apache.pulsar.client.api.schema.GenericRecordBuilder
- 
Build a generic record.
- build() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Build the schema definition.
- build() - Method in interface org.apache.pulsar.client.api.TopicConsumerBuilder
- 
Complete the configuration of the topic specific options and return control back to theConsumerBuilderinstance.
- build() - Method in interface org.apache.pulsar.client.api.transaction.TransactionBuilder
- 
Build the transaction with the configured settings.
- build() - Method in class org.apache.pulsar.common.schema.SchemaInfo.SchemaInfoBuilder
- build(SchemaType) - Method in interface org.apache.pulsar.client.api.schema.RecordSchemaBuilder
- 
Build the schema info.
- builder() - Static method in class org.apache.pulsar.client.api.BatchReceivePolicy
- builder() - Static method in interface org.apache.pulsar.client.api.PulsarClient
- 
Get a new builder instance that can used to configure and build aPulsarClientinstance.
- builder() - Static method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get a new builder instance that can used to configure and build aSchemaDefinitioninstance.
- builder() - Static method in interface org.apache.pulsar.common.schema.SchemaInfo
- Builder() - Constructor for class org.apache.pulsar.client.api.BatchReceivePolicy.Builder
- BYTEBUFFER - Static variable in interface org.apache.pulsar.client.api.Schema
- 
ByteBuffer Schema.
- BYTES - Enum constant in enum class org.apache.pulsar.client.api.SizeUnit
- BYTES - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
A bytes array.
- BYTES - Static variable in interface org.apache.pulsar.client.api.Schema
- 
Schema that doesn't perform any encoding on the message payloads.
C
- checkInterval(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set the checkInterval for probe.
- checkInterval(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ControlledClusterFailoverBuilder
- 
Set the probe check interval.
- ChecksumException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ChecksumException
- 
Constructs anChecksumExceptionwith the specified detail message.
- choosePartition(Message<?>) - Method in interface org.apache.pulsar.client.api.MessageRouter
- 
Deprecated.
- choosePartition(Message<?>, TopicMetadata) - Method in interface org.apache.pulsar.client.api.MessageRouter
- 
Choose a partition based on msg and the topic metadata.
- chunkMaxMessageSize(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Max chunk-message size in bytes.
- clear() - Method in interface org.apache.pulsar.client.api.BatchMessageContainer
- 
Clear the message batch container.
- clear(String) - Method in interface org.apache.pulsar.client.api.schema.GenericRecordBuilder
- 
Clears the value of the given field.
- clear(Field) - Method in interface org.apache.pulsar.client.api.schema.GenericRecordBuilder
- 
Clears the value of the given field.
- ClientBuilder - Interface in org.apache.pulsar.client.api
- 
Builder interface that is used to configure and construct aPulsarClientinstance.
- clock(Clock) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
The clock used by the pulsar client.
- clone() - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Create a copy of the current client builder.
- clone() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Create a copy of the current consumer builder.
- clone() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Create a copy of the currentProducerBuilder.
- clone() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Create a copy of the currentReaderBuilder.
- clone() - Method in interface org.apache.pulsar.client.api.Schema
- 
Duplicates the schema.
- close() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Close the consumer and stop the broker to push more messages.
- close() - Method in interface org.apache.pulsar.client.api.ConsumerInterceptor
- 
Close the interceptor.
- close() - Method in interface org.apache.pulsar.client.api.interceptor.ProducerInterceptor
- 
Close the interceptor.
- close() - Method in class org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
- close() - Method in interface org.apache.pulsar.client.api.Producer
- 
Close the producer and releases resources allocated.
- close() - Method in interface org.apache.pulsar.client.api.ProducerInterceptor
- 
Deprecated.Close the interceptor.
- close() - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Close the PulsarClient and release all the resources.
- close() - Method in interface org.apache.pulsar.client.api.ReaderInterceptor
- 
Close the interceptor.
- close() - Method in interface org.apache.pulsar.client.api.ServiceUrlProvider
- 
Close the resource that the provider allocated.
- close() - Method in interface org.apache.pulsar.client.api.transaction.TransactionBufferClient
- closeAsync() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Asynchronously close the consumer and stop the broker to push more messages.
- closeAsync() - Method in interface org.apache.pulsar.client.api.Producer
- 
Close the producer and releases resources allocated.
- closeAsync() - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Asynchronously close the PulsarClient and release all the resources.
- closeAsync() - Method in interface org.apache.pulsar.client.api.Reader
- 
Asynchronously close the reader and stop the broker to push more messages.
- closeAsync() - Method in interface org.apache.pulsar.client.api.TableView
- 
Close the table view and releases resources allocated.
- closeAsync() - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Close the transaction meta store client asynchronous.
- CLOSED - Enum constant in enum class org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
- CLOSING - Enum constant in enum class org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
- commit() - Method in interface org.apache.pulsar.client.api.transaction.Transaction
- 
Commit the transaction.
- commit(TxnID) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Commit txn.
- commitAsync(TxnID) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Commit txn asynchronously.
- COMMITTED - Enum constant in enum class org.apache.pulsar.client.api.transaction.Transaction.State
- 
When a client receives a response to a commit, the transaction state is changed from `COMMITTING` to `COMMITTED`.
- COMMITTING - Enum constant in enum class org.apache.pulsar.client.api.transaction.Transaction.State
- 
When a client invokes a commit, the transaction state is changed from `OPEN` to `COMMITTING`.
- commitTxnOnSubscription(String, String, long, long, long) - Method in interface org.apache.pulsar.client.api.transaction.TransactionBufferClient
- 
Commit the transaction associated with the topic subscription.
- commitTxnOnTopic(String, long, long, long) - Method in interface org.apache.pulsar.client.api.transaction.TransactionBufferClient
- 
Commit the transaction associated with the topic.
- compareTo(Range) - Method in class org.apache.pulsar.client.api.Range
- compressionType(CompressionType) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the compression type for the producer.
- CompressionType - Enum Class in org.apache.pulsar.client.api
- 
The compression type that can be specified on aProducer.
- CONF_DELIVERY_AFTER_SECONDS - Static variable in interface org.apache.pulsar.client.api.TypedMessageBuilder
- CONF_DELIVERY_AT - Static variable in interface org.apache.pulsar.client.api.TypedMessageBuilder
- CONF_DISABLE_REPLICATION - Static variable in interface org.apache.pulsar.client.api.TypedMessageBuilder
- CONF_EVENT_TIME - Static variable in interface org.apache.pulsar.client.api.TypedMessageBuilder
- CONF_KEY - Static variable in interface org.apache.pulsar.client.api.TypedMessageBuilder
- CONF_PROPERTIES - Static variable in interface org.apache.pulsar.client.api.TypedMessageBuilder
- CONF_REPLICATION_CLUSTERS - Static variable in interface org.apache.pulsar.client.api.TypedMessageBuilder
- CONF_SEQUENCE_ID - Static variable in interface org.apache.pulsar.client.api.TypedMessageBuilder
- configure(String) - Method in interface org.apache.pulsar.client.api.EncodedAuthenticationParameterSupport
- 
Plugins which use ":" and/or "," in a configuration parameter value need to implement this interface.
- configure(Map<String, String>) - Method in interface org.apache.pulsar.client.api.Authentication
- 
Deprecated.This method will be deleted on version 2.0, instead please use configure(String encodedAuthParamString) which is in EncodedAuthenticationParameterSupport for now and will be integrated into this interface.
- configureSchemaInfo(String, String, SchemaInfo) - Method in interface org.apache.pulsar.client.api.Schema
- 
Configure the schema to use the provided schema info.
- ConnectException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConnectException
- 
Constructs anConnectExceptionwith the specified detail message.
- ConnectException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConnectException
- 
Constructs anConnectExceptionwith the specified cause.
- connectionMaxIdleSeconds(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Release the connection if it is not used for more than seconds.
- connectionsPerBroker(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Sets the max number of connection that the client library will open to a single broker.
- connectionTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the duration of time to wait for a connection to a broker to be established.
- CONSUME - Enum constant in enum class org.apache.pulsar.client.api.ConsumerCryptoFailureAction
- 
Deliver the encrypted message to the application.
- Consumer<T> - Interface in org.apache.pulsar.client.api
- 
An interface that abstracts behavior of Pulsar's consumer.
- ConsumerAssignException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConsumerAssignException
- 
Constructs anConsumerAssignExceptionwith the specified detail message.
- ConsumerBuilder<T> - Interface in org.apache.pulsar.client.api
- 
ConsumerBuilderis used to configure and create instances ofConsumer.
- ConsumerBusyException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConsumerBusyException
- 
Constructs anConsumerBusyExceptionwith the specified detail message.
- ConsumerCryptoFailureAction - Enum Class in org.apache.pulsar.client.api
- 
The action a consumer should take when a consumer receives a message that it cannot decrypt.
- consumerEventListener(ConsumerEventListener) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets aConsumerEventListenerfor the consumer.
- ConsumerEventListener - Interface in org.apache.pulsar.client.api
- 
Listener on the consumer state changes.
- ConsumerInterceptor<T> - Interface in org.apache.pulsar.client.api
- 
A plugin interface that allows you to intercept (and possibly mutate) messages received by the consumer.
- consumerName(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the consumer name.
- ConsumerStats - Interface in org.apache.pulsar.client.api
- 
Consumer statistics recorded by client.
- contains(int) - Method in class org.apache.pulsar.client.api.Range
- 
Check if the value is in the range.
- containsKey(String) - Method in interface org.apache.pulsar.client.api.TableView
- 
Returnstrueif thisTableViewcontains a mapping for the specified key.
- ControlledClusterFailoverBuilder - Interface in org.apache.pulsar.client.api
- 
ControlledClusterFailoverBuilderis used to configure and create instance ofServiceUrlProvider.
- convertKeyValueDataStringToSchemaInfoSchema(byte[]) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Convert the key/value schema info data json bytes to key/value schema info data bytes.
- convertKeyValueSchemaInfoDataToString(KeyValue<SchemaInfo, SchemaInfo>) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Convert the key/value schema data.
- CoordinatorClientStateException() - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.CoordinatorClientStateException
- CoordinatorClientStateException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.CoordinatorClientStateException
- CoordinatorNotFoundException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.CoordinatorNotFoundException
- copiedBuffer() - Method in interface org.apache.pulsar.client.api.MessagePayload
- 
Copy the bytes of the payload into the byte array.
- create() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Finalize the creation of theProducerinstance.
- create() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Finalize the creation of theReaderinstance.
- create() - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Finalize the creation of theTableViewinstance.
- create(String, String) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
- 
Create an instance of theAuthenticationobject by using the plugin class name.
- create(String, Map<String, String>) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
- 
Create an instance of the Authentication-Plugin.
- create(String, MessageId) - Static method in interface org.apache.pulsar.client.api.TopicMessageId
- createAsync() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Finalize the creation of theProducerinstance in asynchronous mode.
- createAsync() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Finalize the creation of theReaderinstance in asynchronous mode.
- createAsync() - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Finalize the creation of theTableViewinstance in asynchronous mode.
- createAuthentication(String, String) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- createAuthentication(String, Map<String, String>) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- CryptoException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.CryptoException
- 
Constructs anCryptoExceptionwith the specified detail message.
- cryptoFailureAction(ConsumerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the ConsumerCryptoFailureAction to the value specified.
- cryptoFailureAction(ConsumerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Sets theConsumerCryptoFailureActionto specify.
- cryptoFailureAction(ConsumerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Set theConsumerCryptoFailureActionto specify.
- cryptoFailureAction(ProducerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the ProducerCryptoFailureAction to the value specified.
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets aCryptoKeyReader.
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Sets aCryptoKeyReader.
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Sets aCryptoKeyReaderto decrypt the message payloads.
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Set theCryptoKeyReaderto decrypt the message payloads.
- CryptoKeyReader - Interface in org.apache.pulsar.client.api
- 
Interface that abstracts the access to a key store.
- CustomPartition - Enum constant in enum class org.apache.pulsar.client.api.MessageRoutingMode
- 
Use custom message router implementation that will be called to determine the partition for a particular message.
D
- DATE - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Date.
- DATE - Static variable in interface org.apache.pulsar.client.api.Schema
- 
Date Schema.
- deadLetterPolicy(DeadLetterPolicy) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets dead letter policy for a consumer.
- DeadLetterPolicy - Class in org.apache.pulsar.client.api
- 
Configuration for the "dead letter queue" feature in consumer.
- DeadLetterPolicy() - Constructor for class org.apache.pulsar.client.api.DeadLetterPolicy
- decode(byte[]) - Method in interface org.apache.pulsar.client.api.Schema
- 
Decode a byte array into an object using the schema definition and deserializer implementation.
- decode(byte[], byte[]) - Method in interface org.apache.pulsar.client.api.Schema
- 
Decode a byte array into an object using a given version.
- decode(byte[], byte[]) - Method in interface org.apache.pulsar.common.schema.KeyValue.KeyValueDecoder
- 
Decode key and value bytes into aKeyValuepair.
- decode(byte[], KeyValue.KeyValueDecoder<K, V>) - Static method in class org.apache.pulsar.common.schema.KeyValue
- 
Decode the value into a key/value pair.
- decode(ByteBuffer) - Method in interface org.apache.pulsar.client.api.Schema
- 
Decode a ByteBuffer into an object using a given version.
- decode(ByteBuffer, byte[]) - Method in interface org.apache.pulsar.client.api.Schema
- 
Decode a ByteBuffer into an object using a given version.
- decodeKeyValueEncodingType(SchemaInfo) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Decode the kv encoding type from the schema info.
- decodeKeyValueSchemaInfo(SchemaInfo) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Decode the key/value schema info to get key schema info and value schema info.
- decrypt(Supplier<MetadataT>, ByteBuffer, ByteBuffer, CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.MessageCrypto
- DEFAULT - Static variable in interface org.apache.pulsar.client.api.BatcherBuilder
- 
Default batch message container.
- DEFAULT - Static variable in interface org.apache.pulsar.client.api.MessagePayloadFactory
- DEFAULT - Static variable in interface org.apache.pulsar.client.api.MessagePayloadProcessor
- DEFAULT_HASH_RANGE_SIZE - Static variable in class org.apache.pulsar.client.api.KeySharedPolicy
- DEFAULT_MULTI_TOPICS_DISABLE_POLICY - Static variable in class org.apache.pulsar.client.api.BatchReceivePolicy
- DEFAULT_POLICY - Static variable in class org.apache.pulsar.client.api.BatchReceivePolicy
- 
Default batch receive policy.
- DEFAULT_TXN_TTL_MS - Static variable in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Default transaction ttl in mills.
- defaultCryptoKeyReader(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the default implementation ofCryptoKeyReader.
- defaultCryptoKeyReader(String) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Sets the default implementation ofCryptoKeyReader.
- defaultCryptoKeyReader(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Sets the default implementation ofCryptoKeyReader.
- defaultCryptoKeyReader(String) - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Set the default implementation ofCryptoKeyReader.
- defaultCryptoKeyReader(Map<String, String>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the default implementation ofCryptoKeyReader.
- defaultCryptoKeyReader(Map<String, String>) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Sets the default implementation ofCryptoKeyReader.
- defaultCryptoKeyReader(Map<String, String>) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Sets the default implementation ofCryptoKeyReader.
- defaultCryptoKeyReader(Map<String, String>) - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Set the default implementation ofCryptoKeyReader.
- DefaultImplementation - Class in org.apache.pulsar.client.internal
- 
This class loads the implementation forPulsarClientImplementationBindingand allows you to decouple the API from the actual implementation.
- DefaultImplementation() - Constructor for class org.apache.pulsar.client.internal.DefaultImplementation
- defaultServiceUrl(String) - Method in interface org.apache.pulsar.client.api.ControlledClusterFailoverBuilder
- 
Set default service url.
- defaultValue(Object) - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
- 
Set the default value of this field.
- deliverAfter(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Request to deliver the message only after the specified relative delay.
- deliverAt(long) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Deliver the message only at or after the specified absolute timestamp.
- disableReplication() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Disable geo-replication for this message.
- discard(Exception) - Method in interface org.apache.pulsar.client.api.BatchMessageContainer
- 
Release the payload and clear the container.
- DISCARD - Enum constant in enum class org.apache.pulsar.client.api.ConsumerCryptoFailureAction
- 
Message is silently acknowledged and not delivered to the application.
- dnsLookupBind(String, int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set dns lookup bind address and port.
- doc(String) - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
- 
The documentation of this field.
- doc(String) - Method in interface org.apache.pulsar.client.api.schema.RecordSchemaBuilder
- 
Add doc to the record schema.
- DOUBLE - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
A double number.
- DOUBLE - Static variable in interface org.apache.pulsar.client.api.Schema
- 
Double Schema.
- Durable - Enum constant in enum class org.apache.pulsar.client.api.SubscriptionMode
E
- earliest - Static variable in interface org.apache.pulsar.client.api.MessageId
- 
MessageId that represents the oldest message available in the topic.
- Earliest - Enum constant in enum class org.apache.pulsar.client.api.SubscriptionInitialPosition
- 
The earliest position which means the start consuming position will be the first message.
- eligible(Message) - Method in interface org.apache.pulsar.client.api.interceptor.ProducerInterceptor
- 
Check whether the interceptor is eligible for this message.
- eligible(Message) - Method in class org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
- enableBatchIndexAcknowledgment(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Enable or disable batch index acknowledgment.
- enableBatching(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set automatic batching of messages for the producer.
- enableBusyWait(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Option to enable busy-wait settings.
- enableChunking(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
If a message's size is higher than the broker's allowed max publish-payload size, enableChunking allows the producer to split the message into multiple chunks and publish it to the broker separately and in order.
- enableLazyStartPartitionedProducers(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
This config affects Shared mode producers of partitioned topics only.
- enableMultiSchema(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the multiple schema mode for producer.
- enableRetry(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
If enabled, the consumer auto-retries messages.
- enableTcpNoDelay(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Configure whether to use TCP no-delay flag on the connection, to disable Nagle algorithm.
- enableTls(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Deprecated.use "pulsar+ssl://" in serviceUrl to enable
- enableTlsHostnameVerification(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
It allows to validate hostname verification when client connects to broker over tls.
- enableTransaction(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
If enable transaction, start the transactionCoordinatorClient with pulsar client.
- encode(K, Schema<K>, V, Schema<V>) - Static method in class org.apache.pulsar.common.schema.KeyValue
- 
Encode a key and value pair into a bytes array.
- encode(T) - Method in interface org.apache.pulsar.client.api.Schema
- 
Encode an object representing the message content into a byte array.
- EncodedAuthenticationParameterSupport - Interface in org.apache.pulsar.client.api
- 
Support for encoded authentication configuration parameters.
- encodeKeyValueSchemaInfo(String, Schema<K>, Schema<V>, KeyValueEncodingType) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Encode key & value into schema into a KeyValue schema.
- encodeKeyValueSchemaInfo(Schema<K>, Schema<V>, KeyValueEncodingType) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Encode key & value into schema into a KeyValue schema.
- encrypt(Set<String>, CryptoKeyReader, Supplier<BuilderT>, ByteBuffer, ByteBuffer) - Method in interface org.apache.pulsar.client.api.MessageCrypto
- EncryptionContext - Class in org.apache.pulsar.common.api
- 
Class representing an encryption context.
- EncryptionContext() - Constructor for class org.apache.pulsar.common.api.EncryptionContext
- EncryptionContext.EncryptionKey - Class in org.apache.pulsar.common.api
- 
Encryption key with metadata.
- EncryptionKey() - Constructor for class org.apache.pulsar.common.api.EncryptionContext.EncryptionKey
- EncryptionKeyInfo - Class in org.apache.pulsar.client.api
- 
EncryptionKeyInfo contains the encryption key and corresponding metadata which contains additional information about the key such as version, timestamp.
- EncryptionKeyInfo() - Constructor for class org.apache.pulsar.client.api.EncryptionKeyInfo
- EncryptionKeyInfo(byte[], Map<String, String>) - Constructor for class org.apache.pulsar.client.api.EncryptionKeyInfo
- entrySet() - Method in interface org.apache.pulsar.client.api.TableView
- 
Returns a Set view of the mappings contained in this map.
- equals(Object) - Method in class org.apache.pulsar.client.api.Range
- equals(Object) - Method in class org.apache.pulsar.client.api.transaction.TxnID
- equals(Object) - Method in class org.apache.pulsar.common.schema.KeyValue
- ERROR - Enum constant in enum class org.apache.pulsar.client.api.transaction.Transaction.State
- 
When a client invokes a commit or an abort, but a transaction does not exist in a coordinator, then the state is changed to `ERROR`.
- eventTime(long) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Set the event time for a given message.
- Exclusive - Enum constant in enum class org.apache.pulsar.client.api.ProducerAccessMode
- 
Require exclusive access for producer.
- Exclusive - Enum constant in enum class org.apache.pulsar.client.api.SubscriptionType
- 
There can be only 1 consumer on the same topic with the same subscription name.
- ExclusiveWithFencing - Enum constant in enum class org.apache.pulsar.client.api.ProducerAccessMode
- 
Acquire exclusive access for the producer.
- execute(Message<?>, Runnable) - Method in interface org.apache.pulsar.client.api.MessageListenerExecutor
- 
select a thread by message to execute the runnable!
- expireTimeOfIncompleteChunkedMessage(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
If the producer fails to publish all the chunks of a message, then the consumer can expire incomplete chunks if the consumer doesn't receive all chunks during the expiration period (default 1 minute).
- expireTimeOfIncompleteChunkedMessage(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
If producer fails to publish all the chunks of a message then consumer can expire incomplete chunks if consumer won't be able to receive all chunks in expire times (default 1 minute).
F
- FAIL - Enum constant in enum class org.apache.pulsar.client.api.ConsumerCryptoFailureAction
- 
This is the default option to fail consume messages until crypto succeeds.
- FAIL - Enum constant in enum class org.apache.pulsar.client.api.ProducerCryptoFailureAction
- 
This is the default option to fail send if crypto operation fails.
- Failover - Enum constant in enum class org.apache.pulsar.client.api.SubscriptionType
- 
Multiple consumer will be able to use the same subscription name but only 1 consumer will receive the messages.
- failoverDelay(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set the switch failoverDelay.
- failoverPolicy(AutoClusterFailoverBuilder.FailoverPolicy) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set secondary choose policy.
- FeatureNotSupportedException(String, PulsarClientException.FailedFeatureCheck) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.FeatureNotSupportedException
- field(String) - Method in interface org.apache.pulsar.client.api.schema.RecordSchemaBuilder
- 
Add a field with the given name to the record.
- field(String, GenericSchema) - Method in interface org.apache.pulsar.client.api.schema.RecordSchemaBuilder
- 
Add a field with the given name and genericSchema to the record.
- Field - Class in org.apache.pulsar.client.api.schema
- 
A field in a record, consisting of a field name, index, andSchemafor the field value.
- Field() - Constructor for class org.apache.pulsar.client.api.schema.Field
- FieldSchemaBuilder<T extends FieldSchemaBuilder<T>> - Interface in org.apache.pulsar.client.api.schema
- 
Build a field for a record.
- filterAndMapProperties(Properties, String) - Static method in class org.apache.pulsar.client.internal.PropertiesUtils
- 
Filters thePropertiesobject so that only properties with the configured prefix are retained, and then removes that prefix and puts the key value pairs into the result map.
- filterAndMapProperties(Properties, String, String) - Static method in class org.apache.pulsar.client.internal.PropertiesUtils
- 
Filters thePropertiesobject so that only properties with the configured prefix are retained, and then replaces the srcPrefix with the targetPrefix when putting the key value pairs in the resulting map.
- FLOAT - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
A float number.
- FLOAT - Static variable in interface org.apache.pulsar.client.api.Schema
- 
Float Schema.
- flush() - Method in interface org.apache.pulsar.client.api.Producer
- 
Flush all the messages buffered in the client and wait until all messages have been successfully persisted.
- flushAsync() - Method in interface org.apache.pulsar.client.api.Producer
- 
Flush all the messages buffered in the client and wait until all messages have been successfully persisted.
- forEach(BiConsumer<String, T>) - Method in interface org.apache.pulsar.client.api.TableView
- 
Performs the given action for each entry in this map until all entries have been processed or the action throws an exception.
- forEachAndListen(BiConsumer<String, T>) - Method in interface org.apache.pulsar.client.api.TableView
- 
Performs the given action for each entry in this map until all entries have been processed or the action throws an exception.
- fromByteArray(byte[]) - Static method in interface org.apache.pulsar.client.api.MessageId
- 
De-serialize a message id from a byte array.
- fromByteArrayWithTopic(byte[], String) - Static method in interface org.apache.pulsar.client.api.MessageId
- 
De-serialize a message id from a byte array with its topic information attached.
G
- generic(SchemaInfo) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Returns a generic schema of existing schema info.
- GenericObject - Interface in org.apache.pulsar.client.api.schema
- 
This is an abstraction over the logical value that is store into a Message.
- GenericRecord - Interface in org.apache.pulsar.client.api.schema
- 
An interface represents a message with schema.
- GenericRecordBuilder - Interface in org.apache.pulsar.client.api.schema
- 
Generic Record Builder to build aGenericRecord.
- GenericSchema<T extends GenericRecord> - Interface in org.apache.pulsar.client.api.schema
- 
A schema that serializes and deserializes betweenGenericRecordand bytes.
- get(String) - Method in interface org.apache.pulsar.client.api.TableView
- 
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
- getAlwaysAllowNull() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get schema whether always allow null or not.
- getAuthData() - Method in interface org.apache.pulsar.client.api.Authentication
- 
Deprecated.
- getAuthData(String) - Method in interface org.apache.pulsar.client.api.Authentication
- 
Get/Create an authentication data provider which provides the data that this client will be sent to the broker.
- getAuthMethodName() - Method in interface org.apache.pulsar.client.api.Authentication
- getAvailableRequestCredits() - Method in interface org.apache.pulsar.client.api.transaction.TransactionBufferClient
- getBatchAllocatedSizeBytes() - Method in interface org.apache.pulsar.client.api.BatchMessageContainer
- 
Get current allocated buffer size of the message batch container in bytes.
- getBrokerPublishTime() - Method in interface org.apache.pulsar.client.api.Message
- 
Get broker publish time from broker entry metadata.
- getBytes(ByteBuffer) - Static method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Retrieves ByteBuffer data into byte[].
- getClassLoader() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get pojo classLoader.
- getCommandData() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- getConsumerName() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Get the name of consumer.
- getCurrentBatchSize() - Method in interface org.apache.pulsar.client.api.BatchMessageContainer
- 
Get current message batch size of the message batch container in bytes.
- getData() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the raw payload of the message.
- getDefaultImplementation() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
- 
Access the actual implementation of the Pulsar Client API.
- getEncryptionCtx() - Method in interface org.apache.pulsar.client.api.Message
- 
EncryptionContextcontains encryption and compression information in it using which application can decrypt consumed message with encrypted-payload.
- getEnd() - Method in class org.apache.pulsar.client.api.Range
- getEventTime() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the event time associated with this message.
- getField(String) - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
- 
Retrieve the value of the provided fieldName.
- getField(Field) - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
- 
Retrieve the value of the provided field.
- getFields() - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
- 
Returns the list of fields associated with the record.
- getFields() - Method in interface org.apache.pulsar.client.api.schema.GenericSchema
- 
Returns the list of fields.
- getGenericSchema(SchemaInfo) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- getHashRangeTotal() - Method in class org.apache.pulsar.client.api.KeySharedPolicy
- getHttpAuthType() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- getHttpHeaders() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- getIndex() - Method in interface org.apache.pulsar.client.api.Message
- 
Get index from broker entry metadata.
- getJsonDef() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get json schema definition.
- getKey() - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
- getKey() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the key of the message.
- getKey() - Method in class org.apache.pulsar.common.schema.KeyValue
- getKeyBytes() - Method in interface org.apache.pulsar.client.api.Message
- 
Get bytes in key.
- getKeySchema() - Method in interface org.apache.pulsar.client.api.schema.KeyValueSchema
- 
Get the Schema of the Key.
- getKeySharedMode() - Method in class org.apache.pulsar.client.api.KeySharedPolicy
- getKeyValueEncodingType() - Method in interface org.apache.pulsar.client.api.schema.KeyValueSchema
- 
Get the KeyValueEncodingType.
- getLastDisconnectedTimestamp() - Method in interface org.apache.pulsar.client.api.Consumer
- getLastDisconnectedTimestamp() - Method in interface org.apache.pulsar.client.api.Producer
- getLastMessageId() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Deprecated.UseConsumer.getLastMessageIds()instead.
- getLastMessageIdAsync() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Deprecated.UseConsumer.getLastMessageIdsAsync()} instead.
- getLastMessageIds() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Get all the last message id of the topics the consumer subscribed.
- getLastMessageIdsAsync() - Method in interface org.apache.pulsar.client.api.Consumer
- 
The asynchronous version ofConsumer.getLastMessageIds().
- getLastSequenceId() - Method in interface org.apache.pulsar.client.api.Producer
- 
Get the last sequence id that was published by this producer.
- getLatestSchema() - Method in interface org.apache.pulsar.client.api.schema.SchemaInfoProvider
- 
Retrieve the latest schema info.
- getMaxNumBytes() - Method in class org.apache.pulsar.client.api.BatchReceivePolicy
- getMaxNumMessages() - Method in class org.apache.pulsar.client.api.BatchReceivePolicy
- getMaxOutputSize(int) - Method in interface org.apache.pulsar.client.api.MessageCrypto
- 
Return the maximum for a given buffer to be encrypted or decrypted.
- getMessageAt(int, int, MessagePayload, boolean, Schema<T>) - Method in interface org.apache.pulsar.client.api.MessagePayloadContext
- 
Get the internal single message with a specific index from a payload if the payload is a batch.
- getMessageId() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the unique message ID associated with this message.
- getMetadata() - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
- getMsgNumInReceiverQueue() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- 
Get the size of receiver queue.
- getMsgNumInSubReceiverQueue() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- 
Get the receiver queue size of sub-consumers.
- getName() - Method in interface org.apache.pulsar.common.schema.SchemaInfo
- getNativeObject() - Method in interface org.apache.pulsar.client.api.schema.GenericObject
- 
Return the internal native representation of the Object, like a AVRO GenericRecord, a String or a byte[].
- getNativeObject() - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
- 
Return the internal native representation of the Record, like a AVRO GenericRecord.
- getNativeSchema() - Method in interface org.apache.pulsar.client.api.Schema
- 
Return the native schema that is wrapped by Pulsar API.
- getNativeSchema() - Method in interface org.apache.pulsar.client.api.schema.SchemaReader
- 
Returns the underling Schema if possible.
- getNumAcksFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getNumAcksReceived() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getNumAcksSent() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getNumBatchReceiveFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getNumBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getNumBytesSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getNumMessages() - Method in interface org.apache.pulsar.client.api.MessagePayloadContext
- 
Get the number of messages when the payload is produced by Pulsar producer.
- getNumMessagesInBatch() - Method in interface org.apache.pulsar.client.api.BatchMessageContainer
- 
Get count of messages in the message batch container.
- getNumMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getNumMsgsSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getNumOfPartitions() - Method in interface org.apache.pulsar.client.api.Producer
- getNumReceiveFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getNumSendFailed() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getOrderingKey() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the ordering key of the message.
- getOwnerTopic() - Method in interface org.apache.pulsar.client.api.TopicMessageId
- 
Return the owner topic name of a message.
- getPartitionsForTopic(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Deprecated.
- getPartitionsForTopic(String, boolean) - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
1.
- getPartitionStats() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getPartitionStats() - Method in interface org.apache.pulsar.client.api.MultiTopicConsumerStats
- getPartitionStats() - Method in interface org.apache.pulsar.client.api.PartitionedTopicProducerStats
- getPartitionStats() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getPendingQueueSize() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getPendingRequestsCount() - Method in interface org.apache.pulsar.client.api.transaction.TransactionBufferClient
- getPojo() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get pojo schema definition.
- getPreviousExceptions() - Method in exception org.apache.pulsar.client.api.PulsarClientException
- 
Get the collection of previous exceptions which have caused retries for this operation.
- getPreviousExceptions(Throwable) - Static method in exception org.apache.pulsar.client.api.PulsarClientException
- getPrivateKey(String, Map<String, String>) - Method in interface org.apache.pulsar.client.api.CryptoKeyReader
- getProducerName() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the producer name who produced this message.
- getProducerName() - Method in interface org.apache.pulsar.client.api.Producer
- getProperties() - Method in interface org.apache.pulsar.client.api.Message
- 
Return the properties attached to the message.
- getProperties() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get schema class.
- getProperties() - Method in interface org.apache.pulsar.common.schema.SchemaInfo
- 
Additional properties of the schema definition (implementation defined).
- getProperty(String) - Method in interface org.apache.pulsar.client.api.Message
- 
Get the value of a specific property.
- getProperty(String) - Method in interface org.apache.pulsar.client.api.MessagePayloadContext
- 
Get a value associated with the given key.
- getPublicKey(String, Map<String, String>) - Method in interface org.apache.pulsar.client.api.CryptoKeyReader
- 
Return the encryption key corresponding to the key name in the argument.
- getPublishTime() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the publish time of this message.
- getRanges() - Method in class org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
- getRateBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getRateMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getReaderSchema() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the schema associated to the message.
- getRedeliveryCount() - Method in interface org.apache.pulsar.client.api.Message
- 
Get message redelivery count, redelivery count maintain in pulsar broker.
- getReplicatedFrom() - Method in interface org.apache.pulsar.client.api.Message
- 
Get name of cluster, from which the message is replicated.
- getSchema() - Method in interface org.apache.pulsar.common.schema.SchemaInfo
- 
The schema data in AVRO JSON format.
- getSchema(SchemaInfo) - Static method in interface org.apache.pulsar.client.api.Schema
- getSchema(SchemaInfo) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- getSchemaByVersion(byte[]) - Method in interface org.apache.pulsar.client.api.schema.SchemaInfoProvider
- 
Retrieve the schema info of a given schemaVersion.
- getSchemaDefinition() - Method in interface org.apache.pulsar.common.schema.SchemaInfo
- getSchemaInfo() - Method in interface org.apache.pulsar.client.api.Schema
- getSchemaReaderOpt() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get a configured schema reader.
- getSchemaType() - Method in interface org.apache.pulsar.client.api.schema.GenericObject
- 
Return the schema tyoe.
- getSchemaType() - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
- 
Return the schema tyoe.
- getSchemaVersion() - Method in interface org.apache.pulsar.client.api.Message
- 
Get schema version of the message.
- getSchemaVersion() - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
- 
Return schema version.
- getSchemaWriterOpt() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get a configured schema writer.
- getSendBytesRate() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getSendLatencyMillis50pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getSendLatencyMillis75pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getSendLatencyMillis95pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getSendLatencyMillis999pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getSendLatencyMillis99pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getSendLatencyMillisMax() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getSendMsgsRate() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getSequenceId() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the sequence id associated with this message.
- getSequenceId() - Method in exception org.apache.pulsar.client.api.PulsarClientException
- getServiceUrl() - Method in interface org.apache.pulsar.client.api.ServiceUrlProvider
- 
Get the current service URL the Pulsar client should connect to.
- getStart() - Method in class org.apache.pulsar.client.api.Range
- getState() - Method in interface org.apache.pulsar.client.api.transaction.Transaction
- 
Get transaction state.
- getState() - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Get current state of the transaction meta store.
- getStats() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Get statistics for the consumer.
- getStats() - Method in interface org.apache.pulsar.client.api.Producer
- 
Get statistics for the producer.
- getSubscription() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Get a subscription for the consumer.
- getSupportSchemaVersioning() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get supportSchemaVersioning schema definition.
- getTimeoutMs() - Method in class org.apache.pulsar.client.api.BatchReceivePolicy
- getTimestamp() - Method in interface org.apache.pulsar.common.schema.SchemaInfo
- 
The created time of schema.
- GettingAuthenticationDataException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
- 
Constructs anGettingAuthenticationDataExceptionwith the specified detail message.
- GettingAuthenticationDataException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
- 
Constructs anGettingAuthenticationDataExceptionwith the specified cause.
- getTlsCerificateFilePath() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- getTlsCertificates() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- getTlsKeyStoreParams() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- 
Used for TLS authentication with keystore type.
- getTlsPrivateKey() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- getTlsPrivateKeyFilePath() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- getTlsTrustStoreStream() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- getTopic() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Get a topic for the consumer.
- getTopic() - Method in interface org.apache.pulsar.client.api.Producer
- getTopic() - Method in interface org.apache.pulsar.client.api.Reader
- getTopicName() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the topic the message was published to.
- getTopicName() - Method in interface org.apache.pulsar.client.api.schema.SchemaInfoProvider
- 
Retrieve the topic name.
- getTotaBatchReceivedFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getTotalAcksFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getTotalAcksReceived() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getTotalAcksSent() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getTotalBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getTotalBytesSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getTotalMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getTotalMsgsSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getTotalReceivedFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
- getTotalSendFailed() - Method in interface org.apache.pulsar.client.api.ProducerStats
- getTxnID() - Method in interface org.apache.pulsar.client.api.transaction.Transaction
- 
Get TxnID of the transaction.
- getType() - Method in interface org.apache.pulsar.common.schema.SchemaInfo
- 
The type of schema (AVRO, JSON, PROTOBUF, etc..).
- getValue() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the de-serialized value of the message, according the configuredSchema.
- getValue() - Method in enum class org.apache.pulsar.client.api.SubscriptionInitialPosition
- getValue() - Method in class org.apache.pulsar.common.schema.KeyValue
- getValue() - Method in enum class org.apache.pulsar.common.schema.SchemaType
- getValueSchema() - Method in interface org.apache.pulsar.client.api.schema.KeyValueSchema
- 
Get the Schema of the Value.
- GIGA_BYTES - Enum constant in enum class org.apache.pulsar.client.api.SizeUnit
H
- hasBase64EncodedKey() - Method in interface org.apache.pulsar.client.api.Message
- 
Check whether the key has been base64 encoded.
- hasBrokerPublishTime() - Method in interface org.apache.pulsar.client.api.Message
- 
Check whether the message has a broker publish time.
- hasDataForHttp() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- 
Check if data for HTTP are available.
- hasDataForTls() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- 
Check if data for TLS are available.
- hasDataFromCommand() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- 
Check if data from Pulsar protocol are available.
- hashCode() - Method in class org.apache.pulsar.client.api.Range
- hashCode() - Method in class org.apache.pulsar.client.api.transaction.TxnID
- hashCode() - Method in class org.apache.pulsar.common.schema.KeyValue
- hashingScheme(HashingScheme) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Change theHashingSchemeused to choose the partition on which to publish a particular message.
- HashingScheme - Enum Class in org.apache.pulsar.client.api
- 
Standard hashing functions available when choosing the partition to use for a particular message.
- hasIndex() - Method in interface org.apache.pulsar.client.api.Message
- 
Check whether the message has an index.
- hasKey() - Method in interface org.apache.pulsar.client.api.Message
- 
Check whether the message has a key.
- hasMessageAvailable() - Method in interface org.apache.pulsar.client.api.Reader
- 
Check if there is any message available to read from the current position.
- hasMessageAvailableAsync() - Method in interface org.apache.pulsar.client.api.Reader
- 
Asynchronously check if there is any message available to read from the current position.
- hasOrderingKey() - Method in interface org.apache.pulsar.client.api.Message
- 
Check whether the message has a ordering key.
- hasProperty(String) - Method in interface org.apache.pulsar.client.api.Message
- 
Check whether the message has a specific property attached.
- hasReachedEndOfTopic() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Return true if the topic was terminated and this consumer has already consumed all the messages in the topic.
- hasReachedEndOfTopic() - Method in interface org.apache.pulsar.client.api.Reader
- 
Return true if the topic was terminated and this reader has reached the end of the topic.
I
- IncompatibleSchemaException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.IncompatibleSchemaException
- 
Constructs anIncompatibleSchemaExceptionwith the specified detail message.
- IncompatibleSchemaException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.IncompatibleSchemaException
- 
Constructs anIncompatibleSchemaExceptionwith the specified cause.
- INIT_AUTH_DATA - Static variable in class org.apache.pulsar.common.api.AuthData
- INIT_AUTH_DATA_BYTES - Static variable in class org.apache.pulsar.common.api.AuthData
- initialize(PulsarClient) - Method in interface org.apache.pulsar.client.api.ServiceUrlProvider
- 
Initialize the service url provider with Pulsar client instance.
- initialSequenceId(long) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the baseline for sequence ids for messages published by the producer.
- INLINE - Enum constant in enum class org.apache.pulsar.common.schema.KeyValueEncodingType
- 
Key and value are stored as message payload.
- INSTANT - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Instant.
- INSTANT - Static variable in interface org.apache.pulsar.client.api.Schema
- 
Instant Schema.
- INT16 - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
A 16-byte integer.
- INT16 - Static variable in interface org.apache.pulsar.client.api.Schema
- 
INT16 Schema.
- INT32 - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
A 32-byte integer.
- INT32 - Static variable in interface org.apache.pulsar.client.api.Schema
- 
INT32 Schema.
- INT64 - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
A 64-byte integer.
- INT64 - Static variable in interface org.apache.pulsar.client.api.Schema
- 
INT64 Schema.
- INT8 - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
A 8-byte integer.
- INT8 - Static variable in interface org.apache.pulsar.client.api.Schema
- 
INT8 Schema.
- intercept(ConsumerInterceptor<T>...) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
InterceptConsumer.
- intercept(ProducerInterceptor...) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Add a set ofProducerInterceptorto the producer.
- intercept(ProducerInterceptor<T>...) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Deprecated.
- intercept(ReaderInterceptor<T>...) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
InterceptReader.
- InterfaceAudience - Class in org.apache.pulsar.common.classification
- 
Annotation to inform users of a package, class or method's intended audience.
- InterfaceAudience.LimitedPrivate - Annotation Interface in org.apache.pulsar.common.classification
- 
Intended for use only within the project(s) specified in the annotation.
- InterfaceAudience.Private - Annotation Interface in org.apache.pulsar.common.classification
- 
Intended for use only within the project itself.
- InterfaceAudience.Public - Annotation Interface in org.apache.pulsar.common.classification
- 
Intended for use by any project or application.
- InterfaceStability - Class in org.apache.pulsar.common.classification
- 
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
- InterfaceStability.Evolving - Annotation Interface in org.apache.pulsar.common.classification
- 
Evolving, but can break compatibility at minor release (i.e.
- InterfaceStability.Stable - Annotation Interface in org.apache.pulsar.common.classification
- 
Can evolve while retaining compatibility for minor release boundaries.; can break compatibility only at major release (ie.
- InterfaceStability.Unstable - Annotation Interface in org.apache.pulsar.common.classification
- 
No guarantee is provided as to reliability or stability across any level of release granularity.
- intersect(Range) - Method in class org.apache.pulsar.client.api.Range
- InvalidConfigurationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
- 
Constructs anInvalidConfigurationExceptionwith the specified detail message.
- InvalidConfigurationException(String, Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
- 
Constructs anInvalidConfigurationExceptionwith the specified cause.
- InvalidConfigurationException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
- 
Constructs anInvalidConfigurationExceptionwith the specified cause.
- InvalidMessageException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidMessageException
- 
Constructs anInvalidMessageExceptionwith the specified detail message.
- InvalidMessageException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidMessageException
- 
Constructs anInvalidMessageExceptionwith the specified detail message.
- InvalidServiceURL(String, Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidServiceURL
- 
Constructs anInvalidServiceURLwith the specified cause.
- InvalidServiceURL(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidServiceURL
- 
Constructs anInvalidServiceURLwith the specified cause.
- InvalidTopicNameException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidTopicNameException
- 
Constructs anInvalidTopicNameExceptionwith the specified detail message.
- InvalidTxnStatusException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.InvalidTxnStatusException
- InvalidTxnStatusException(String, String, String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.InvalidTxnStatusException
- ioThreads(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the number of threads to be used for handling connections to brokers (default: Runtime.getRuntime().availableProcessors()).
- isAckReceiptEnabled(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Enables or disables the acknowledgment receipt feature.
- isAllowOutOfOrderDelivery() - Method in class org.apache.pulsar.client.api.KeySharedPolicy
- isBatch() - Method in interface org.apache.pulsar.client.api.MessagePayloadContext
- 
Check whether the payload is a batch when the payload is produced by Pulsar producer.
- isClosed() - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Return internal state of the client.
- isComplete() - Method in class org.apache.pulsar.common.api.AuthData
- isConnected() - Method in interface org.apache.pulsar.client.api.Consumer
- isConnected() - Method in interface org.apache.pulsar.client.api.Producer
- isConnected() - Method in interface org.apache.pulsar.client.api.Reader
- isEmpty() - Method in interface org.apache.pulsar.client.api.BatchMessageContainer
- 
Check the message batch container is empty.
- isEmpty() - Method in interface org.apache.pulsar.client.api.TableView
- 
Returnstrueif thisTableViewcontains no key-value mappings.
- isJsr310ConversionEnabled() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
- 
Get JSR310 conversion enabled.
- isMessagesFromMultiTopicsEnabled() - Method in class org.apache.pulsar.client.api.BatchReceivePolicy
- isMultiBatches() - Method in interface org.apache.pulsar.client.api.BatchMessageContainer
- 
Return the batch container batch message in multiple batches.
- isPrimitive() - Method in enum class org.apache.pulsar.common.schema.SchemaType
- isPrimitiveType(SchemaType) - Static method in enum class org.apache.pulsar.common.schema.SchemaType
- isReplicated() - Method in interface org.apache.pulsar.client.api.Message
- 
Check whether the message is replicated from other cluster.
- isRetriableError(Throwable) - Static method in exception org.apache.pulsar.client.api.PulsarClientException
- isStruct() - Method in enum class org.apache.pulsar.common.schema.SchemaType
- isStructType(SchemaType) - Static method in enum class org.apache.pulsar.common.schema.SchemaType
- IV_LEN - Static variable in interface org.apache.pulsar.client.api.MessageCrypto
J
- JavaStringHash - Enum constant in enum class org.apache.pulsar.client.api.HashingScheme
- 
Use regularString.hashCode().
- JSON - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
JSON object encoding and validation.
- JSON(Class<T>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a JSON schema type by extracting the fields of the specified class.
- JSON(SchemaDefinition) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a JSON schema type with schema definition.
- jsonifyKeyValueSchemaInfo(KeyValue<SchemaInfo, SchemaInfo>) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Jsonify the key/value schema info.
- jsonifySchemaInfo(SchemaInfo) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Jsonify the schema info.
- jsonifySchemaInfoWithVersion(SchemaInfoWithVersion) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- 
Jsonify the schema info with version.
K
- keepAliveInterval(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set keep alive interval for each client-broker-connection.
- key(String) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Sets the key of the message for routing policy.
- KEY_BASED - Static variable in interface org.apache.pulsar.client.api.BatcherBuilder
- 
Key based batch message container.
- Key_Shared - Enum constant in enum class org.apache.pulsar.client.api.SubscriptionType
- 
Multiple consumer will be able to use the same subscription and all messages with the same key will be dispatched to only one consumer.
- KEY_VALUE - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
A Schema that contains Key Schema and Value Schema.
- keyBytes(byte[]) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Sets the bytes of the key of the message for routing policy.
- keyHashRange(Range...) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Set key hash range of the reader, broker will only dispatch messages which hash of the message key contains by the specified key hash range.
- keySet() - Method in interface org.apache.pulsar.client.api.TableView
- keySharedMode - Variable in class org.apache.pulsar.client.api.KeySharedPolicy
- KeySharedMode - Enum Class in org.apache.pulsar.client.api
- 
KeyShared mode of KeyShared subscription.
- keySharedPolicy(KeySharedPolicy) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets KeyShared subscription policy for consumer.
- KeySharedPolicy - Class in org.apache.pulsar.client.api
- 
KeyShared policy for KeyShared subscription.
- KeySharedPolicy() - Constructor for class org.apache.pulsar.client.api.KeySharedPolicy
- KeySharedPolicy.KeySharedPolicyAutoSplit - Class in org.apache.pulsar.client.api
- 
Auto split hash range key shared policy.
- KeySharedPolicy.KeySharedPolicySticky - Class in org.apache.pulsar.client.api
- 
Sticky attach topic with fixed hash range.
- KeyStoreParams - Class in org.apache.pulsar.client.api
- 
KeyStore parameters used for tls authentication.
- KeyStoreParams() - Constructor for class org.apache.pulsar.client.api.KeyStoreParams
- KeyValue<K,V> - Class in org.apache.pulsar.common.schema 
- 
A simple KeyValue class.
- KeyValue(K, V) - Constructor for class org.apache.pulsar.common.schema.KeyValue
- KeyValue(Class<K>, Class<V>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Key Value Schema whose underneath key and value schemas are JSONSchema.
- KeyValue(Class<K>, Class<V>, SchemaType) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Key Value Schema using passed in schema type, support JSON and AVRO currently.
- KeyValue(Schema<K>, Schema<V>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Key Value Schema using passed in key and value schemas withKeyValueEncodingType.INLINEencoding type.
- KeyValue(Schema<K>, Schema<V>, KeyValueEncodingType) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Key Value Schema using passed in key, value and encoding type schemas.
- KeyValue.KeyValueDecoder<K,V> - Interface in org.apache.pulsar.common.schema 
- 
Decoder to decode key/value bytes.
- KeyValueEncodingType - Enum Class in org.apache.pulsar.common.schema
- 
Encoding types of supported KeyValueSchema for Pulsar messages.
- KeyValueSchema<K,V> - Interface in org.apache.pulsar.client.api.schema 
- 
This interface models a Schema that is composed of two parts.
- KILO_BYTES - Enum constant in enum class org.apache.pulsar.client.api.SizeUnit
- KV_BYTES() - Static method in interface org.apache.pulsar.client.api.Schema
- 
Schema that can be used to encode/decode KeyValue.
L
- latest - Static variable in interface org.apache.pulsar.client.api.MessageId
- 
MessageId that represents the next message published in the topic.
- Latest - Enum constant in enum class org.apache.pulsar.client.api.SubscriptionInitialPosition
- 
The latest position which means the start consuming position will be the last message.
- listen(BiConsumer<String, T>) - Method in interface org.apache.pulsar.client.api.TableView
- 
Performs the given action for each future entry in this map until all entries have been processed or the action throws an exception.
- listenerName(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Configure the listenerName that the broker will return the corresponding `advertisedListener`.
- listenerThreads(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the number of threads to be used for message listeners (default: Runtime.getRuntime().availableProcessors()).
- loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Load the configuration from provided config map.
- loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Load the configuration from provided config map.
- loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Load the configuration from provided config map.
- loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Load the configuration from provided config map.
- loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Load the configuration from provided config map.
- loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Configure theTypedMessageBuilderfrom a config map, as an alternative compared to call the individual builder methods.
- LOCAL_DATE - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
LocalDate.
- LOCAL_DATE - Static variable in interface org.apache.pulsar.client.api.Schema
- 
LocalDate Schema.
- LOCAL_DATE_TIME - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
LocalDateTime.
- LOCAL_DATE_TIME - Static variable in interface org.apache.pulsar.client.api.Schema
- 
LocalDateTime Schema.
- LOCAL_TIME - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
LocalTime.
- LOCAL_TIME - Static variable in interface org.apache.pulsar.client.api.Schema
- 
LocalTime Schema.
- LookupException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.LookupException
- 
Constructs anLookupExceptionwith the specified detail message.
- lookupTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set lookup timeout (default: matches operation timeout)
- LZ4 - Enum constant in enum class org.apache.pulsar.client.api.CompressionType
- 
Compress with LZ4 algorithm.
M
- maxAcknowledgmentGroupSize(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Set the number of messages for group consumer acknowledgments.
- maxBackoffInterval(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the maximum duration of time for a backoff interval.
- maxConcurrentLookupRequests(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Number of concurrent lookup-requests allowed to send on each broker-connection to prevent overload on broker.
- maxLookupRedirects(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the maximum number of times a lookup-request to a broker will be redirected.
- maxLookupRequests(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Number of max lookup-requests allowed on each broker-connection to prevent overload on broker.
- maxNumberOfRejectedRequestPerConnection(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set max number of broker-rejected requests in a certain time-frame (60 seconds) after which current connection will be closed and client creates a new connection that give chance to connect a different broker (default: 50).
- maxNumBytes(int) - Method in class org.apache.pulsar.client.api.BatchReceivePolicy.Builder
- maxNumMessages(int) - Method in class org.apache.pulsar.client.api.BatchReceivePolicy.Builder
- maxPendingChuckedMessage(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Deprecated.
- maxPendingChunkedMessage(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Consumer buffers chunk messages into memory until it receives all the chunks of the original message.
- maxPendingChunkedMessage(int) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Consumer buffers chunk messages into memory until it receives all the chunks of the original message.
- maxPendingMessages(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the max size of the queue holding the messages pending to receive an acknowledgment from the broker.
- maxPendingMessagesAcrossPartitions(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Deprecated.
- maxTotalReceiverQueueSizeAcrossPartitions(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the max total receiver queue size across partitions.
- MEGA_BYTES - Enum constant in enum class org.apache.pulsar.client.api.SizeUnit
- MemoryBufferIsFullError(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.MemoryBufferIsFullError
- 
Constructs anMemoryBufferIsFullErrorwith the specified detail message.
- MemoryBufferIsFullError(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.MemoryBufferIsFullError
- 
Constructs anMemoryBufferIsFullErrorwith the specified detail message.
- memoryLimit(long, SizeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Configure a limit on the amount of direct memory that will be allocated by this client instance (default: 64 MB).
- Message<T> - Interface in org.apache.pulsar.client.api
- 
The message abstraction used in Pulsar.
- MessageAcknowledgeException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.MessageAcknowledgeException
- 
Constructs anMessageAcknowledgeExceptionwith the specified detail message.
- MessageAcknowledgeException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.MessageAcknowledgeException
- 
Constructs anMessageAcknowledgeExceptionwith the specified cause.
- MessageAcknowledger - Interface in org.apache.pulsar.client.api
- 
The interface to acknowledge one or more messages individually or cumulatively.
- messageCrypto(MessageCrypto) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets aMessageCrypto.
- messageCrypto(MessageCrypto) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Sets aMessageCrypto.
- MessageCrypto<MetadataT,BuilderT> - Interface in org.apache.pulsar.client.api 
- 
Interface that abstracts the method to encrypt/decrypt message for End to End Encryption.
- MessageId - Interface in org.apache.pulsar.client.api
- 
Opaque unique identifier of a single message
- messageListener(MessageListener<T>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets aMessageListenerfor the consumer.
- MessageListener<T> - Interface in org.apache.pulsar.client.api
- 
A listener that will be called in order for every message received.
- messageListenerExecutor(MessageListenerExecutor) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Set theMessageListenerExecutorto be used for message listeners of current consumer.
- MessageListenerExecutor - Interface in org.apache.pulsar.client.api
- 
Interface for providing service to execute message listeners.
- MessagePayload - Interface in org.apache.pulsar.client.api
- 
The abstraction of a message's payload.
- MessagePayloadContext - Interface in org.apache.pulsar.client.api
- 
The context of the message payload, which usually represents a batched message (batch) or a single message.
- MessagePayloadFactory - Interface in org.apache.pulsar.client.api
- 
The factory class ofMessagePayload.
- messagePayloadProcessor(MessagePayloadProcessor) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
If configured with a non-null value, the consumer uses the processor to process the payload, including decoding it to messages and triggering the listener.
- MessagePayloadProcessor - Interface in org.apache.pulsar.client.api
- 
The processor to process a message payload.
- messageRouter(MessageRouter) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set a custom message routing policy by passing an implementation of MessageRouter.
- MessageRouter - Interface in org.apache.pulsar.client.api
- 
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(MessageRoutingMode) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set theMessageRoutingModefor a partitioned producer.
- MessageRoutingMode - Enum Class in org.apache.pulsar.client.api
- 
Default routing mode for messages to partition.
- Messages<T> - Interface in org.apache.pulsar.client.api
- 
A container that holds the listMessagefor a topic.
- messagesFromMultiTopicsEnabled(boolean) - Method in class org.apache.pulsar.client.api.BatchReceivePolicy.Builder
- MetaStoreHandlerNotExistsException(long) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.MetaStoreHandlerNotExistsException
- MetaStoreHandlerNotExistsException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.MetaStoreHandlerNotExistsException
- MetaStoreHandlerNotReadyException(long) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.MetaStoreHandlerNotReadyException
- MetaStoreHandlerNotReadyException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.MetaStoreHandlerNotReadyException
- MultiTopicConsumerStats - Interface in org.apache.pulsar.client.api
- 
Multi-topic Consumer statistics recorded by client.
- Murmur3_32Hash - Enum constant in enum class org.apache.pulsar.client.api.HashingScheme
- 
Use Murmur3 hashing function.
N
- name(String) - Method in class org.apache.pulsar.common.schema.SchemaInfo.SchemaInfoBuilder
- NATIVE_AVRO(Object) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a schema instance that accepts a serialized Avro payload without validating it against the schema specified.
- negativeAcknowledge(Message<?>) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Acknowledge the failure to process a single message.
- negativeAcknowledge(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Acknowledge the failure to process a single message.
- negativeAcknowledge(Messages<?>) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Acknowledge the failure to processMessages.
- negativeAckRedeliveryBackoff(RedeliveryBackoff) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
negativeAckRedeliveryBackoff doesn't work with `consumer.negativeAcknowledge(MessageId messageId)` because we are unable to get the redelivery count from the message ID.
- negativeAckRedeliveryDelay(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the delay to wait before re-delivering messages that have failed to be processed.
- newAuthenticationTLS(String, String) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newAuthenticationToken(String) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newAuthenticationToken(Supplier<String>) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newAutoConsumeSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newAutoProduceSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newAutoProduceSchema(Schema<?>) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newAutoProduceValidatedAvroSchema(Object) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newAvroSchema(SchemaDefinition) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newBooleanSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newByteBufferSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newByteSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newBytesSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newClientBuilder() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newConsumer() - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Create a consumer builder with no schema (Schema.BYTES) for subscribing to one or more topics.
- newConsumer(Schema<T>) - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Create a consumer builder with a specific schema for subscribing on a specific topic
- newDateSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newDefaultBatcherBuilder() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newDefaultMessagePayloadFactory() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newDoubleSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newFloatSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newInstantSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newIntSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newJSONSchema(SchemaDefinition) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newKeyBasedBatcherBuilder() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newKeyValueBytesSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newKeyValueSchema(Class<K>, Class<V>, SchemaType) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newKeyValueSchema(Schema<K>, Schema<V>, KeyValueEncodingType) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newLocalDateSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newLocalDateTimeSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newLocalTimeSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newLongSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newMessage() - Method in interface org.apache.pulsar.client.api.Producer
- 
Create a new message builder.
- newMessage(Schema<V>) - Method in interface org.apache.pulsar.client.api.Producer
- 
Create a new message builder with schema, not required same parameterized type with the producer.
- newMessage(Transaction) - Method in interface org.apache.pulsar.client.api.Producer
- 
Create a new message builder with transaction.
- newMessageId(long, long, int) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newMessageIdFromByteArray(byte[]) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newMessageIdFromByteArrayWithTopic(byte[], String) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newProducer() - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Create a producer builder that can be used to configure and construct a producer with defaultSchema.BYTES.
- newProducer(Schema<T>) - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Create a producer builder that can be used to configure and construct a producer with the specified schema.
- newProtobufNativeSchema(SchemaDefinition) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newProtobufSchema(SchemaDefinition) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newReader() - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Create a topic reader builder with no schema (Schema.BYTES) to read from the specified topic.
- newReader(Schema<T>) - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Create a topic reader builder with a specificSchema) to read from the specified topic.
- newRecordBuilder() - Method in interface org.apache.pulsar.client.api.schema.GenericSchema
- 
Create a builder to buildGenericRecord.
- newRecordSchemaBuilder(String) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newRequestHeader(String, AuthenticationDataProvider, Map<String, String>) - Method in interface org.apache.pulsar.client.api.Authentication
- 
Add an authenticationStage that will complete along with authFuture.
- newSchemaDefinitionBuilder() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newSchemaInfoImpl(String, byte[], SchemaType, long, Map<String, String>) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newShortSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newStringSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newStringSchema(Charset) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newTableView() - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Create a table view builder for subscribing on a specific topic.
- newTableView(Schema<T>) - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Create a table view builder with a specific schema for subscribing on a specific topic.
- newTableViewBuilder(Schema<T>) - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Deprecated.UsePulsarClient.newTableView(Schema)to build and configure aTableViewBuilderinstance
- newTimeSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newTimestampSchema() - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newTopicMessageId(String, MessageId) - Method in interface org.apache.pulsar.client.internal.PulsarClientImplementationBinding
- newTransaction() - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Create a transaction builder that can be used to configure and construct a transaction.
- newTransaction() - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Create a new transaction.
- newTransaction(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Create a new transaction.
- newTransactionAsync() - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Create a new transaction asynchronously.
- newTransactionAsync(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Create a new transaction asynchronously.
- next(int) - Method in interface org.apache.pulsar.client.api.RedeliveryBackoff
- NonDurable - Enum constant in enum class org.apache.pulsar.client.api.SubscriptionMode
- NONE - Enum constant in enum class org.apache.pulsar.client.api.CompressionType
- 
No compression.
- NONE - Enum constant in enum class org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
- NONE - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
No schema defined.
- NonPersistentOnly - Enum constant in enum class org.apache.pulsar.client.api.RegexSubscriptionMode
- 
Only subscribe to non-persistent topics.
- NotAllowedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotAllowedException
- 
Constructs anNotAllowedExceptionwith the specified detail message.
- NotConnectedException() - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotConnectedException
- NotConnectedException(long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotConnectedException
- NotFoundException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotFoundException
- 
Constructs anNotFoundExceptionwith the specified detail message.
- NotFoundException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotFoundException
- 
Constructs anNotFoundExceptionwith the specified cause.
- NotSupportedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotSupportedException
- 
Constructs anNotSupportedExceptionwith the specified detail message.
- numPartitions() - Method in interface org.apache.pulsar.client.api.TopicMetadata
- 
Return the number of partitions per topic.
O
- of(int, int) - Static method in class org.apache.pulsar.client.api.Range
- of(SchemaInfo) - Static method in interface org.apache.pulsar.client.api.schema.GenericSchema
- of(SchemaInfo, boolean) - Static method in interface org.apache.pulsar.client.api.schema.GenericSchema
- onAcknowledge(Consumer<T>, MessageId, Throwable) - Method in interface org.apache.pulsar.client.api.ConsumerInterceptor
- 
This is called consumer sends the acknowledgment to the broker.
- onAcknowledgeCumulative(Consumer<T>, MessageId, Throwable) - Method in interface org.apache.pulsar.client.api.ConsumerInterceptor
- 
This is called consumer send the cumulative acknowledgment to the broker.
- onAckTimeoutSend(Consumer<T>, Set<MessageId>) - Method in interface org.apache.pulsar.client.api.ConsumerInterceptor
- 
This method will be called when a redelivery from an acknowledge timeout occurs.
- onNegativeAcksSend(Consumer<T>, Set<MessageId>) - Method in interface org.apache.pulsar.client.api.ConsumerInterceptor
- 
This method will be called when a redelivery from a negative acknowledge occurs.
- onPartitionsChange(String, int) - Method in interface org.apache.pulsar.client.api.ConsumerInterceptor
- 
This method is called when partitions of the topic (partitioned-topic) changes.
- onPartitionsChange(String, int) - Method in interface org.apache.pulsar.client.api.interceptor.ProducerInterceptor
- 
This method is called when partitions of the topic (partitioned-topic) changes.
- onPartitionsChange(String, int) - Method in class org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
- onPartitionsChange(String, int) - Method in interface org.apache.pulsar.client.api.ProducerInterceptor
- 
Deprecated.This method is called when partitions of the topic (partitioned-topic) changes.
- onPartitionsChange(String, int) - Method in interface org.apache.pulsar.client.api.ReaderInterceptor
- 
This method is called when partitions of the topic (partitioned-topic) changes.
- onSendAcknowledgement(Producer<T>, Message<T>, MessageId, Throwable) - Method in interface org.apache.pulsar.client.api.ProducerInterceptor
- 
Deprecated.This method is called when the message sent to the broker has been acknowledged, or when sending the message fails.
- onSendAcknowledgement(Producer, Message, MessageId, Throwable) - Method in interface org.apache.pulsar.client.api.interceptor.ProducerInterceptor
- 
This method is called when the message sent to the broker has been acknowledged, or when sending the message fails.
- onSendAcknowledgement(Producer, Message, MessageId, Throwable) - Method in class org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
- OPEN - Enum constant in enum class org.apache.pulsar.client.api.transaction.Transaction.State
- 
When a transaction is in the `OPEN` state, messages can be produced and acked with this transaction.
- operationTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the operation timeout (default: 30 seconds).
- optional() - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
- 
Make this field optional.
- ORDER - Enum constant in enum class org.apache.pulsar.client.api.AutoClusterFailoverBuilder.FailoverPolicy
- orderingKey(byte[]) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Sets the ordering key of the message for message dispatch inSubscriptionType.Key_Sharedmode.
- org.apache.pulsar.client.api - package org.apache.pulsar.client.api
- 
Pulsar Client API.
- org.apache.pulsar.client.api.interceptor - package org.apache.pulsar.client.api.interceptor
- 
Pulsar interceptors.
- org.apache.pulsar.client.api.schema - package org.apache.pulsar.client.api.schema
- 
Schema definitions for Pulsar Client API.
- org.apache.pulsar.client.api.transaction - package org.apache.pulsar.client.api.transaction
- 
Pulsar transaction related API.
- org.apache.pulsar.client.internal - package org.apache.pulsar.client.internal
- 
Helpers which provide useful functionality for the implementation of Pulsar Client API.
- org.apache.pulsar.common.api - package org.apache.pulsar.common.api
- 
Common data classes used in the Pulsar Client API.
- org.apache.pulsar.common.classification - package org.apache.pulsar.common.classification
- 
Annotations used across the whole project.
- org.apache.pulsar.common.schema - package org.apache.pulsar.common.schema
- 
This package contains data structures for schema definitions used in the Pulsar Client API.
P
- PartitionedTopicProducerStats - Interface in org.apache.pulsar.client.api
- 
Partitioned topic Producer statistics recorded by client.
- patternAutoDiscoveryPeriod(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets topic's auto-discovery period when using a pattern for topics consumer.
- patternAutoDiscoveryPeriod(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets topic's auto-discovery period when using a pattern for topics consumer.
- pause() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Stop requesting new messages from the broker untilConsumer.resume()is called.
- PersistentOnly - Enum constant in enum class org.apache.pulsar.client.api.RegexSubscriptionMode
- 
Only subscribe to persistent topics.
- poolMessages(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Enable pooling of messages and the underlying data buffers.
- poolMessages(boolean) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Enable pooling of messages and the underlying data buffers.
- primary(String) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set the primary service url.
- priorityLevel(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Shared subscription
- priorityLevel(int) - Method in interface org.apache.pulsar.client.api.TopicConsumerBuilder
- 
Configure the priority level of this topic.
- process(MessagePayload, MessagePayloadContext, Schema<T>, Consumer<Message<T>>) - Method in interface org.apache.pulsar.client.api.MessagePayloadProcessor
- 
Process the message payload.
- Producer<T> - Interface in org.apache.pulsar.client.api
- 
Producer is used to publish messages on a topic.
- ProducerAccessMode - Enum Class in org.apache.pulsar.client.api
- 
The type of access to the topic that the producer requires.
- ProducerBlockedQuotaExceededError(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerBlockedQuotaExceededError
- 
Constructs anProducerBlockedQuotaExceededErrorwith the specified detail message.
- ProducerBlockedQuotaExceededException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerBlockedQuotaExceededException
- 
Constructs anProducerBlockedQuotaExceededExceptionwith the specified detail message.
- ProducerBuilder<T> - Interface in org.apache.pulsar.client.api
- 
ProducerBuilderis used to configure and create instances ofProducer.
- ProducerBusyException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerBusyException
- 
Constructs anProducerBusyExceptionwith the specified detail message.
- ProducerCryptoFailureAction - Enum Class in org.apache.pulsar.client.api
- 
The action the producer will take in case of encryption failures.
- ProducerFencedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerFencedException
- 
Constructs aProducerFencedExceptionwith the specified detail message.
- ProducerInterceptor - Interface in org.apache.pulsar.client.api.interceptor
- 
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.
- ProducerInterceptor<T> - Interface in org.apache.pulsar.client.api
- 
Deprecated.
- ProducerInterceptorWrapper - Class in org.apache.pulsar.client.api.interceptor
- 
A wrapper for old style producer interceptor.
- ProducerInterceptorWrapper(ProducerInterceptor<?>) - Constructor for class org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
- producerName(String) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Specify a name for the producer.
- ProducerQueueIsFullError(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerQueueIsFullError
- 
Constructs anProducerQueueIsFullErrorwith the specified detail message.
- ProducerQueueIsFullError(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerQueueIsFullError
- 
Constructs anProducerQueueIsFullErrorwith the specified detail message.
- ProducerStats - Interface in org.apache.pulsar.client.api
- 
Producer statistics recorded by client.
- properties(Map<String, String>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Add all the properties in the provided map to the consumer.
- properties(Map<String, String>) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Add all the properties in the provided map to the producer.
- properties(Map<String, String>) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Add all the properties in the provided map.
- properties(Map<String, String>) - Method in class org.apache.pulsar.common.schema.SchemaInfo.SchemaInfoBuilder
- PropertiesUtils - Class in org.apache.pulsar.client.internal
- 
Internal utility methods for filtering and mappingPropertiesobjects.
- PropertiesUtils() - Constructor for class org.apache.pulsar.client.internal.PropertiesUtils
- property(String, String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets a name/value property with this consumer.
- property(String, String) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set a name/value property for this producer.
- property(String, String) - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
- 
Set name-value pair properties for this field.
- property(String, String) - Method in interface org.apache.pulsar.client.api.schema.RecordSchemaBuilder
- 
Attach val-name property pair to the record schema.
- property(String, String) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Sets a new property on a message.
- PROTOBUF - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Protobuf message encoding and decoding.
- PROTOBUF(Class<T>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a Protobuf schema type by extracting the fields of the specified class.
- PROTOBUF(SchemaDefinition<T>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a Protobuf schema type with schema definition.
- PROTOBUF_NATIVE - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Protobuf native schema base on Descriptor.
- PROTOBUF_NATIVE(Class<T>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a Protobuf-Native schema type by extracting the fields of the specified class.
- PROTOBUF_NATIVE(SchemaDefinition<T>) - Static method in interface org.apache.pulsar.client.api.Schema
- 
Create a Protobuf-Native schema type with schema definition.
- ProxyProtocol - Enum Class in org.apache.pulsar.client.api
- 
Protcol type to determine type of proxy routing when client connects to proxy using {@link ClientBuilder::proxyServiceUrl}.
- proxyServiceUrl(String, ProxyProtocol) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Proxy-service url when client would like to connect to broker via proxy.
- PULSAR_AUTH_METHOD_NAME - Static variable in interface org.apache.pulsar.client.api.AuthenticationDataProvider
- PulsarClient - Interface in org.apache.pulsar.client.api
- 
Class that provides a client interface to Pulsar.
- PulsarClientException - Exception in org.apache.pulsar.client.api
- 
Base type of exception thrown by Pulsar client.
- PulsarClientException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
- 
Constructs anPulsarClientExceptionwith the specified detail message.
- PulsarClientException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
- 
Constructs anPulsarClientExceptionwith the specified detail message.
- PulsarClientException(String, Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
- 
Constructs anPulsarClientExceptionwith the specified cause.
- PulsarClientException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
- 
Constructs anPulsarClientExceptionwith the specified cause.
- PulsarClientException(Throwable, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
- 
Constructs anPulsarClientExceptionwith the specified cause.
- PulsarClientException.AlreadyClosedException - Exception in org.apache.pulsar.client.api
- 
Already closed exception thrown by Pulsar client.
- PulsarClientException.AuthenticationException - Exception in org.apache.pulsar.client.api
- 
Authentication exception thrown by Pulsar client.
- PulsarClientException.AuthorizationException - Exception in org.apache.pulsar.client.api
- 
Authorization exception thrown by Pulsar client.
- PulsarClientException.BrokerMetadataException - Exception in org.apache.pulsar.client.api
- 
Broker metadata exception thrown by Pulsar client.
- PulsarClientException.BrokerPersistenceException - Exception in org.apache.pulsar.client.api
- 
Broker persistence exception thrown by Pulsar client.
- PulsarClientException.ChecksumException - Exception in org.apache.pulsar.client.api
- 
Checksum exception thrown by Pulsar client.
- PulsarClientException.ConnectException - Exception in org.apache.pulsar.client.api
- 
Connect exception thrown by Pulsar client.
- PulsarClientException.ConsumerAssignException - Exception in org.apache.pulsar.client.api
- 
Consumer assign exception thrown by Pulsar client.
- PulsarClientException.ConsumerBusyException - Exception in org.apache.pulsar.client.api
- 
Consumer busy exception thrown by Pulsar client.
- PulsarClientException.CryptoException - Exception in org.apache.pulsar.client.api
- 
Crypto exception thrown by Pulsar client.
- PulsarClientException.FailedFeatureCheck - Enum Class in org.apache.pulsar.client.api
- 
"supports_auth_refresh" was introduced at "2.6" and is no longer supported, so skip this enum.
- PulsarClientException.FeatureNotSupportedException - Exception in org.apache.pulsar.client.api
- 
Not supported exception thrown by Pulsar client.
- PulsarClientException.GettingAuthenticationDataException - Exception in org.apache.pulsar.client.api
- 
Getting authentication data exception thrown by Pulsar client.
- PulsarClientException.IncompatibleSchemaException - Exception in org.apache.pulsar.client.api
- 
Incompatible schema exception thrown by Pulsar client.
- PulsarClientException.InvalidConfigurationException - Exception in org.apache.pulsar.client.api
- 
Invalid Configuration exception thrown by Pulsar client.
- PulsarClientException.InvalidMessageException - Exception in org.apache.pulsar.client.api
- 
Invalid message exception thrown by Pulsar client.
- PulsarClientException.InvalidServiceURL - Exception in org.apache.pulsar.client.api
- 
Invalid Service URL exception thrown by Pulsar client.
- PulsarClientException.InvalidTopicNameException - Exception in org.apache.pulsar.client.api
- 
Invalid topic name exception thrown by Pulsar client.
- PulsarClientException.LookupException - Exception in org.apache.pulsar.client.api
- 
Lookup exception thrown by Pulsar client.
- PulsarClientException.MemoryBufferIsFullError - Exception in org.apache.pulsar.client.api
- 
Memory buffer full error thrown by Pulsar client.
- PulsarClientException.MessageAcknowledgeException - Exception in org.apache.pulsar.client.api
- 
Consumer assign exception thrown by Pulsar client.
- PulsarClientException.NotAllowedException - Exception in org.apache.pulsar.client.api
- 
Not allowed exception thrown by Pulsar client.
- PulsarClientException.NotConnectedException - Exception in org.apache.pulsar.client.api
- 
Not connected exception thrown by Pulsar client.
- PulsarClientException.NotFoundException - Exception in org.apache.pulsar.client.api
- 
Not Found exception thrown by Pulsar client.
- PulsarClientException.NotSupportedException - Exception in org.apache.pulsar.client.api
- 
Not supported exception thrown by Pulsar client.
- PulsarClientException.ProducerBlockedQuotaExceededError - Exception in org.apache.pulsar.client.api
- 
Producer blocked quota exceeded error thrown by Pulsar client.
- PulsarClientException.ProducerBlockedQuotaExceededException - Exception in org.apache.pulsar.client.api
- 
Producer blocked quota exceeded exception thrown by Pulsar client.
- PulsarClientException.ProducerBusyException - Exception in org.apache.pulsar.client.api
- 
Producer busy exception thrown by Pulsar client.
- PulsarClientException.ProducerFencedException - Exception in org.apache.pulsar.client.api
- 
Producer fenced exception thrown by Pulsar client.
- PulsarClientException.ProducerQueueIsFullError - Exception in org.apache.pulsar.client.api
- 
Full producer queue error thrown by Pulsar client.
- PulsarClientException.ServiceNotReadyException - Exception in org.apache.pulsar.client.api
- 
Relates to server-side errors: ServiceUnitNotReadyException, TopicFencedException and SubscriptionFencedException.
- PulsarClientException.SubscriptionNotFoundException - Exception in org.apache.pulsar.client.api
- 
Not found subscription that cannot be created.
- PulsarClientException.TimeoutException - Exception in org.apache.pulsar.client.api
- 
Timeout exception thrown by Pulsar client.
- PulsarClientException.TooManyRequestsException - Exception in org.apache.pulsar.client.api
- 
Too many requests exception thrown by Pulsar client.
- PulsarClientException.TopicDoesNotExistException - Exception in org.apache.pulsar.client.api
- 
Topic does not exist and cannot be created.
- PulsarClientException.TopicMigrationException - Exception in org.apache.pulsar.client.api
- 
TopicMigration exception thrown by Pulsar client.
- PulsarClientException.TopicTerminatedException - Exception in org.apache.pulsar.client.api
- 
Topic terminated exception thrown by Pulsar client.
- PulsarClientException.TransactionConflictException - Exception in org.apache.pulsar.client.api
- 
Consumer assign exception thrown by Pulsar client.
- PulsarClientException.TransactionHasOperationFailedException - Exception in org.apache.pulsar.client.api
- PulsarClientException.UnsupportedAuthenticationException - Exception in org.apache.pulsar.client.api
- 
Unsupported authentication exception thrown by Pulsar client.
- PulsarClientImplementationBinding - Interface in org.apache.pulsar.client.internal
- 
Helper class for class instantiations and it also contains methods to work with schemas.
R
- Range - Class in org.apache.pulsar.client.api
- 
Int range.
- Range(int, int) - Constructor for class org.apache.pulsar.client.api.Range
- ranges - Variable in class org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
- ranges(List<Range>) - Method in class org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
- ranges(Range...) - Method in class org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
- reachedEndOfTopic(Consumer<T>) - Method in interface org.apache.pulsar.client.api.MessageListener
- 
Get the notification when a topic is terminated.
- reachedEndOfTopic(Reader<T>) - Method in interface org.apache.pulsar.client.api.ReaderListener
- 
Get the notification when a topic is terminated.
- ReachMaxPendingOpsException() - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionBufferClientException.ReachMaxPendingOpsException
- ReachMaxPendingOpsException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionBufferClientException.ReachMaxPendingOpsException
- read(byte[]) - Method in interface org.apache.pulsar.client.api.schema.SchemaReader
- 
Serialize bytes convert pojo.
- read(byte[], byte[]) - Method in interface org.apache.pulsar.client.api.schema.SchemaReader
- 
Serialize bytes convert pojo.
- read(byte[], int, int) - Method in interface org.apache.pulsar.client.api.schema.SchemaReader
- 
serialize bytes convert pojo.
- read(InputStream) - Method in interface org.apache.pulsar.client.api.schema.SchemaReader
- 
serialize bytes convert pojo.
- read(InputStream, byte[]) - Method in interface org.apache.pulsar.client.api.schema.SchemaReader
- 
serialize bytes convert pojo.
- READ_COMMITTED - Enum constant in enum class org.apache.pulsar.client.api.TransactionIsolationLevel
- READ_UNCOMMITTED - Enum constant in enum class org.apache.pulsar.client.api.TransactionIsolationLevel
- readCompacted(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
If enabled, the consumer reads messages from the compacted topic rather than the full message topic backlog.
- readCompacted(boolean) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
If enabled, the reader will read messages from the compacted topic rather than reading the full message backlog of the topic.
- Reader<T> - Interface in org.apache.pulsar.client.api
- 
A Reader can be used to scan through all the messages currently available in a topic.
- ReaderBuilder<T> - Interface in org.apache.pulsar.client.api
- 
ReaderBuilderis used to configure and create instances ofReader.
- ReaderInterceptor<T> - Interface in org.apache.pulsar.client.api
- 
Reader interceptor.
- readerListener(ReaderListener<T>) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Sets aReaderListenerfor the reader.
- ReaderListener<T> - Interface in org.apache.pulsar.client.api
- 
A listener that will be called in order for every message received.
- readerName(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Specify a reader name.
- readNext() - Method in interface org.apache.pulsar.client.api.Reader
- 
Read the next message in the topic.
- readNext(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.Reader
- 
Read the next message in the topic waiting for a maximum time.
- readNextAsync() - Method in interface org.apache.pulsar.client.api.Reader
- 
Read asynchronously the next message in the topic.
- READY - Enum constant in enum class org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
- receive() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Receives a single message in blocking mode.
- receive(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Receive a single message.
- receiveAsync() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Receive a single message
- received(Consumer<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.MessageListener
- 
This method is called whenever a new message is received.
- received(Reader<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.ReaderListener
- 
This method is called whenever a new message is received.
- receiverQueueSize(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the size of the consumer receive queue.
- receiverQueueSize(int) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Sets the size of the consumer receive queue.
- reconsumeLater(Message<?>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
reconsumeLater the consumption ofMessages.
- reconsumeLater(Message<?>, Map<String, String>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
reconsumeLater the consumption ofMessages.
- reconsumeLater(Messages<?>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
reconsumeLater the consumption ofMessages.
- reconsumeLaterAsync(Message<?>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Asynchronously reconsumeLater the consumption of a single message.
- reconsumeLaterAsync(Message<?>, Map<String, String>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Asynchronously reconsumeLater the consumption of a single message.
- reconsumeLaterAsync(Messages<?>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Asynchronously reconsumeLater the consumption ofMessages.
- reconsumeLaterCumulative(Message<?>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
reconsumeLater the reception of all the messages in the stream up to (and including) the provided message.
- reconsumeLaterCumulativeAsync(Message<?>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Asynchronously ReconsumeLater the reception of all the messages in the stream up to (and including) the provided message.
- reconsumeLaterCumulativeAsync(Message<?>, Map<String, String>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Asynchronously ReconsumeLater the reception of all the messages in the stream up to (and including) the provided message.
- record(String) - Static method in interface org.apache.pulsar.client.api.schema.SchemaBuilder
- 
Build the schema for a record.
- RecordSchemaBuilder - Interface in org.apache.pulsar.client.api.schema
- 
Building the schema for aGenericRecord.
- redeliverUnacknowledgedMessages() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Redelivers all the unacknowledged messages.
- RedeliveryBackoff - Interface in org.apache.pulsar.client.api
- 
Interface for custom message is negativeAcked policy, users can specify aRedeliveryBackofffor a consumer.
- REFRESH_AUTH_DATA - Static variable in class org.apache.pulsar.common.api.AuthData
- REFRESH_AUTH_DATA_BYTES - Static variable in class org.apache.pulsar.common.api.AuthData
- RegexSubscriptionMode - Enum Class in org.apache.pulsar.client.api
- 
When subscribing to topics using a regular expression, one can specify to only pick a certain type of topics.
- release() - Method in interface org.apache.pulsar.client.api.Message
- 
Release a message back to the pool.
- release() - Method in interface org.apache.pulsar.client.api.MessagePayload
- 
Release the resources if necessary.
- removeKeyCipher(String) - Method in interface org.apache.pulsar.client.api.MessageCrypto
- replicateSubscriptionState(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- replicationClusters(List<String>) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Override the geo-replication clusters for this message.
- RequestTimeoutException() - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionBufferClientException.RequestTimeoutException
- RequestTimeoutException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionBufferClientException.RequestTimeoutException
- required() - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
- 
Make this field required.
- requireFetchingSchemaInfo() - Method in interface org.apache.pulsar.client.api.Schema
- 
Check if this schema requires fetching schema info to configure the schema.
- resume() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Resume requesting messages from the broker.
- RoundRobinPartition - Enum constant in enum class org.apache.pulsar.client.api.MessageRoutingMode
- 
If no key is provided, the producer will publish messages across all partitions in round-robin fashion to achieve maximum throughput.
- roundRobinRouterBatchingPartitionSwitchFrequency(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the partition switch frequency while batching of messages is enabled and using round-robin routing mode for non-keyed messages.
S
- schema(byte[]) - Method in class org.apache.pulsar.common.schema.SchemaInfo.SchemaInfoBuilder
- Schema<T> - Interface in org.apache.pulsar.client.api
- 
Message schema definition.
- SchemaBuilder - Interface in org.apache.pulsar.client.api.schema
- 
Builder to build schema.
- SchemaDefinition<T> - Interface in org.apache.pulsar.client.api.schema
- 
Interface for schema definition.
- SchemaDefinitionBuilder<T> - Interface in org.apache.pulsar.client.api.schema
- 
Builder to build schema definitionSchemaDefinition.
- SchemaInfo - Interface in org.apache.pulsar.common.schema
- 
Information about the schema.
- SchemaInfo.SchemaInfoBuilder - Class in org.apache.pulsar.common.schema
- SchemaInfoProvider - Interface in org.apache.pulsar.client.api.schema
- 
Schema Provider.
- SchemaInfoWithVersion - Class in org.apache.pulsar.common.schema
- 
Data structure representing a schema information including its version.
- SchemaInfoWithVersion() - Constructor for class org.apache.pulsar.common.schema.SchemaInfoWithVersion
- SchemaReader<T> - Interface in org.apache.pulsar.client.api.schema
- 
Deserialize messages from bytes.
- SchemaSerializationException - Exception in org.apache.pulsar.client.api
- 
Schema serialization exception.
- SchemaSerializationException(String) - Constructor for exception org.apache.pulsar.client.api.SchemaSerializationException
- 
Constructs anSchemaSerializationExceptionwith the specified detail message.
- SchemaSerializationException(Throwable) - Constructor for exception org.apache.pulsar.client.api.SchemaSerializationException
- 
Constructs anSchemaSerializationExceptionwith the specified cause.
- SchemaType - Enum Class in org.apache.pulsar.common.schema
- 
Types of supported schema for Pulsar messages.
- SchemaWriter<T> - Interface in org.apache.pulsar.client.api.schema
- 
Serialize messages into bytes.
- secondary(List<String>) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set the secondary service url.
- secondaryAuthentication(Map<String, Authentication>) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set secondary authentication.
- secondaryTlsTrustCertsFilePath(Map<String, String>) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set secondary tlsTrustCertsFilePath.
- secondaryTlsTrustStorePassword(Map<String, String>) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set secondary tlsTrustStorePassword.
- secondaryTlsTrustStorePath(Map<String, String>) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set secondary tlsTrustStorePath.
- seek(long) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Reset the subscription associated with this consumer to a specific message publish time.
- seek(long) - Method in interface org.apache.pulsar.client.api.Reader
- 
Reset the subscription associated with this reader to a specific message publish time.
- seek(Function<String, Object>) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Reset the subscription associated with this consumer to a specific message ID or message publish time.
- seek(Function<String, Object>) - Method in interface org.apache.pulsar.client.api.Reader
- 
Reset the subscription associated with this consumer to a specific message ID or message publish time.
- seek(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Reset the subscription associated with this consumer to a specific message id.
- seek(MessageId) - Method in interface org.apache.pulsar.client.api.Reader
- 
Reset the subscription associated with this reader to a specific message id.
- seekAsync(long) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Reset the subscription associated with this consumer to a specific message publish time.
- seekAsync(long) - Method in interface org.apache.pulsar.client.api.Reader
- 
Reset the subscription associated with this reader to a specific message publish time.
- seekAsync(Function<String, Object>) - Method in interface org.apache.pulsar.client.api.Consumer
- 
Reset the subscription associated with this consumer to a specific message ID or message publish time asynchronously.
- seekAsync(Function<String, Object>) - Method in interface org.apache.pulsar.client.api.Reader
- 
Reset the subscription associated with this consumer to a specific message ID or message publish time asynchronously.
- seekAsync(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
- 
The asynchronous version ofConsumer.seek(MessageId).
- seekAsync(MessageId) - Method in interface org.apache.pulsar.client.api.Reader
- 
Reset the subscription associated with this reader to a specific message id.
- send() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Send a message synchronously.
- send(T) - Method in interface org.apache.pulsar.client.api.Producer
- 
Sends a message.
- SEND - Enum constant in enum class org.apache.pulsar.client.api.ProducerCryptoFailureAction
- 
Ignore crypto failure and proceed with sending unencrypted messages.
- sendAsync() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Send a message asynchronously
- sendAsync(T) - Method in interface org.apache.pulsar.client.api.Producer
- 
Send a message asynchronously.
- sendTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Set the send timeout (default: 30 seconds).
- SEPARATED - Enum constant in enum class org.apache.pulsar.common.schema.KeyValueEncodingType
- 
Key is stored as message key, while value is stored as message payload.
- sequenceId(long) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Specify a custom sequence id for the message being published.
- ServiceNotReadyException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ServiceNotReadyException
- serviceUrl(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Configure the service URL for the Pulsar service.
- serviceUrlProvider(ServiceUrlProvider) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Configure the service URL provider for Pulsar service.
- ServiceUrlProvider - Interface in org.apache.pulsar.client.api
- 
The provider to provide the service url.
- set(String, Object) - Method in interface org.apache.pulsar.client.api.schema.GenericRecordBuilder
- 
Sets the value of a field.
- set(Field, Object) - Method in interface org.apache.pulsar.client.api.schema.GenericRecordBuilder
- 
Sets the value of a field.
- setAllowOutOfOrderDelivery(boolean) - Method in class org.apache.pulsar.client.api.KeySharedPolicy
- 
If enabled, it will relax the ordering requirement, allowing the broker to send out-of-order messages in case of failures.
- setKey(byte[]) - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
- setMetadata(Map<String, String>) - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
- setPreviousExceptions(Throwable, Collection<Throwable>) - Static method in exception org.apache.pulsar.client.api.PulsarClientException
- setPreviousExceptions(Collection<Throwable>) - Method in exception org.apache.pulsar.client.api.PulsarClientException
- 
Add a list of previous exception which occurred for the same operation and have been retried.
- setSchemaInfoProvider(SchemaInfoProvider) - Method in interface org.apache.pulsar.client.api.schema.SchemaReader
- 
Set schema info provider, this method support multi version reader.
- setSchemaInfoProvider(SchemaInfoProvider) - Method in interface org.apache.pulsar.client.api.Schema
- setSequenceId(long) - Method in exception org.apache.pulsar.client.api.PulsarClientException
- Shared - Enum constant in enum class org.apache.pulsar.client.api.ProducerAccessMode
- 
By default multiple producers can publish on a topic.
- Shared - Enum constant in enum class org.apache.pulsar.client.api.SubscriptionType
- 
Multiple consumer will be able to use the same subscription name and the messages will be dispatched according to a round-robin rotation between the connected consumers.
- shutdown() - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Perform immediate shutdown of PulsarClient.
- SinglePartition - Enum constant in enum class org.apache.pulsar.client.api.MessageRoutingMode
- 
If no key is provided, The partitioned producer will randomly pick one single partition and publish all the messages into that partition.
- size() - Method in interface org.apache.pulsar.client.api.Message
- 
Get the uncompressed message payload size in bytes.
- size() - Method in interface org.apache.pulsar.client.api.Messages
- 
Get number of messages.
- size() - Method in interface org.apache.pulsar.client.api.TableView
- 
Returns the number of key-value mappings in theTableView.
- SizeUnit - Enum Class in org.apache.pulsar.client.api
- 
Size unit converter.
- SNAPPY - Enum constant in enum class org.apache.pulsar.client.api.CompressionType
- 
Compress with Snappy codec.
- SNI - Enum constant in enum class org.apache.pulsar.client.api.ProxyProtocol
- 
Follows SNI-routing https://docs.trafficserver.apache.org/en/latest/admin-guide/layer-4-routing.en.html#sni-routing.
- socks5ProxyAddress(InetSocketAddress) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set socks5 proxy address.
- socks5ProxyPassword(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set socks5 proxy password.
- socks5ProxyUsername(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set socks5 proxy username.
- sslProvider(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
The name of the security provider used for SSL connections.
- start() - Method in interface org.apache.pulsar.client.api.Authentication
- 
Initialize the authentication provider.
- start() - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Start transaction meta store client.
- startAsync() - Method in interface org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
- 
Start transaction meta store client asynchronous.
- STARTING - Enum constant in enum class org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
- startingBackoffInterval(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the duration of time for a backoff interval.
- startMessageFromRollbackDuration(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
The initial reader positioning can be set at specific timestamp by providing total rollback duration.
- startMessageId(MessageId) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
The initial reader positioning is done by specifying a message id.
- startMessageIdInclusive() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets the consumer to include the given position of any reset operation likeConsumer.seek(long)orConsumer.seek(MessageId)}.
- startMessageIdInclusive() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Set the reader to include the given position ofReaderBuilder.startMessageId(MessageId)
- startPaused(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Starts the consumer in a paused state.
- statsInterval(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the interval between each stat info (default: 60 seconds) Stats will be activated with positive statsInterval It should be set to at least 1 second.
- STICKY - Enum constant in enum class org.apache.pulsar.client.api.KeySharedMode
- 
New consumer with fixed hash range to attach the topic, if new consumer use conflict hash range with exits consumers, new consumer will be rejected.
- stickyHashRange() - Static method in class org.apache.pulsar.client.api.KeySharedPolicy
- STRING - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Simple String encoding with UTF-8.
- STRING - Static variable in interface org.apache.pulsar.client.api.Schema
- 
Schema that can be used to encode/decode messages whose values are String.
- subscribe() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Finalize theConsumercreation by subscribing to the topic.
- subscribeAsync() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Finalize theConsumercreation by subscribing to the topic in asynchronous mode.
- subscriptionInitialPosition(SubscriptionInitialPosition) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Sets theSubscriptionInitialPositionfor the consumer.
- SubscriptionInitialPosition - Enum Class in org.apache.pulsar.client.api
- 
When creating a consumer, if the subscription does not exist, a new subscription will be created.
- subscriptionMode(SubscriptionMode) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Selects the subscription mode to be used when subscribing to a topic.
- SubscriptionMode - Enum Class in org.apache.pulsar.client.api
- 
Types of subscription mode supported by Pulsar.
- subscriptionName(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Specify the subscription name for this consumer.
- subscriptionName(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Set the subscription name.
- subscriptionName(String) - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Set the subscription name of theTableView.
- SubscriptionNotFoundException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.SubscriptionNotFoundException
- 
Constructs anSubscriptionNotFoundExceptionwith the specified detail message.
- subscriptionProperties(Map<String, String>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Specify the subscription properties for this subscription.
- subscriptionRolePrefix(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Set the subscription role prefix.
- subscriptionTopicsMode(RegexSubscriptionMode) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Determines which topics this consumer should be subscribed to - Persistent, Non-Persistent, or both.
- subscriptionType(SubscriptionType) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Select the subscription type to be used when subscribing to a topic.
- SubscriptionType - Enum Class in org.apache.pulsar.client.api
- 
Types of subscription supported by Pulsar.
- supportSchemaVersioning() - Method in interface org.apache.pulsar.client.api.Schema
- 
Returns whether this schema supports versioning.
- SupportsGetPartitionedMetadataWithoutAutoCreation - Enum constant in enum class org.apache.pulsar.client.api.PulsarClientException.FailedFeatureCheck
- switchBackDelay(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.AutoClusterFailoverBuilder
- 
Set the switchBackDelay.
T
- TableView<T> - Interface in org.apache.pulsar.client.api
- TableViewBuilder<T> - Interface in org.apache.pulsar.client.api
- 
TableViewBuilderis used to configure and create instances ofTableView.
- TIME - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Time.
- TIME - Static variable in interface org.apache.pulsar.client.api.Schema
- 
Time Schema.
- TIME_OUT - Enum constant in enum class org.apache.pulsar.client.api.transaction.Transaction.State
- 
When a transaction is timed out and the transaction state is `OPEN`, then the transaction state is changed from `OPEN` to `TIME_OUT`.
- timeout(int, TimeUnit) - Method in class org.apache.pulsar.client.api.BatchReceivePolicy.Builder
- TimeoutException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TimeoutException
- 
Constructs anTimeoutExceptionwith the specified detail message.
- TimeoutException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TimeoutException
- 
Constructs anTimeoutExceptionwith the specified detail message.
- TimeoutException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TimeoutException
- 
Constructs anTimeoutExceptionwith the specified cause.
- TimeoutException(Throwable, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TimeoutException
- 
Constructs anTimeoutExceptionwith the specified cause.
- timestamp(long) - Method in class org.apache.pulsar.common.schema.SchemaInfo.SchemaInfoBuilder
- TIMESTAMP - Enum constant in enum class org.apache.pulsar.common.schema.SchemaType
- 
Timestamp.
- TIMESTAMP - Static variable in interface org.apache.pulsar.client.api.Schema
- 
Timestamp Schema.
- TLS(String, String) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
- 
Create an authentication provider for TLS based authentication.
- tlsCertificateFilePath(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the path to the TLS certificate file.
- tlsCiphers(Set<String>) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
A list of cipher suites.
- tlsKeyFilePath(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the path to the TLS key file.
- tlsKeyStorePassword(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
The store password for the key store file.
- tlsKeyStorePath(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
The location of the key store file.
- tlsKeyStoreType(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
The file format of the key store file.
- tlsProtocols(Set<String>) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
The SSL protocol used to generate the SSLContext.
- tlsTrustCertsFilePath(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
Set the path to the trusted TLS certificate file.
- tlsTrustStorePassword(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
The store password for the key store file.
- tlsTrustStorePath(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
The location of the trust store file.
- tlsTrustStoreType(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
The file format of the trust store file.
- toByteArray() - Method in interface org.apache.pulsar.client.api.MessageId
- 
Serialize the message ID into a byte array.
- toBytes(long) - Method in enum class org.apache.pulsar.client.api.SizeUnit
- toGigaBytes(long) - Method in enum class org.apache.pulsar.client.api.SizeUnit
- token(String) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
- 
Create an authentication provider for token based authentication.
- token(Supplier<String>) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
- 
Create an authentication provider for token based authentication.
- toKiloBytes(long) - Method in enum class org.apache.pulsar.client.api.SizeUnit
- toMegaBytes(long) - Method in enum class org.apache.pulsar.client.api.SizeUnit
- TooManyRequestsException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TooManyRequestsException
- 
Constructs anTooManyRequestsExceptionwith the specified detail message.
- topic(String) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
- 
Specify the topic this producer will be publishing on.
- topic(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Specify the topic this reader will read from.
- topic(String) - Method in interface org.apache.pulsar.client.api.TableViewBuilder
- 
Set the topic name of theTableView.
- topic(String...) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Specify the topics this consumer subscribes to.
- topicConfiguration(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Configure topic specific options to override those set at theConsumerBuilderlevel.
- topicConfiguration(String, Consumer<TopicConsumerBuilder<T>>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Configure topic specific options to override those set at theConsumerBuilderlevel.
- topicConfiguration(Pattern) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Configure topic specific options to override those set at theConsumerBuilderlevel.
- topicConfiguration(Pattern, Consumer<TopicConsumerBuilder<T>>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Configure topic specific options to override those set at theConsumerBuilderlevel.
- TopicConsumerBuilder<T> - Interface in org.apache.pulsar.client.api
- 
TopicConsumerBuilderis used to configure topic specific options to override those set at theConsumerBuilderlevel.
- TopicDoesNotExistException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TopicDoesNotExistException
- 
Constructs anTopicDoesNotExistExceptionwith the specified detail message.
- TopicMessageId - Interface in org.apache.pulsar.client.api
- 
The MessageId used for a consumer that subscribes multiple topics or partitioned topics.
- TopicMetadata - Interface in org.apache.pulsar.client.api
- 
Metadata of a topic that can be used for message routing.
- TopicMigrationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TopicMigrationException
- 
Constructs anTopicMigrationExceptionwith the specified detail message.
- topics(List<String>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Specify a list of topics that this consumer subscribes to.
- topics(List<String>) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
- 
Specify topics this reader will read from.
- topicsPattern(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Specify a pattern for topics(not contains the partition suffix) that this consumer subscribes to.
- topicsPattern(Pattern) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
- 
Specify a pattern for topics(not contains the partition suffix) that this consumer subscribes to.
- TopicTerminatedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TopicTerminatedException
- 
Constructs anTopicTerminatedExceptionwith the specified detail message.
- TopicTerminatedException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TopicTerminatedException
- 
Constructs anTopicTerminatedExceptionwith the specified detail message.
- toString() - Method in class org.apache.pulsar.client.api.BatchReceivePolicy
- toString() - Method in exception org.apache.pulsar.client.api.PulsarClientException
- toString() - Method in class org.apache.pulsar.client.api.Range
- toString() - Method in class org.apache.pulsar.client.api.transaction.TxnID
- toString() - Method in class org.apache.pulsar.common.schema.KeyValue
- toString() - Method in class org.apache.pulsar.common.schema.SchemaInfoWithVersion
- Transaction - Interface in org.apache.pulsar.client.api.transaction
- 
The class represents a transaction within Pulsar.
- Transaction.State - Enum Class in org.apache.pulsar.client.api.transaction
- TransactionBufferClient - Interface in org.apache.pulsar.client.api.transaction
- 
The transaction buffer client to commit and abort transactions on topics or subscription.
- TransactionBufferClientException - Exception in org.apache.pulsar.client.api.transaction
- 
Exceptions for transaction buffer client.
- TransactionBufferClientException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionBufferClientException
- TransactionBufferClientException(Throwable) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionBufferClientException
- TransactionBufferClientException.ReachMaxPendingOpsException - Exception in org.apache.pulsar.client.api.transaction
- 
Thrown when transaction buffer op over max pending numbers.
- TransactionBufferClientException.RequestTimeoutException - Exception in org.apache.pulsar.client.api.transaction
- 
Thrown when operation timeout.
- TransactionBuilder - Interface in org.apache.pulsar.client.api.transaction
- 
The builder to build a transaction for Pulsar.
- TransactionConflictException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TransactionConflictException
- 
Constructs anTransactionConflictExceptionwith the specified detail message.
- TransactionConflictException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TransactionConflictException
- 
Constructs anTransactionConflictExceptionwith the specified cause.
- TransactionCoordinatorClient - Interface in org.apache.pulsar.client.api.transaction
- 
Transaction coordinator client.
- TransactionCoordinatorClient.State - Enum Class in org.apache.pulsar.client.api.transaction
- 
State of the transaction coordinator client.
- TransactionCoordinatorClientException - Exception in org.apache.pulsar.client.api.transaction
- 
Exceptions for transaction coordinator client.
- TransactionCoordinatorClientException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException
- TransactionCoordinatorClientException(Throwable) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException
- TransactionCoordinatorClientException.CoordinatorClientStateException - Exception in org.apache.pulsar.client.api.transaction
- 
Thrown when transaction coordinator with unexpected state.
- TransactionCoordinatorClientException.CoordinatorNotFoundException - Exception in org.apache.pulsar.client.api.transaction
- 
Thrown when transaction coordinator not found in broker side.
- TransactionCoordinatorClientException.InvalidTxnStatusException - Exception in org.apache.pulsar.client.api.transaction
- 
Thrown when transaction switch to a invalid status.
- TransactionCoordinatorClientException.MetaStoreHandlerNotExistsException - Exception in org.apache.pulsar.client.api.transaction
- 
Thrown when transaction meta store handler not exists.
- TransactionCoordinatorClientException.MetaStoreHandlerNotReadyException - Exception in org.apache.pulsar.client.api.transaction
- 
Thrown when send request to transaction meta store but the transaction meta store handler not ready.
- TransactionCoordinatorClientException.TransactionNotFoundException - Exception in org.apache.pulsar.client.api.transaction
- 
Thrown when transaction not found in transaction coordinator.
- TransactionHasOperationFailedException() - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TransactionHasOperationFailedException
- 
Constructs anTransactionHasOperationFailedException.
- TransactionHasOperationFailedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TransactionHasOperationFailedException
- 
Constructs anTransactionHasOperationFailedExceptionwith the specified detail message.
- TransactionIsolationLevel - Enum Class in org.apache.pulsar.client.api
- TransactionNotFoundException(String) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.TransactionNotFoundException
- TxnID - Class in org.apache.pulsar.client.api.transaction
- 
An identifier for representing a transaction.
- TxnID(long, long) - Constructor for class org.apache.pulsar.client.api.transaction.TxnID
- type(SchemaType) - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
- 
The type of this field.
- type(SchemaType) - Method in class org.apache.pulsar.common.schema.SchemaInfo.SchemaInfoBuilder
- TypedMessageBuilder<T> - Interface in org.apache.pulsar.client.api
- 
Message builder that constructs a message to be published through a producer.
U
- unsubscribe() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Unsubscribe the consumer.
- unsubscribeAsync() - Method in interface org.apache.pulsar.client.api.Consumer
- 
Asynchronously unsubscribe the consumer.
- UnsupportedAuthenticationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.UnsupportedAuthenticationException
- 
Constructs anUnsupportedAuthenticationExceptionwith the specified detail message.
- UnsupportedAuthenticationException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.UnsupportedAuthenticationException
- 
Constructs anUnsupportedAuthenticationExceptionwith the specified cause.
- unwrap(Throwable) - Static method in exception org.apache.pulsar.client.api.PulsarClientException
- unwrap(Throwable) - Static method in exception org.apache.pulsar.client.api.transaction.TransactionBufferClientException
- unwrap(Throwable) - Static method in exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException
- updateServiceUrl(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
- 
Update the service URL this client is using.
- urlProvider(String) - Method in interface org.apache.pulsar.client.api.ControlledClusterFailoverBuilder
- 
Set the service url provider.
- urlProviderHeader(Map<String, String>) - Method in interface org.apache.pulsar.client.api.ControlledClusterFailoverBuilder
- 
Set the service url provider header to authenticate provider service.
- useKeyStoreTls(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
- 
If Tls is enabled, whether use KeyStore type as tls configuration parameter.
V
- validate() - Method in class org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicyAutoSplit
- validate() - Method in class org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
- validate() - Method in class org.apache.pulsar.client.api.KeySharedPolicy
- validate(byte[]) - Method in interface org.apache.pulsar.client.api.Schema
- 
Check if the message is a valid object for this schema.
- value(T) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
- 
Set a domain object on the message.
- valueOf(int) - Static method in enum class org.apache.pulsar.common.schema.SchemaType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.AutoClusterFailoverBuilder.FailoverPolicy
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.CompressionType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.ConsumerCryptoFailureAction
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.HashingScheme
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.KeySharedMode
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.MessageRoutingMode
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.ProducerAccessMode
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.ProducerCryptoFailureAction
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.ProxyProtocol
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.PulsarClientException.FailedFeatureCheck
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.RegexSubscriptionMode
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.SizeUnit
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.SubscriptionInitialPosition
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.SubscriptionMode
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.SubscriptionType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.transaction.Transaction.State
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.client.api.TransactionIsolationLevel
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.common.schema.KeyValueEncodingType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.pulsar.common.schema.SchemaType
- 
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.apache.pulsar.client.api.AutoClusterFailoverBuilder.FailoverPolicy
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.CompressionType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.ConsumerCryptoFailureAction
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.HashingScheme
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.KeySharedMode
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.MessageRoutingMode
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.ProducerAccessMode
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.ProducerCryptoFailureAction
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.ProxyProtocol
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.PulsarClientException.FailedFeatureCheck
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.RegexSubscriptionMode
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.SizeUnit
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.SubscriptionInitialPosition
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.SubscriptionMode
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.SubscriptionType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in interface org.apache.pulsar.client.api.TableView
- 
Returns a Collection view of the values contained in thisTableView.
- values() - Static method in enum class org.apache.pulsar.client.api.transaction.Transaction.State
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.client.api.TransactionIsolationLevel
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.common.schema.KeyValueEncodingType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.pulsar.common.schema.SchemaType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- verify() - Method in class org.apache.pulsar.client.api.BatchReceivePolicy
W
- WaitForExclusive - Enum constant in enum class org.apache.pulsar.client.api.ProducerAccessMode
- 
Producer creation is pending until it can acquire exclusive access.
- withAlwaysAllowNull(boolean) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema whether always allow null or not.
- withClassLoader(ClassLoader) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema of pojo classLoader.
- withJsonDef(String) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema of json definition.
- withJSR310ConversionEnabled(boolean) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema use JRS310 conversion or not.
- withPojo(Class) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema of pojo definition.
- withProperties(Map<String, String>) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema info properties.
- withSchemaReader(SchemaReader<T>) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema reader for deserialization of object data.
- withSchemaWriter(SchemaWriter<T>) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema writer for serialization of objects.
- withSupportSchemaVersioning(boolean) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
- 
Set schema whether decode by schema version.
- withTransactionTimeout(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.transaction.TransactionBuilder
- 
Configure the maximum amount of time that the transaction coordinator will for a transaction to be completed by the client before proactively aborting the ongoing transaction.
- wrap(byte[]) - Method in interface org.apache.pulsar.client.api.MessagePayloadFactory
- 
Create a payload whose underlying buffer refers to a byte array.
- wrap(Throwable, String) - Static method in exception org.apache.pulsar.client.api.PulsarClientException
- wrap(ByteBuffer) - Method in interface org.apache.pulsar.client.api.MessagePayloadFactory
- 
Create a payload whose underlying buffer refers to a NIO buffer.
- write(T) - Method in interface org.apache.pulsar.client.api.schema.SchemaWriter
- 
Serialize the message into bytes.
Z
- ZLIB - Enum constant in enum class org.apache.pulsar.client.api.CompressionType
- 
Compress with ZLib.
- ZSTD - Enum constant in enum class org.apache.pulsar.client.api.CompressionType
- 
Compress with Zstandard codec.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
MessageRouter.choosePartition(Message, TopicMetadata)instead.