- 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.
- acknowledge(Message<?>) - Method in interface org.apache.pulsar.client.api.Consumer
-
Acknowledge the consumption of a single message.
- acknowledge(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
-
Acknowledge the consumption of a single message, identified by its
MessageId
.
- acknowledge(Messages<?>) - Method in interface org.apache.pulsar.client.api.Consumer
-
Acknowledge the consumption of
Messages
.
- acknowledgeAsync(Message<?>) - Method in interface org.apache.pulsar.client.api.Consumer
-
Asynchronously acknowledge the consumption of a single message.
- acknowledgeAsync(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
-
Asynchronously acknowledge the consumption of a single message.
- acknowledgeAsync(Messages<?>) - Method in interface org.apache.pulsar.client.api.Consumer
-
Asynchronously acknowledge the consumption of
Messages
.
- acknowledgeCumulative(Message<?>) - Method in interface org.apache.pulsar.client.api.Consumer
-
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.
- acknowledgeCumulative(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
-
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.Consumer
-
Asynchronously Acknowledge the reception of all the messages in the stream up to (and including) the provided
message.
- acknowledgeCumulativeAsync(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
-
Asynchronously Acknowledge the reception of all the messages in the stream up to (and including) the provided
message.
- acknowledgmentGroupTime(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Group the consumer acknowledgments for the specified time.
- ackTimeout(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set the timeout for unacked messages, truncated to the nearest millisecond.
- 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.
- 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).
- AlreadyClosedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AlreadyClosedException
-
Constructs an AlreadyClosedException
with the specified detail message.
- AlreadyClosedException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AlreadyClosedException
-
Constructs an AlreadyClosedException
with the specified detail message.
- 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 - Interface in org.apache.pulsar.client.api
-
Interface of authentication providers.
- authentication(Authentication) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Set the authentication provider to use in the Pulsar client instance.
- 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.
- 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 an AuthenticationException
with the specified detail message.
- AuthenticationFactory - Class in org.apache.pulsar.client.api
-
Factory class that allows to create
Authentication
instances
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 an AuthorizationException
with the specified detail message.
- AUTO() - Static method in interface org.apache.pulsar.client.api.Schema
-
Deprecated.
- 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.
- 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 @maxPendingChuckedMessage threshold.
- 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 will auto subscribe for partitions increasement.
- autoUpdatePartitions(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
If enabled, partitioned producer will automatically discover new partitions at runtime.
- 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.
- BatcherBuilder - Interface in org.apache.pulsar.client.api
-
Batcher builder.
- batcherBuilder(BatcherBuilder) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
- 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 the messages sent will be batched default: 1 ms 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 - Class in org.apache.pulsar.client.api
-
- batchReceivePolicy(BatchReceivePolicy) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
- 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
-
- beforeSend(Producer, Message) - Method in interface org.apache.pulsar.client.api.interceptor.ProducerInterceptor
-
- beforeSend(Producer, Message) - Method in class org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
-
- beforeSend(Producer<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.ProducerInterceptor
-
Deprecated.
- blockIfQueueFull(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
- BOOL - Static variable in interface org.apache.pulsar.client.api.Schema
-
Boolean Schema.
- BrokerMetadataException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.BrokerMetadataException
-
Constructs an BrokerMetadataException
with the specified detail message.
- BrokerPersistenceException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.BrokerPersistenceException
-
Constructs an BrokerPersistenceException
with the specified detail message.
- 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
-
- build() - Method in interface org.apache.pulsar.client.api.schema.GenericRecordBuilder
-
Build a generic record.
- build(SchemaType) - Method in interface org.apache.pulsar.client.api.schema.RecordSchemaBuilder
-
Build the schema info.
- build() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
-
Build the schema definition.
- build() - Method in interface org.apache.pulsar.client.api.transaction.TransactionBuilder
-
Build the transaction with the configured settings.
- builder() - Static method in class org.apache.pulsar.client.api.BatchReceivePolicy
-
- Builder() - Constructor for class org.apache.pulsar.client.api.BatchReceivePolicy.Builder
-
- builder() - Static method in interface org.apache.pulsar.client.api.PulsarClient
-
Get a new builder instance that can used to configure and build a
PulsarClient
instance.
- builder() - Static method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
-
Get a new builder instance that can used to configure and build a
SchemaDefinition
instance.
- BYTEBUFFER - Static variable in interface org.apache.pulsar.client.api.Schema
-
ByteBuffer Schema.
- BYTES - Static variable in interface org.apache.pulsar.client.api.Schema
-
Schema that doesn't perform any encoding on the message payloads.
- ChecksumException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ChecksumException
-
Constructs an ChecksumException
with the specified detail message.
- choosePartition(Message<?>) - Method in interface org.apache.pulsar.client.api.MessageRouter
-
- choosePartition(Message<?>, TopicMetadata) - Method in interface org.apache.pulsar.client.api.MessageRouter
-
Choose a partition based on msg and the topic metadata.
- 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 a
PulsarClient
instance.
- 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
-
- clone() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
- 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.
- 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.transaction.TransactionCoordinatorClient
-
Close the transaction meta store client asynchronous.
- 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.
- CompressionType - Enum in org.apache.pulsar.client.api
-
The compression type that can be specified on a
Producer
.
- compressionType(CompressionType) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set the compression type for the producer.
- 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(Map<String, String>) - Method in interface org.apache.pulsar.client.api.Authentication
-
- 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.
- configureSchemaInfo(String, String, SchemaInfo) - Method in interface org.apache.pulsar.client.api.Schema
-
Configure the schema to use the provided schema info.
- ConnectException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConnectException
-
Constructs an ConnectException
with the specified cause.
- ConnectException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConnectException
-
Constructs an ConnectException
with the specified detail message.
- 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.
- 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 an ConsumerAssignException
with the specified detail message.
- ConsumerBuilder<T> - Interface in org.apache.pulsar.client.api
-
- ConsumerBusyException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConsumerBusyException
-
Constructs an ConsumerBusyException
with the specified detail message.
- ConsumerCryptoFailureAction - Enum 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
-
- 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
-
Set the consumer name.
- ConsumerStats - Interface in org.apache.pulsar.client.api
-
Consumer statistics recorded by client.
- convertKeyValueDataStringToSchemaInfoSchema(byte[]) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
Convert the key/value schema info data json bytes to key/value schema info data bytes.
- convertKeyValueSchemaInfoDataToString(KeyValue<SchemaInfo, SchemaInfo>) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
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
-
- create(String, String) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
-
Create an instance of the
Authentication
object 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() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Finalize the creation of the
Producer
instance.
- create() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Finalize the creation of the
Reader
instance.
- createAsync() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Finalize the creation of the
Producer
instance in asynchronous mode.
- createAsync() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Finalize the creation of the
Reader
instance in asynchronous mode.
- createAuthentication(String, String) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- createAuthentication(String, Map<String, String>) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- CryptoException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.CryptoException
-
Constructs an CryptoException
with the specified detail message.
- cryptoFailureAction(ConsumerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Sets the ConsumerCryptoFailureAction to the value specified.
- cryptoFailureAction(ProducerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Sets the ProducerCryptoFailureAction to the value specified.
- cryptoFailureAction(ConsumerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
- CryptoKeyReader - Interface in org.apache.pulsar.client.api
-
Interface that abstracts the access to a key store.
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
- DATE - Static variable in interface org.apache.pulsar.client.api.Schema
-
Date Schema.
- deadLetterPolicy(DeadLetterPolicy) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set dead letter policy for 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[], KeyValue.KeyValueDecoder<K, V>) - Static method in class org.apache.pulsar.common.schema.KeyValue
-
Decode the value into a key/value pair.
- decode(byte[], byte[]) - Method in interface org.apache.pulsar.common.schema.KeyValue.KeyValueDecoder
-
Decode key and value bytes into a
KeyValue
pair.
- decodeKeyValueEncodingType(SchemaInfo) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
Decode the kv encoding type from the schema info.
- decodeKeyValueSchemaInfo(SchemaInfo) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
Decode the key/value schema info to get key schema info and value schema info.
- decrypt(Supplier<MetadataT>, ByteBuf, 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_HASH_RANGE_SIZE - Static variable in class org.apache.pulsar.client.api.KeySharedPolicy
-
- 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.
- DefaultImplementation - Class in org.apache.pulsar.client.internal
-
Helper class for class instantiations and it also contains methods to work with schemas.
- DefaultImplementation() - Constructor for class org.apache.pulsar.client.internal.DefaultImplementation
-
- 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.
- 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 - Static variable in interface org.apache.pulsar.client.api.Schema
-
Double Schema.
- earliest - Static variable in interface org.apache.pulsar.client.api.MessageId
-
MessageId that represents the oldest message available in the topic.
- 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 the batch index acknowledgment.
- enableBatching(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Control whether automatic batching of messages is enabled for the producer.
- enableChunking(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
If message size is higher than allowed max publish-payload size by broker then enableChunking helps producer to
split message into multiple chunks and publish them to broker separately and in order.
- enableMultiSchema(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Control whether enable the multiple schema mode for producer.
- enableRetry(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
If enabled, the consumer will auto retry message.
- 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
-
- enableTlsHostnameVerification(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
It allows to validate hostname verification when client connects to broker over tls.
- encode(T) - Method in interface org.apache.pulsar.client.api.Schema
-
Encode an object representing the message content into a byte array.
- 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.
- EncodedAuthenticationParameterSupport - Interface in org.apache.pulsar.client.api
-
Support for encoded authentication configuration parameters.
- encodeKeyValueSchemaInfo(Schema<K>, Schema<V>, KeyValueEncodingType) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
Encode key & value into schema into a KeyValue schema.
- encodeKeyValueSchemaInfo(String, Schema<K>, Schema<V>, KeyValueEncodingType) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
Encode key & value into schema into a KeyValue schema.
- encrypt(Set<String>, CryptoKeyReader, Supplier<BuilderT>, ByteBuf) - 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
-
- equals(Object) - Method in class org.apache.pulsar.common.schema.KeyValue
-
- eventTime(long) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Set the event time for a given message.
- expireTimeOfIncompleteChunkedMessage(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
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 hour).
- generic(SchemaInfo) - Static method in interface org.apache.pulsar.client.api.Schema
-
Returns a generic schema of existing schema info.
- 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
-
- GenericSchema<T extends GenericRecord> - Interface in org.apache.pulsar.client.api.schema
-
A schema that serializes and deserializes between
GenericRecord
and bytes.
- 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
-
- 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
-
- 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.
- getEncryptionCtx() - Method in interface org.apache.pulsar.client.api.Message
-
EncryptionContext
contains 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(Field) - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
-
Retrieve the value of the provided field.
- getField(String) - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
-
Retrieve the value of the provided fieldName.
- 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) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- 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
-
- 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.
- getKeySharedMode() - Method in class org.apache.pulsar.client.api.KeySharedPolicy
-
- getLastMessageId() - Method in interface org.apache.pulsar.client.api.Consumer
-
Get the last message id available available for consume.
- getLastMessageIdAsync() - Method in interface org.apache.pulsar.client.api.Consumer
-
Get the last message id available available for consume.
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- getPartitionsForTopic(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
Get the list of partitions for a given topic.
- getPojo() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
-
Get pojo schema definition.
- 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.
- getProperty(String) - Method in interface org.apache.pulsar.client.api.Message
-
Get the value of a specific property.
- 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
-
- 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(SchemaInfo) - Static method in interface org.apache.pulsar.client.api.Schema
-
- getSchema(SchemaInfo) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- getSchemaByVersion(byte[]) - Method in interface org.apache.pulsar.client.api.schema.SchemaInfoProvider
-
Retrieve the schema info of a given schemaVersion.
- getSchemaDefinition() - Method in class 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.
- 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.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
-
- GettingAuthenticationDataException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
-
Constructs an GettingAuthenticationDataException
with the specified cause.
- GettingAuthenticationDataException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
-
Constructs an GettingAuthenticationDataException
with the specified detail message.
- 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
-
- 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
-
- getValue() - Method in interface org.apache.pulsar.client.api.Message
-
Get the de-serialized value of the message, according the configured
Schema
.
- getValue() - Method in enum org.apache.pulsar.client.api.SubscriptionInitialPosition
-
- getValue() - Method in class org.apache.pulsar.common.schema.KeyValue
-
- getValue() - Method in enum org.apache.pulsar.common.schema.SchemaType
-
- IncompatibleSchemaException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.IncompatibleSchemaException
-
Constructs an IncompatibleSchemaException
with the specified cause.
- IncompatibleSchemaException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.IncompatibleSchemaException
-
Constructs an IncompatibleSchemaException
with the specified detail message.
- INIT_AUTH_DATA - 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 the sequence ids for messages published by the producer.
- INT16 - Static variable in interface org.apache.pulsar.client.api.Schema
-
INT16 Schema.
- INT32 - Static variable in interface org.apache.pulsar.client.api.Schema
-
INT32 Schema.
- INT64 - Static variable in interface org.apache.pulsar.client.api.Schema
-
INT64 Schema.
- 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
-
- intercept(ProducerInterceptor<T>...) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Deprecated.
- intercept(ProducerInterceptor...) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
- intersect(Range) - Method in class org.apache.pulsar.client.api.Range
-
- InvalidConfigurationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
-
Constructs an InvalidConfigurationException
with the specified detail message.
- InvalidConfigurationException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
-
Constructs an InvalidConfigurationException
with the specified cause.
- InvalidConfigurationException(String, Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
-
Constructs an InvalidConfigurationException
with the specified cause.
- InvalidMessageException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidMessageException
-
Constructs an InvalidMessageException
with the specified detail message.
- InvalidMessageException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidMessageException
-
Constructs an InvalidMessageException
with the specified detail message.
- InvalidServiceURL(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidServiceURL
-
Constructs an InvalidServiceURL
with the specified cause.
- InvalidServiceURL(String, Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidServiceURL
-
Constructs an InvalidServiceURL
with the specified cause.
- InvalidTopicNameException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidTopicNameException
-
Constructs an InvalidTopicNameException
with the specified detail message.
- InvalidTxnStatusException(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: 1 thread).
- isAllowOutOfOrderDelivery() - Method in class org.apache.pulsar.client.api.KeySharedPolicy
-
- 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.
- isJsr310ConversionEnabled() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
-
Get JSR310 conversion enabled.
- isMultiBatches() - Method in interface org.apache.pulsar.client.api.BatchMessageContainer
-
Return the batch container batch message in multiple batches.
- isPrimitive() - Method in enum org.apache.pulsar.common.schema.SchemaType
-
- isPrimitiveType(SchemaType) - Static method in enum 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 org.apache.pulsar.common.schema.SchemaType
-
- isStructType(SchemaType) - Static method in enum org.apache.pulsar.common.schema.SchemaType
-
- IV_LEN - Static variable in interface org.apache.pulsar.client.api.MessageCrypto
-
- 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.
- 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.
- KeySharedMode - Enum in org.apache.pulsar.client.api
-
KeyShared mode of KeyShared subscription.
- keySharedMode - Variable in class org.apache.pulsar.client.api.KeySharedPolicy
-
- keySharedPolicy(KeySharedPolicy) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set 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(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(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(Schema<K>, Schema<V>) - Static method in interface org.apache.pulsar.client.api.Schema
-
Key Value Schema using passed in key and value schemas.
- 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<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.KeyValueDecoder<K,V> - Interface in org.apache.pulsar.common.schema
-
Decoder to decode key/value bytes.
- KeyValueEncodingType - Enum in org.apache.pulsar.common.schema
-
Encoding types of supported KeyValueSchema for Pulsar messages.
- KV_BYTES() - Static method in interface org.apache.pulsar.client.api.Schema
-
Schema that can be used to encode/decode KeyValue.
- 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 (30 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
-
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
-
Set the number of max pending messages across all the partitions.
- maxTotalReceiverQueueSizeAcrossPartitions(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set the max total receiver queue size across partitons.
- Message<T> - Interface in org.apache.pulsar.client.api
-
The message abstraction used in Pulsar.
- messageCrypto(MessageCrypto) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
- 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
-
- MessageListener<T> - Interface in org.apache.pulsar.client.api
-
A listener that will be called in order for every message received.
- 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.
- messageRouter(MessageRouter) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set a custom message routing policy by passing an implementation of MessageRouter.
- MessageRoutingMode - Enum in org.apache.pulsar.client.api
-
Default routing mode for messages to partition.
- messageRoutingMode(MessageRoutingMode) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
- Messages<T> - Interface in org.apache.pulsar.client.api
-
A container that holds the list
Message
for a topic.
- 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
-
- 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 process
Messages
.
- negativeAckRedeliveryDelay(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set the delay to wait before re-delivering messages that have failed to be process.
- newAuthenticationTLS(String, String) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newAuthenticationToken(String) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newAuthenticationToken(Supplier<String>) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newAutoConsumeSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newAutoProduceSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newAutoProduceSchema(Schema<?>) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newAvroSchema(SchemaDefinition) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newBooleanSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newByteBufferSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newByteSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newBytesSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newClientBuilder() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- 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() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newDefaultBatcherBuilder() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newDoubleSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newFloatSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newIntSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newJSONSchema(SchemaDefinition) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newKeyBasedBatcherBuilder() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newKeyValueBytesSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newKeyValueSchema(Schema<K>, Schema<V>) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newKeyValueSchema(Schema<K>, Schema<V>, KeyValueEncodingType) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newKeyValueSchema(Class<K>, Class<V>, SchemaType) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newLongSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- 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.
- newMessageId(long, long, int) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newMessageIdFromByteArray(byte[]) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newMessageIdFromByteArrayWithTopic(byte[], String) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- 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 default Schema.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.
- newProtobufSchema(SchemaDefinition) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- 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 specific
Schema
) to read from the specified topic.
- newRecordBuilder() - Method in interface org.apache.pulsar.client.api.schema.GenericSchema
-
- newRecordSchemaBuilder(String) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- 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() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newShortSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newStringSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newStringSchema(Charset) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newTimeSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- newTimestampSchema() - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- 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.
- NotAllowedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotAllowedException
-
Constructs an NotAllowedException
with 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 an NotFoundException
with the specified detail message.
- NotFoundException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotFoundException
-
Constructs an NotFoundException
with the specified cause.
- NotSupportedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotSupportedException
-
Constructs an NotSupportedException
with the specified detail message.
- numPartitions() - Method in interface org.apache.pulsar.client.api.TopicMetadata
-
Return the number of partitions per topic.
- of(int, int) - Static method in class org.apache.pulsar.client.api.Range
-
- 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.
- 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
-
- 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.
- 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.
- orderingKey(byte[]) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
- 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.schema - package org.apache.pulsar.common.schema
-
This package contains data structures for schema definitions used in the Pulsar Client API.
- patternAutoDiscoveryPeriod(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set topics auto discovery period when using a pattern for topics consumer.
- patternAutoDiscoveryPeriod(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set topics auto discovery period when using a pattern for topics consumer.
- pause() - Method in interface org.apache.pulsar.client.api.Consumer
-
- priorityLevel(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Shared subscription
Sets priority level for the shared subscription consumers to which broker gives more priority while dispatching
messages.
- Producer<T> - Interface in org.apache.pulsar.client.api
-
Producer is used to publish messages on a topic.
- ProducerBlockedQuotaExceededError(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerBlockedQuotaExceededError
-
Constructs an ProducerBlockedQuotaExceededError
with the specified detail message.
- ProducerBlockedQuotaExceededException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerBlockedQuotaExceededException
-
Constructs an ProducerBlockedQuotaExceededException
with the specified detail message.
- ProducerBuilder<T> - Interface in org.apache.pulsar.client.api
-
- ProducerBusyException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerBusyException
-
Constructs an ProducerBusyException
with the specified detail message.
- ProducerCryptoFailureAction - Enum in org.apache.pulsar.client.api
-
The action the producer will take in case of encryption failures.
- 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 an ProducerQueueIsFullError
with the specified detail message.
- ProducerQueueIsFullError(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerQueueIsFullError
-
Constructs an ProducerQueueIsFullError
with 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.
- property(String, String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set a name/value property with this consumer.
- property(String, String) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set a name/value property with 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(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.
- ProxyProtocol - Enum in org.apache.pulsar.client.api
-
Protcol type to determine type of proxy routing when client connects to proxy using
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.
- 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 an PulsarClientException
with the specified detail message.
- PulsarClientException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
-
Constructs an PulsarClientException
with the specified detail message.
- PulsarClientException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
-
Constructs an PulsarClientException
with the specified cause.
- PulsarClientException(String, Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
-
Constructs an PulsarClientException
with the specified cause.
- PulsarClientException(Throwable, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
-
Constructs an PulsarClientException
with 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.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.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.ProducerQueueIsFullError - Exception in org.apache.pulsar.client.api
-
Full producer queue error thrown by Pulsar client.
- 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.TopicTerminatedException - Exception in org.apache.pulsar.client.api
-
Topic terminated exception thrown by Pulsar client.
- PulsarClientException.UnsupportedAuthenticationException - Exception in org.apache.pulsar.client.api
-
Unsupported authentication exception thrown by Pulsar client.
- 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.
- read(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.
- readCompacted(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
If enabled, the consumer will read messages from the compacted topic rather than reading the full message backlog
of the topic.
- 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
-
- readerListener(ReaderListener<T>) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
- 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.
- receive() - Method in interface org.apache.pulsar.client.api.Consumer
-
Receives a single message.
- 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 of
Messages
.
- reconsumeLater(Messages<?>, long, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
-
reconsumeLater the consumption of
Messages
.
- reconsumeLaterAsync(Message<?>, 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 of
Messages
.
- 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.
- 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
-
- redeliverUnacknowledgedMessages() - Method in interface org.apache.pulsar.client.api.Consumer
-
Redelivers all the unacknowledged messages.
- RegexSubscriptionMode - Enum 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.
- 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.
- 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.
- 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 message default: 10.
- 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
-
- SchemaInfo - Class in org.apache.pulsar.common.schema
-
Information about the schema.
- SchemaInfo() - Constructor for class org.apache.pulsar.common.schema.SchemaInfo
-
- 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 an SchemaSerializationException
with the specified detail message.
- SchemaSerializationException(Throwable) - Constructor for exception org.apache.pulsar.client.api.SchemaSerializationException
-
Constructs an SchemaSerializationException
with the specified cause.
- SchemaType - Enum 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.
- seek(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
-
Reset the subscription associated with this consumer to a specific message id.
- 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(MessageId) - Method in interface org.apache.pulsar.client.api.Reader
-
Reset the subscription associated with this reader to a specific message id.
- seek(long) - Method in interface org.apache.pulsar.client.api.Reader
-
Reset the subscription associated with this reader to a specific message publish time.
- seekAsync(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
-
Reset the subscription associated with this consumer 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(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.Reader
-
Reset the subscription associated with this reader to a specific message publish time.
- send(T) - Method in interface org.apache.pulsar.client.api.Producer
-
Sends a message.
- send() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Send a message synchronously.
- sendAsync(T) - Method in interface org.apache.pulsar.client.api.Producer
-
Send a message asynchronously.
- sendAsync() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Send a message asynchronously
- sendTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set the send timeout (default: 30 seconds).
- sequenceId(long) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Specify a custom sequence id for the message being published.
- 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
-
- setSchemaInfoProvider(SchemaInfoProvider) - Method in interface org.apache.pulsar.client.api.Schema
-
- setSequenceId(long) - Method in exception org.apache.pulsar.client.api.PulsarClientException
-
- shutdown() - Method in interface org.apache.pulsar.client.api.PulsarClient
-
Perform immediate shutdown of PulsarClient.
- size() - Method in interface org.apache.pulsar.client.api.Messages
-
Get number of messages.
- 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.
- 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
-
- startMessageIdInclusive() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
- 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.
- stickyHashRange() - Static method in class org.apache.pulsar.client.api.KeySharedPolicy
-
- 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 the
Consumer
creation by subscribing to the topic.
- subscribeAsync() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Finalize the
Consumer
creation by subscribing to the topic in asynchronous mode.
- subscriptionInitialPosition(SubscriptionInitialPosition) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
- SubscriptionInitialPosition - Enum 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
-
Select the subscription mode to be used when subscribing to the topic.
- SubscriptionMode - Enum 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.
- 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 to 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 the topic.
- SubscriptionType - Enum 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.
- TIME - Static variable in interface org.apache.pulsar.client.api.Schema
-
Time Schema.
- timeout(int, TimeUnit) - Method in class org.apache.pulsar.client.api.BatchReceivePolicy.Builder
-
- TimeoutException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TimeoutException
-
Constructs an TimeoutException
with the specified cause.
- TimeoutException(Throwable, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TimeoutException
-
Constructs an TimeoutException
with the specified cause.
- TimeoutException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TimeoutException
-
Constructs an TimeoutException
with the specified detail message.
- TimeoutException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TimeoutException
-
Constructs an TimeoutException
with the specified detail message.
- 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.
- tlsCiphers(Set<String>) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
A list of cipher suites.
- 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.
- 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.
- TooManyRequestsException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TooManyRequestsException
-
Constructs an TooManyRequestsException
with the specified detail message.
- topic(String...) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Specify the topics this consumer will subscribe on.
- 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.
- TopicDoesNotExistException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TopicDoesNotExistException
-
Constructs an TopicDoesNotExistException
with the specified detail message.
- TopicMetadata - Interface in org.apache.pulsar.client.api
-
Metadata of a topic that can be used for message routing.
- topics(List<String>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Specify a list of topics that this consumer will subscribe on.
- topicsPattern(Pattern) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Specify a pattern for topics that this consumer will subscribe on.
- topicsPattern(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Specify a pattern for topics that this consumer will subscribe on.
- TopicTerminatedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TopicTerminatedException
-
Constructs an TopicTerminatedException
with the specified detail message.
- TopicTerminatedException(String, long) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TopicTerminatedException
-
Constructs an TopicTerminatedException
with the specified detail message.
- toString() - Method in class org.apache.pulsar.client.api.BatchReceivePolicy
-
- toString() - Method in class org.apache.pulsar.client.api.Range
-
- toString() - Method in class org.apache.pulsar.common.schema.KeyValue
-
- toString() - Method in class org.apache.pulsar.common.schema.SchemaInfo
-
- 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.
- TransactionBuilder - Interface in org.apache.pulsar.client.api.transaction
-
The builder to build a transaction for Pulsar.
- TransactionCoordinatorClient - Interface in org.apache.pulsar.client.api.transaction
-
Transaction coordinator client.
- TransactionCoordinatorClient.State - Enum 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(Throwable) - Constructor for exception org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException
-
- TransactionCoordinatorClientException(String) - 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.
- type(SchemaType) - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
-
The type of this field.
- TypedMessageBuilder<T> - Interface in org.apache.pulsar.client.api
-
Message builder that constructs a message to be published through a producer.
- 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(String) - Static method in enum org.apache.pulsar.client.api.CompressionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.ConsumerCryptoFailureAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.HashingScheme
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.KeySharedMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.MessageRoutingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.ProducerCryptoFailureAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.ProxyProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.RegexSubscriptionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.SubscriptionInitialPosition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.SubscriptionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.SubscriptionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.common.schema.KeyValueEncodingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.common.schema.SchemaType
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.apache.pulsar.common.schema.SchemaType
-
- values() - Static method in enum org.apache.pulsar.client.api.CompressionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.ConsumerCryptoFailureAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.HashingScheme
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.KeySharedMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.MessageRoutingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.ProducerCryptoFailureAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.ProxyProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.RegexSubscriptionMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.SubscriptionInitialPosition
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.SubscriptionMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.SubscriptionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.common.schema.KeyValueEncodingType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.common.schema.SchemaType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- verify() - Method in class org.apache.pulsar.client.api.BatchReceivePolicy
-