Skip navigation links
A B C D E F G H I J K L M N O P R S T U V 

A

ackCumulative() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
ackIndividual() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
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(Message<?>) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
acknowledge(MessageId) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
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(Message<?>) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
acknowledgeAsync(MessageId) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
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.
acknowledgeCumulative(Message<?>) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
acknowledgeCumulative(MessageId) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
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.
acknowledgeCumulativeAsync(Message<?>) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
acknowledgeCumulativeAsync(MessageId) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
acknowledgmentGroupTime(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Group the consumer acknowledgments for the specified time.
acknowledgmentGroupTime(long, TimeUnit) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
AcknowledgmentsGroupingTracker - Interface in org.apache.pulsar.client.impl
Acknowledgments grouping tracker.
ackTimeout(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Set the timeout for unacked messages, truncated to the nearest millisecond.
ackTimeout(long, TimeUnit) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
add(MessageId) - Method in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
addAcknowledgment(MessageIdImpl, PulsarApi.CommandAck.AckType, Map<String, Long>) - Method in interface org.apache.pulsar.client.impl.AcknowledgmentsGroupingTracker
 
addAcknowledgment(MessageIdImpl, PulsarApi.CommandAck.AckType, Map<String, Long>) - Method in class org.apache.pulsar.client.impl.NonPersistentAcknowledgmentGroupingTracker
 
addAcknowledgment(MessageIdImpl, PulsarApi.CommandAck.AckType, Map<String, Long>) - Method in class org.apache.pulsar.client.impl.PersistentAcknowledgmentsGroupingTracker
 
addCallback(MessageImpl<?>, SendCallback) - Method in interface org.apache.pulsar.client.impl.SendCallback
used to specify a callback to be invoked on completion of a send operation for individual messages sent in a batch.
addEncryptionKey(String) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Add public encryption key, used by producer to encrypt the data key.
addEncryptionKey(String) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Add public encryption key, used by producer to encrypt the data key.
addEncryptionKey(String) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
addPublicKeyCipher(Set<String>, CryptoKeyReader) - Method in class org.apache.pulsar.client.impl.MessageCrypto
 
allowTlsInsecureConnection(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
Configure whether the Pulsar client accept untrusted TLS certificate from broker (default: false)
allowTlsInsecureConnection(boolean) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
AlreadyClosedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AlreadyClosedException
 
Authentication - Interface in org.apache.pulsar.client.api
 
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
Set the authentication provider to use in the Pulsar client instance.
authentication(String, Map<String, String>) - Method in interface org.apache.pulsar.client.api.ClientBuilder
Set the authentication provider to use in the Pulsar client instance.
authentication(Authentication) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
authentication(String, String) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
authentication(String, Map<String, String>) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
authentication - Variable in class org.apache.pulsar.client.impl.ClientCnx
 
authentication - Variable in class org.apache.pulsar.client.impl.HttpClient
 
AuthenticationBasic - Class in org.apache.pulsar.client.impl.auth
 
AuthenticationBasic() - Constructor for class org.apache.pulsar.client.impl.auth.AuthenticationBasic
 
AuthenticationDataBasic - Class in org.apache.pulsar.client.impl.auth
 
AuthenticationDataBasic(String, String) - Constructor for class org.apache.pulsar.client.impl.auth.AuthenticationDataBasic
 
AuthenticationDataNull - Class in org.apache.pulsar.client.impl.auth
 
AuthenticationDataNull() - Constructor for class org.apache.pulsar.client.impl.auth.AuthenticationDataNull
 
AuthenticationDataProvider - Interface in org.apache.pulsar.client.api
Interface for accessing data which are used in variety of authentication schemes on client side
AuthenticationDataTls - Class in org.apache.pulsar.client.impl.auth
 
AuthenticationDataTls(String, String) - Constructor for class org.apache.pulsar.client.impl.auth.AuthenticationDataTls
 
AuthenticationDisabled - Class in org.apache.pulsar.client.impl.auth
 
AuthenticationDisabled() - Constructor for class org.apache.pulsar.client.impl.auth.AuthenticationDisabled
 
AuthenticationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AuthenticationException
 
AuthenticationFactory - Class in org.apache.pulsar.client.api
 
AuthenticationFactory() - Constructor for class org.apache.pulsar.client.api.AuthenticationFactory
 
AuthenticationTls - Class in org.apache.pulsar.client.impl.auth
This plugin requires these parameters tlsCertFile: A file path for a client certificate.
AuthenticationTls() - Constructor for class org.apache.pulsar.client.impl.auth.AuthenticationTls
 
AuthenticationUtil - Class in org.apache.pulsar.client.api
 
AuthenticationUtil() - Constructor for class org.apache.pulsar.client.api.AuthenticationUtil
 
authoritative - Variable in class org.apache.pulsar.client.impl.BinaryProtoLookupService.LookupDataResult
 
AuthorizationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AuthorizationException
 

B

Backoff - Class in org.apache.pulsar.client.impl
 
Backoff(long, TimeUnit, long, TimeUnit, long, TimeUnit) - Constructor for class org.apache.pulsar.client.impl.Backoff
 
batchingMaxMessages(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Set the maximum number of messages permitted in a batch.
batchingMaxMessages(int) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
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.
batchingMaxPublishDelay(long, TimeUnit) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
BatchMessageIdImpl - Class in org.apache.pulsar.client.impl
 
BatchMessageIdImpl(long, long, int, int) - Constructor for class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
BatchMessageIdImpl(long, long, int, int, BatchMessageAcker) - Constructor for class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
BatchMessageIdImpl(MessageIdImpl) - Constructor for class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
becameActive(Consumer<?>, int) - Method in interface org.apache.pulsar.client.api.ConsumerEventListener
Notified when the consumer group is changed, and the consumer becomes the active consumer.
becameInactive(Consumer<?>, int) - Method in interface org.apache.pulsar.client.api.ConsumerEventListener
Notified when the consumer group is changed, and the consumer is still inactive or becomes inactive.
beforeConsume(Consumer<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.ConsumerInterceptor
This is called just before the message is returned by Consumer.receive(), MessageListener.received(Consumer, Message) or the CompletableFuture returned by Consumer.receiveAsync() completes.
beforeConsume(Message<T>) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
beforeConsume(Consumer<T>, Message<T>) - Method in class org.apache.pulsar.client.impl.ConsumerInterceptors
This is called just before the message is returned by Consumer.receive(), MessageListener.received(Consumer, Message) or the CompletableFuture returned by Consumer.receiveAsync() completes.
beforeSend(Producer<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.ProducerInterceptor
This is called from Producer.send(Object) and Producer.sendAsync(Object) methods, before send the message to the brokers.
beforeSend(Message<T>) - Method in class org.apache.pulsar.client.impl.ProducerBase
 
beforeSend(Producer<T>, Message<T>) - Method in class org.apache.pulsar.client.impl.ProducerInterceptors
This is called when client sends message to pulsar broker, before key and value gets serialized.
BinaryProtoLookupService - Class in org.apache.pulsar.client.impl
 
BinaryProtoLookupService(PulsarClientImpl, String, boolean, ExecutorService) - Constructor for class org.apache.pulsar.client.impl.BinaryProtoLookupService
 
BinaryProtoLookupService.LookupDataResult - Class in org.apache.pulsar.client.impl
 
blockIfQueueFull(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Set whether the Producer.send(T) and Producer.sendAsync(T) operations should block when the outgoing message queue is full.
blockIfQueueFull(boolean) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
brokerChecksumSupportedVersion() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
BrokerMetadataException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.BrokerMetadataException
 
BrokerPersistenceException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.BrokerPersistenceException
 
brokerUrl - Variable in class org.apache.pulsar.client.impl.BinaryProtoLookupService.LookupDataResult
 
brokerUrlTls - Variable in class org.apache.pulsar.client.impl.BinaryProtoLookupService.LookupDataResult
 
build() - Method in interface org.apache.pulsar.client.api.ClientBuilder
 
build() - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Finalize the immutable message
build() - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
build() - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
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.

C

cancelStatsTimeout() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
cancelStatsTimeout() - Method in interface org.apache.pulsar.client.impl.ProducerStatsRecorder
 
cancelStatsTimeout() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
certificates - Variable in class org.apache.pulsar.client.impl.auth.AuthenticationDataTls
 
channelActive(ChannelHandlerContext) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
ChecksumException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ChecksumException
 
choosePartition(Message<?>) - Method in interface org.apache.pulsar.client.api.MessageRouter
Deprecated.
choosePartition(Message<?>, TopicMetadata) - Method in interface org.apache.pulsar.client.api.MessageRouter
Choose a partition based on msg and the topic metadata.
choosePartition(Message<?>, TopicMetadata) - Method in class org.apache.pulsar.client.impl.RoundRobinPartitionMessageRouterImpl
 
choosePartition(Message<?>, TopicMetadata) - Method in class org.apache.pulsar.client.impl.SinglePartitionMessageRouterImpl
 
clear() - Method in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
ClientBuilder - Interface in org.apache.pulsar.client.api
Builder interface that is used to construct a PulsarClient instance.
ClientBuilderImpl - Class in org.apache.pulsar.client.impl
 
ClientBuilderImpl() - Constructor for class org.apache.pulsar.client.impl.ClientBuilderImpl
 
ClientBuilderImpl(ClientConfigurationData) - Constructor for class org.apache.pulsar.client.impl.ClientBuilderImpl
 
ClientCnx - Class in org.apache.pulsar.client.impl
 
ClientCnx(ClientConfigurationData, EventLoopGroup) - Constructor for class org.apache.pulsar.client.impl.ClientCnx
 
ClientCnx(ClientConfigurationData, EventLoopGroup, int) - Constructor for class org.apache.pulsar.client.impl.ClientCnx
 
ClientConfiguration - Class in org.apache.pulsar.client.api
Deprecated.
Use PulsarClient.builder() to construct and configure a new PulsarClient instance
ClientConfiguration() - Constructor for class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
ClientConfigurationData - Class in org.apache.pulsar.client.impl.conf
This is a simple holder of the client configuration values.
ClientConfigurationData() - Constructor for class org.apache.pulsar.client.impl.conf.ClientConfigurationData
 
clone() - Method in interface org.apache.pulsar.client.api.ClientBuilder
Create a copy of the current client builder.
clone() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Create a copy of the current consumer builder.
clone() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Create a copy of the current ProducerBuilder.
clone() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
Create a copy of the current ReaderBuilder.
clone() - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
clone() - Method in class org.apache.pulsar.client.impl.conf.ClientConfigurationData
 
clone() - Method in class org.apache.pulsar.client.impl.conf.ConsumerConfigurationData
 
clone() - Method in class org.apache.pulsar.client.impl.conf.ProducerConfigurationData
 
clone() - Method in class org.apache.pulsar.client.impl.conf.ReaderConfigurationData
 
clone() - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
clone() - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
clone() - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
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.Producer
Close the producer and releases resources allocated.
close() - Method in interface org.apache.pulsar.client.api.ProducerInterceptor
Close the interceptor.
close() - Method in interface org.apache.pulsar.client.api.PulsarClient
Close the PulsarClient and release all the resources.
close() - Method in interface org.apache.pulsar.client.impl.AcknowledgmentsGroupingTracker
 
close() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationBasic
 
close() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDisabled
 
close() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationTls
 
close() - Method in class org.apache.pulsar.client.impl.BinaryProtoLookupService
 
close() - Method in class org.apache.pulsar.client.impl.ClientCnx
 
close() - Method in class org.apache.pulsar.client.impl.ConnectionPool
 
close() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
close() - Method in class org.apache.pulsar.client.impl.ConsumerInterceptors
 
close() - Method in class org.apache.pulsar.client.impl.HttpClient
 
close() - Method in class org.apache.pulsar.client.impl.NonPersistentAcknowledgmentGroupingTracker
 
close() - Method in class org.apache.pulsar.client.impl.PersistentAcknowledgmentsGroupingTracker
 
close() - Method in class org.apache.pulsar.client.impl.ProducerBase
 
close() - Method in class org.apache.pulsar.client.impl.ProducerInterceptors
 
close() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
close() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
close() - Method in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
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 class org.apache.pulsar.client.impl.ConsumerBase
 
closeAsync() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
closeAsync() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
closeAsync() - Method in class org.apache.pulsar.client.impl.PartitionedProducerImpl
 
closeAsync() - Method in class org.apache.pulsar.client.impl.PatternMultiTopicsConsumerImpl
 
closeAsync() - Method in class org.apache.pulsar.client.impl.ProducerBase
 
closeAsync() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
closeAsync() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
closeAsync() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
compareTo(MessageId) - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
compareTo(ConsumerId) - Method in class org.apache.pulsar.client.impl.ConsumerId
 
compareTo(MessageId) - Method in class org.apache.pulsar.client.impl.MessageIdImpl
 
compareTo(MessageId) - Method in class org.apache.pulsar.client.impl.TopicMessageIdImpl
 
CompressionType - Enum in org.apache.pulsar.client.api
 
compressionType(CompressionType) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Set the compression type for the producer.
compressionType(CompressionType) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
conf - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
conf - Variable in class org.apache.pulsar.client.impl.ProducerBase
 
ConfigurationDataUtils - Class in org.apache.pulsar.client.impl.conf
Utils for loading configuration data.
configure(Map<String, String>) - Method in interface org.apache.pulsar.client.api.Authentication
Deprecated.
This method will be deleted on version 2.0, instead please use configure(String encodedAuthParamString) which is in EncodedAuthenticationParameterSupport for now and will be integrated into this interface.
configure(String) - Method in interface org.apache.pulsar.client.api.EncodedAuthenticationParameterSupport
Plugins which use ":" and/or "," in a configuration parameter value need to implement this interface.
configure(Map<String, String>) - Method in class org.apache.pulsar.client.impl.auth.AuthenticationBasic
 
configure(String) - Method in class org.apache.pulsar.client.impl.auth.AuthenticationBasic
 
configure(String) - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDisabled
 
configure(Map<String, String>) - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDisabled
Deprecated.
configure(String) - Method in class org.apache.pulsar.client.impl.auth.AuthenticationTls
 
configure(Map<String, String>) - Method in class org.apache.pulsar.client.impl.auth.AuthenticationTls
Deprecated.
configureFromJsonString(String) - Static method in class org.apache.pulsar.client.api.AuthenticationUtil
 
configureFromPulsar1AuthParamString(String) - Static method in class org.apache.pulsar.client.api.AuthenticationUtil
 
ConnectException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConnectException
 
connectionFailed(PulsarClientException) - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
connectionFailed(PulsarClientException) - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
connectionOpened(ClientCnx) - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
connectionOpened(ClientCnx) - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
ConnectionPool - Class in org.apache.pulsar.client.impl
 
ConnectionPool(ClientConfigurationData, EventLoopGroup) - Constructor for class org.apache.pulsar.client.impl.ConnectionPool
 
ConnectionPool(ClientConfigurationData, EventLoopGroup, Supplier<ClientCnx>) - Constructor for class org.apache.pulsar.client.impl.ConnectionPool
 
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.
connectionsPerBroker(int) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
Consumer<T> - Interface in org.apache.pulsar.client.api
An interface that abstracts behavior of Pulsar's consumer.
ConsumerBase<T> - Class in org.apache.pulsar.client.impl
 
ConsumerBase(PulsarClientImpl, String, ConsumerConfigurationData<T>, int, ExecutorService, CompletableFuture<Consumer<T>>, Schema<T>, ConsumerInterceptors) - Constructor for class org.apache.pulsar.client.impl.ConsumerBase
 
ConsumerBuilder<T> - Interface in org.apache.pulsar.client.api
ConsumerBuilder is used to configure and create instances of Consumer.
ConsumerBuilderImpl<T> - Class in org.apache.pulsar.client.impl
 
ConsumerBuilderImpl(PulsarClientImpl, Schema<T>) - Constructor for class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
ConsumerBusyException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConsumerBusyException
 
ConsumerConfiguration - Class in org.apache.pulsar.client.api
Deprecated.
Use PulsarClient.newConsumer() to build and configure a Consumer instance
ConsumerConfiguration() - Constructor for class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
ConsumerConfigurationData<T> - Class in org.apache.pulsar.client.impl.conf
 
ConsumerConfigurationData() - Constructor for class org.apache.pulsar.client.impl.conf.ConsumerConfigurationData
 
ConsumerCryptoFailureAction - Enum in org.apache.pulsar.client.api
 
consumerEventListener(ConsumerEventListener) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Sets a ConsumerEventListener for the consumer.
ConsumerEventListener - Interface in org.apache.pulsar.client.api
Listener on the consumer state changes.
consumerEventListener - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
consumerEventListener(ConsumerEventListener) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
ConsumerId - Class in org.apache.pulsar.client.impl
 
ConsumerId(String, String) - Constructor for class org.apache.pulsar.client.impl.ConsumerId
 
ConsumerImpl<T> - Class in org.apache.pulsar.client.impl
 
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.
ConsumerInterceptors<T> - Class in org.apache.pulsar.client.impl
A container that hold the list ConsumerInterceptor and wraps calls to the chain of custom interceptors.
ConsumerInterceptors(List<ConsumerInterceptor<T>>) - Constructor for class org.apache.pulsar.client.impl.ConsumerInterceptors
 
consumerName(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Set the consumer name.
consumerName - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
consumerName(String) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
ConsumerName - Class in org.apache.pulsar.client.util
 
ConsumerName() - Constructor for class org.apache.pulsar.client.util.ConsumerName
 
ConsumerStats - Interface in org.apache.pulsar.client.api
Consumer statistics recorded by client.
ConsumerStatsDisabled - Class in org.apache.pulsar.client.impl
 
ConsumerStatsDisabled() - Constructor for class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
ConsumerStatsRecorder - Interface in org.apache.pulsar.client.impl
 
ConsumerStatsRecorderImpl - Class in org.apache.pulsar.client.impl
 
ConsumerStatsRecorderImpl() - Constructor for class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
ConsumerStatsRecorderImpl(PulsarClientImpl, ConsumerConfigurationData<?>, ConsumerImpl<?>) - Constructor for class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
create(String, String) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
Create an instance of the Authentication-Plugin
create(String, Map<String, String>) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
Create an instance of the Authentication-Plugin
create(Schema<T>) - Static method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Create a new message builder instance.
create() - Static method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
 
create() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Finalize the creation of the Producer instance.
create(String) - Static method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
use PulsarClient.builder() to construct a client instance
create(String, ClientConfiguration) - Static method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
use PulsarClient.builder() to construct a client instance
create() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
Finalize the creation of the Reader instance.
create() - Static method in class org.apache.pulsar.client.impl.conf.ConfigurationDataUtils
 
create() - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
create() - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
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.
createAsync() - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
createAsync() - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
createPartitionedConsumer(PulsarClientImpl, ConsumerConfigurationData<T>, ExecutorService, CompletableFuture<Consumer<T>>, int, Schema<T>, ConsumerInterceptors<T>) - Static method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
createProducer(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
use PulsarClient.newProducer() to build a new producer
createProducer(String, ProducerConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
use PulsarClient.newProducer() to build a new producer
createProducer(String) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createProducer(String, ProducerConfiguration) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createProducerAsync(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
use PulsarClient.newProducer() to build a new producer
createProducerAsync(String, ProducerConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
use PulsarClient.newProducer() to build a new producer
createProducerAsync(String) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createProducerAsync(String, ProducerConfiguration) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createProducerAsync(ProducerConfigurationData) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createProducerAsync(ProducerConfigurationData, Schema<T>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createProducerAsync(ProducerConfigurationData, Schema<T>, ProducerInterceptors<T>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createReader(String, MessageId, ReaderConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
Use PulsarClient.newReader() to build a new reader
createReader(String, MessageId, ReaderConfiguration) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createReaderAsync(String, MessageId, ReaderConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
Use PulsarClient.newReader() to build a new reader
createReaderAsync(String, MessageId, ReaderConfiguration) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createReaderAsync(ReaderConfigurationData<byte[]>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createReaderAsync(ReaderConfigurationData<T>, Schema<T>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
createURLStreamHandler(String) - Method in class org.apache.pulsar.client.api.url.PulsarURLStreamHandlerFactory
 
CryptoException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.CryptoException
 
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
Sets the ConsumerCryptoFailureAction to the value specified
cryptoFailureAction(ConsumerCryptoFailureAction) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
cryptoFailureAction(ProducerCryptoFailureAction) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
cryptoFailureAction(ConsumerCryptoFailureAction) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
CryptoKeyReader - Interface in org.apache.pulsar.client.api
 
cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
cryptoKeyReader(CryptoKeyReader) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
cryptoKeyReader(CryptoKeyReader) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
cryptoKeyReader(CryptoKeyReader) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
currentSet - Variable in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 

D

DataURLStreamHandler - Class in org.apache.pulsar.client.api.url
 
DataURLStreamHandler() - Constructor for class org.apache.pulsar.client.api.url.DataURLStreamHandler
 
deadLetterPolicy(DeadLetterPolicy) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Set dead letter policy for consumer By default some message will redelivery so many times possible, even to the extent that it can be never stop.
DeadLetterPolicy - Class in org.apache.pulsar.client.api
 
DeadLetterPolicy() - Constructor for class org.apache.pulsar.client.api.DeadLetterPolicy
 
deadLetterPolicy(DeadLetterPolicy) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
decrypt(PulsarApi.MessageMetadata, ByteBuf, CryptoKeyReader) - Method in class org.apache.pulsar.client.impl.MessageCrypto
 
DEFAULT_CONNECT_TIMEOUT_IN_SECONDS - Static variable in class org.apache.pulsar.client.impl.HttpClient
 
DEFAULT_READ_TIMEOUT_IN_SECONDS - Static variable in class org.apache.pulsar.client.impl.HttpClient
 
deserialize(ByteBuf) - Static method in class org.apache.pulsar.client.impl.MessageImpl
 
disableReplication() - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Disable replication for this message.
disableReplication() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Disable replication for this message.
disableReplication() - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
disableReplication() - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
dnsResolver - Variable in class org.apache.pulsar.client.impl.ConnectionPool
 
doAcknowledge(MessageId, PulsarApi.CommandAck.AckType, Map<String, Long>) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
doAcknowledge(MessageId, PulsarApi.CommandAck.AckType, Map<String, Long>) - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
doAcknowledge(MessageId, PulsarApi.CommandAck.AckType, Map<String, Long>) - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 

E

earliest - Static variable in interface org.apache.pulsar.client.api.MessageId
 
enableBatching(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Control whether automatic batching of messages is enabled for the producer.
enableBatching(boolean) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
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.
enableTcpNoDelay(boolean) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
enableTls(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
Deprecated.
use "pulsar+ssl://" in serviceUrl to enable
enableTls(boolean) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
enableTlsHostnameVerification(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
It allows to validate hostname verification when client connects to broker over tls.
enableTlsHostnameVerification(boolean) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
EncodedAuthenticationParameterSupport - Interface in org.apache.pulsar.client.api
 
encrypt(Set<String>, CryptoKeyReader, PulsarApi.MessageMetadata.Builder, ByteBuf) - Method in class org.apache.pulsar.client.impl.MessageCrypto
 
EncryptionKeyInfo - Class in org.apache.pulsar.client.api
 
EncryptionKeyInfo() - Constructor for class org.apache.pulsar.client.api.EncryptionKeyInfo
 
EncryptionKeyInfo(byte[], Map<String, String>) - Constructor for class org.apache.pulsar.client.api.EncryptionKeyInfo
 
entryId - Variable in class org.apache.pulsar.client.impl.MessageIdImpl
 
equals(Object) - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
equals(Object) - Method in class org.apache.pulsar.client.impl.ConsumerId
 
equals(Object) - Method in class org.apache.pulsar.client.impl.MessageIdImpl
 
equals(Object) - Method in class org.apache.pulsar.client.impl.TopicMessageIdImpl
 
eventLoopGroup() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
eventTime(long) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Set the event time for a given message.
eventTime(long) - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
ExecutorProvider - Class in org.apache.pulsar.client.util
 
ExecutorProvider(int, ThreadFactory) - Constructor for class org.apache.pulsar.client.util.ExecutorProvider
 

F

flush() - Method in interface org.apache.pulsar.client.api.Producer
Flush all the messages buffered in the client and wait until all messages have been successfully persisted.
flush() - Method in interface org.apache.pulsar.client.impl.AcknowledgmentsGroupingTracker
 
flush() - Method in class org.apache.pulsar.client.impl.NonPersistentAcknowledgmentGroupingTracker
 
flush() - Method in class org.apache.pulsar.client.impl.PersistentAcknowledgmentsGroupingTracker
Flush all the pending acks and send them to the broker
flush() - Method in class org.apache.pulsar.client.impl.ProducerBase
 
flushAsync() - Method in interface org.apache.pulsar.client.api.Producer
Flush all the messages buffered in the client and wait until all messages have been successfully persisted.
flushAsync() - Method in class org.apache.pulsar.client.impl.PartitionedProducerImpl
 
flushAsync() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
fromByteArray(byte[]) - Static method in interface org.apache.pulsar.client.api.MessageId
De-serialize a message id from a byte array
fromByteArray(byte[]) - Static method in class org.apache.pulsar.client.impl.MessageIdImpl
 
fromByteArrayWithTopic(byte[], TopicName) - Static method in interface org.apache.pulsar.client.api.MessageId
 
fromByteArrayWithTopic(byte[], TopicName) - Static method in class org.apache.pulsar.client.impl.MessageIdImpl
 

G

generateRandomName() - Static method in class org.apache.pulsar.client.util.ConsumerName
 
get(String, Class<T>) - Method in class org.apache.pulsar.client.impl.HttpClient
 
getAcker() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
getAckTimeoutMillis() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getAuthData() - Method in interface org.apache.pulsar.client.api.Authentication
 
getAuthData() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationBasic
 
getAuthData() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDisabled
 
getAuthData() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationTls
 
getAuthentication() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
getAuthMethodName() - Method in interface org.apache.pulsar.client.api.Authentication
 
getAuthMethodName() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationBasic
 
getAuthMethodName() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDisabled
 
getAuthMethodName() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationTls
 
getAvailablePermits() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
getAvailablePermits() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
getAvailablePermits() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
getBatchIndex() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
getBatchingEnabled() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Return the flag whether automatic message batching is enabled or not.
getBatchingMaxMessages() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getBatchingMaxPublishDelayMs() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getBatchSize() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
getBlockIfQueueFull() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getBroker(TopicName) - Method in class org.apache.pulsar.client.impl.BinaryProtoLookupService
Calls broker binaryProto-lookup api to find broker-service address which can serve a given topic.
getBroker(TopicName) - Method in interface org.apache.pulsar.client.impl.LookupService
Calls broker lookup-api to get broker InetSocketAddress which serves namespace bundle that contains given topic.
getClientCnx() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
getClientConfigurationData() - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
getCnx() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getCnxPool() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
getCommandData() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
 
getCommandData() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDataBasic
 
getCompressionType() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getConcurrentLookupRequest() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Get configured total allowed concurrent lookup-request.
getConf() - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
getConfiguration() - Method in class org.apache.pulsar.client.impl.ProducerBase
 
getConfiguration() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
getConfigurationData() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
getConfigurationData() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getConnectedSince() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
getConnection(InetSocketAddress) - Method in class org.apache.pulsar.client.impl.ConnectionPool
 
getConnection(InetSocketAddress, InetSocketAddress) - Method in class org.apache.pulsar.client.impl.ConnectionPool
Get a connection from the pool.
getConnection(String) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
getConnectionHandler() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
getConnectionHandler() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
getConnectionId() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
getConnectionsPerBroker() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
getConsumer() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
getConsumerEventListener() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getConsumerName() - Method in interface org.apache.pulsar.client.api.Consumer
Get the name of consumer.
getConsumerName() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getConsumerName() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
getConsumers() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
getContent() - Method in class org.apache.pulsar.client.api.url.URL
 
getContent(Class[]) - Method in class org.apache.pulsar.client.api.url.URL
 
getContent() - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
getCryptoFailureAction() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getCryptoFailureAction() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getCryptoFailureAction() - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
 
getCryptoKeyReader() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getCryptoKeyReader() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getCryptoKeyReader() - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
 
getData() - Method in interface org.apache.pulsar.client.api.Message
Get the content of the message
getData() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getData() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getDataBuffer() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getDelayInMillis() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
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.
getEncryptionCtx() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getEncryptionCtx() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getEncryptionKeys() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getEntryId() - Method in class org.apache.pulsar.client.impl.MessageIdImpl
 
getEventTime() - Method in interface org.apache.pulsar.client.api.Message
Get the event time associated with this message.
getEventTime() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getEventTime() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getExecutor() - Method in class org.apache.pulsar.client.util.ExecutorProvider
 
getFuture() - Method in interface org.apache.pulsar.client.impl.SendCallback
 
getHashingScheme() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getHttpAuthType() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
 
getHttpHeaders() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
 
getHttpHeaders() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDataBasic
 
getInitialSequenceId() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getInnerMessageId() - Method in class org.apache.pulsar.client.impl.TopicMessageIdImpl
 
getInnerMessageId() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getInstance() - Static method in class org.apache.pulsar.client.impl.JavaStringHash
 
getInstance() - Static method in class org.apache.pulsar.client.impl.Murmur3_32Hash
 
getIoThreads() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
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.client.impl.MessageImpl
 
getKey() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getKey() - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
getKeyBytes() - Method in interface org.apache.pulsar.client.api.Message
Get bytes in key.
getKeyBytes() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getKeyBytes() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getLastSequenceId() - Method in interface org.apache.pulsar.client.api.Producer
Get the last sequence id that was published by this producer.
getLastSequenceId() - Method in class org.apache.pulsar.client.impl.PartitionedProducerImpl
 
getLastSequenceId() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
getLedgerId() - Method in class org.apache.pulsar.client.impl.MessageIdImpl
 
getListenerThreads() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
getLookup() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
getMaxNumberOfRejectedRequestPerConnection() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Get configured max number of reject-request in a time-frame (30 seconds) after which connection will be closed
getMaxPendingMessages() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getMaxPendingMessagesAcrossPartitions() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getMaxTotalReceiverQueueSizeAcrossPartitions() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getMessage() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getMessageBuilder() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getMessageId() - Method in interface org.apache.pulsar.client.api.Message
Get the unique message ID associated with this message.
getMessageId() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getMessageId() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getMessageListener() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getMessageRouter(int) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
since 1.22.0-incubating. numPartitions is already passed as parameter in MessageRouter.choosePartition(Message, TopicMetadata).
getMessageRouter() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
getMessageRoutingMode() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Get the message routing mode for the partitioned producer.
getMetadata() - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
 
getNameSpaceFromPattern(Pattern) - Static method in class org.apache.pulsar.client.impl.PatternMultiTopicsConsumerImpl
 
getNextMessage() - Method in interface org.apache.pulsar.client.impl.SendCallback
Return next message in chain
getNextSendCallback() - Method in interface org.apache.pulsar.client.impl.SendCallback
 
getNumAcksFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getNumAcksFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getNumAcksFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getNumAcksReceived() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getNumAcksReceived() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getNumAcksReceived() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getNumAcksSent() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getNumAcksSent() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getNumAcksSent() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getNumberOfPartitions(String) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
getNumBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getNumBytesReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getNumBytesReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getNumBytesSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getNumBytesSent() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getNumBytesSent() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getNumMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getNumMsgsReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getNumMsgsReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getNumMsgsSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getNumMsgsSent() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getNumMsgsSent() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getNumReceiveFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getNumReceiveFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getNumReceiveFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getNumSendFailed() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getNumSendFailed() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getNumSendFailed() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getOperationTimeoutMs() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
getOutstandingAcksInSameBatch() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
getPartitionedTopicMetadata(TopicName) - Method in class org.apache.pulsar.client.impl.BinaryProtoLookupService
calls broker binaryProto-lookup api to get metadata of partitioned-topic.
getPartitionedTopicMetadata(TopicName) - Method in interface org.apache.pulsar.client.impl.LookupService
Returns PartitionedTopicMetadata for a given topic.
getPartitionedTopicMetadata(String) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
getPartitionedTopics() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
getPartitionIndex() - Method in class org.apache.pulsar.client.impl.MessageIdImpl
 
getPattern() - Method in class org.apache.pulsar.client.impl.PatternMultiTopicsConsumerImpl
 
getPendingQueueSize() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
getPriorityLevel() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getPrivateKey(String, Map<String, String>) - Method in interface org.apache.pulsar.client.api.CryptoKeyReader
 
getProducerConfigurationData() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
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
 
getProducerName() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getProducerName() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getProducerName() - Method in class org.apache.pulsar.client.impl.PartitionedProducerImpl
 
getProducerName() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
getProducerName() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getProducers() - Method in class org.apache.pulsar.client.impl.PartitionedProducerImpl
 
getProperties() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getProperties() - Method in interface org.apache.pulsar.client.api.Message
Return the properties attached to the message.
getProperties() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getProperties() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getProperties() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getProperty(String) - Method in interface org.apache.pulsar.client.api.Message
Get the value of a specific property
getProperty(String) - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getProperty(String) - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
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.
getPublishTime() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getPublishTime() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getPublishTime() - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
getPulsarClientVersion() - Static method in class org.apache.pulsar.client.impl.HttpClient
Looks for a file called pulsar-client-version.properties and returns the client version
getRateBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getRateBytesReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getRateBytesReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getRateMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getRateMsgsReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getRateMsgsReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getReadCompacted() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getReaderConfigurationData() - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
 
getReaderListener() - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
 
getReaderName() - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
 
getReceiverQueueSize() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getReceiverQueueSize() - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
 
getReplicatedFrom() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getReplicateTo() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getSchema(TopicName) - Method in class org.apache.pulsar.client.impl.BinaryProtoLookupService
 
getSchema(TopicName) - Method in interface org.apache.pulsar.client.impl.LookupService
 
getSchema(String) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
Read the schema information for a given topic.
getSendBytesRate() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getSendBytesRate() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getSendBytesRate() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getSendLatencyMillis50pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis50pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getSendLatencyMillis50pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getSendLatencyMillis75pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis75pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getSendLatencyMillis75pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getSendLatencyMillis95pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis95pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getSendLatencyMillis95pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getSendLatencyMillis999pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis999pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getSendLatencyMillis999pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getSendLatencyMillis99pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis99pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getSendLatencyMillis99pct() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getSendLatencyMillisMax() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillisMax() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getSendLatencyMillisMax() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getSendMsgsRate() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getSendMsgsRate() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getSendMsgsRate() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getSendTimeoutMs() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
getSequenceId() - Method in interface org.apache.pulsar.client.api.Message
Get the sequence id associated with this message.
getSequenceId() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getSequenceId() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
getServiceUrl() - Method in interface org.apache.pulsar.client.api.ServiceUrlProvider
Get the current service URL the Pulsar client should connect to.
getServiceUrl() - Method in class org.apache.pulsar.client.impl.BinaryProtoLookupService
 
getServiceUrl() - Method in interface org.apache.pulsar.client.impl.LookupService
Returns broker-service lookup api url.
getSingleTopic() - Method in class org.apache.pulsar.client.impl.conf.ConsumerConfigurationData
 
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 numMsgsSent : Number of messages sent in the current interval numBytesSent : Number of bytes sent in the current interval numSendFailed : Number of messages failed to send in the current interval numAcksReceived : Number of acks received in the current interval totalMsgsSent : Total number of messages sent totalBytesSent : Total number of bytes sent totalSendFailed : Total number of messages failed to send totalAcksReceived: Total number of acks received
getStats() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
getStats() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
getStats() - Method in class org.apache.pulsar.client.impl.PartitionedProducerImpl
 
getStats() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
getStatsIntervalSeconds() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Stats will be activated with positive statsIntervalSeconds
getStatTimeout() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getStatTimeout() - Method in interface org.apache.pulsar.client.impl.ConsumerStatsRecorder
 
getStatTimeout() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getSubscription() - Method in interface org.apache.pulsar.client.api.Consumer
Get a subscription for the consumer
getSubscription() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
getSubscription() - Method in class org.apache.pulsar.client.impl.ConsumerId
 
getSubscriptionInitialPosition() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getSubscriptionRolePrefix() - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
 
getSubscriptionType() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
getSubType() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
getThreadLocal() - Static method in class org.apache.pulsar.client.impl.conf.ConfigurationDataUtils
 
GettingAuthenticationDataException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
 
GettingAuthenticationDataException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
 
getTlsCertificates() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
 
getTlsCertificates() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDataTls
 
getTlsPrivateKey() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
 
getTlsPrivateKey() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDataTls
 
getTlsTrustCertsFilePath() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
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
 
getTopic() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
getTopic() - Method in class org.apache.pulsar.client.impl.ConsumerId
 
getTopic() - Method in class org.apache.pulsar.client.impl.ProducerBase
 
getTopic() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
getTopicName() - Method in interface org.apache.pulsar.client.api.Message
Get the topic the message was published to
getTopicName() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getTopicName() - Method in class org.apache.pulsar.client.impl.TopicMessageIdImpl
Get the topic name without partition part of this message.
getTopicName() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
Get the topic name without partition part of this message.
getTopicNameWithoutPartition() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
getTopicPartitionName() - Method in class org.apache.pulsar.client.impl.TopicMessageIdImpl
Get the topic name which contains partition part for this message.
getTopicPartitionName() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
Get the topic name which contains partition part for this message.
getTopics() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
getTopicsUnderNamespace(NamespaceName, PulsarApi.CommandGetTopicsOfNamespace.Mode) - Method in class org.apache.pulsar.client.impl.BinaryProtoLookupService
 
getTopicsUnderNamespace(NamespaceName, PulsarApi.CommandGetTopicsOfNamespace.Mode) - Method in interface org.apache.pulsar.client.impl.LookupService
Returns all the topics name for a given namespace.
getTotalAcksFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getTotalAcksFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getTotalAcksFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getTotalAcksReceived() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getTotalAcksReceived() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getTotalAcksReceived() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getTotalAcksSent() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getTotalAcksSent() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getTotalAcksSent() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getTotalBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getTotalBytesReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getTotalBytesReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getTotalBytesSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getTotalBytesSent() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getTotalBytesSent() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getTotalMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getTotalMsgsReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getTotalMsgsReceived() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getTotalMsgsSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getTotalMsgsSent() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getTotalMsgsSent() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getTotalReceivedFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
 
getTotalReceivedFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
getTotalReceivedFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
getTotalSendFailed() - Method in interface org.apache.pulsar.client.api.ProducerStats
 
getTotalSendFailed() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
getTotalSendFailed() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
getUnAckedMessageTracker() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
getUnAckedMessageTracker() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
getValue() - Method in interface org.apache.pulsar.client.api.Message
 
getValue() - Method in enum org.apache.pulsar.client.api.SubscriptionInitialPosition
 
getValue() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
getValue() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 

H

handleActiveConsumerChange(PulsarApi.CommandActiveConsumerChange) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleCloseConsumer(PulsarApi.CommandCloseConsumer) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleCloseProducer(PulsarApi.CommandCloseProducer) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleConnected(PulsarApi.CommandConnected) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleError(PulsarApi.CommandError) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleGetLastMessageIdSuccess(PulsarApi.CommandGetLastMessageIdResponse) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleGetSchemaResponse(PulsarApi.CommandGetSchemaResponse) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleGetTopicsOfNamespaceSuccess(PulsarApi.CommandGetTopicsOfNamespaceResponse) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleLookupResponse(PulsarApi.CommandLookupTopicResponse) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleMessage(PulsarApi.CommandMessage, ByteBuf) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handlePartitionResponse(PulsarApi.CommandPartitionedTopicMetadataResponse) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleProducerSuccess(PulsarApi.CommandProducerSuccess) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleReachedEndOfTopic(PulsarApi.CommandReachedEndOfTopic) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleSendError(PulsarApi.CommandSendError) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleSendReceipt(PulsarApi.CommandSendReceipt) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
handleSuccess(PulsarApi.CommandSuccess) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
hasBase64EncodedKey() - Method in interface org.apache.pulsar.client.api.Message
Check whether the key has been base64 encoded.
hasBase64EncodedKey() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
hasBase64EncodedKey() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
hasDataForHttp() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
Check if data for HTTP are available.
hasDataForHttp() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDataBasic
 
hasDataForTls() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
Check if data for TLS are available.
hasDataForTls() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDataTls
 
hasDataFromCommand() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
Check if data from Pulsar protocol are available.
hasDataFromCommand() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDataBasic
 
Hash - Interface in org.apache.pulsar.client.impl
 
hash - Variable in class org.apache.pulsar.client.impl.MessageRouterBase
 
hashCode() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
hashCode() - Method in class org.apache.pulsar.client.impl.ConsumerId
 
hashCode() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
hashCode() - Method in class org.apache.pulsar.client.impl.MessageIdImpl
 
HashingScheme - Enum in org.apache.pulsar.client.api
Standard hashing functions available when choosing the partition to use for a particular message.
hashingScheme(HashingScheme) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Change the HashingScheme used to chose the partition on where to publish a particular message.
hashingScheme(HashingScheme) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
hasKey() - Method in interface org.apache.pulsar.client.api.Message
Check whether the message has a key
hasKey() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
hasKey() - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
hasKey() - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
hasMessageAvailable() - Method in interface org.apache.pulsar.client.api.Reader
Check if there is any message available to read from the current position.
hasMessageAvailable() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
hasMessageAvailable() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
hasMessageAvailableAsync() - Method in interface org.apache.pulsar.client.api.Reader
Asynchronously Check if there is message that has been published successfully to the broker in the topic.
hasMessageAvailableAsync() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
hasMessageAvailableAsync() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
hasProperty(String) - Method in interface org.apache.pulsar.client.api.Message
Check whether the message has a specific property attached.
hasProperty(String) - Method in class org.apache.pulsar.client.impl.MessageImpl
 
hasProperty(String) - Method in class org.apache.pulsar.client.impl.TopicMessageImpl
 
hasReachedEndOfTopic() - Method in interface org.apache.pulsar.client.api.Consumer
Return true if the topic was terminated and this consumer has already consumed all the messages in the topic.
hasReachedEndOfTopic() - Method in interface org.apache.pulsar.client.api.Reader
Return true if the topic was terminated and this reader has reached the end of the topic
hasReachedEndOfTopic() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
hasReachedEndOfTopic() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
hasReachedEndOfTopic() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
hasReplicateTo() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
HttpClient - Class in org.apache.pulsar.client.impl
 
HttpClient(String, Authentication, EventLoopGroup, boolean, String) - Constructor for class org.apache.pulsar.client.impl.HttpClient
 
HttpClient(String, Authentication, EventLoopGroup, boolean, String, int, int) - Constructor for class org.apache.pulsar.client.impl.HttpClient
 
httpClient - Variable in class org.apache.pulsar.client.impl.HttpClient
 

I

incrementNumAcksFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
incrementNumAcksFailed() - Method in interface org.apache.pulsar.client.impl.ConsumerStatsRecorder
 
incrementNumAcksFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
incrementNumAcksReceived(long) - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
incrementNumAcksReceived(long) - Method in interface org.apache.pulsar.client.impl.ProducerStatsRecorder
 
incrementNumAcksReceived(long) - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
incrementNumAcksSent(long) - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
incrementNumAcksSent(long) - Method in interface org.apache.pulsar.client.impl.ConsumerStatsRecorder
 
incrementNumAcksSent(long) - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
incrementNumReceiveFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
incrementNumReceiveFailed() - Method in interface org.apache.pulsar.client.impl.ConsumerStatsRecorder
 
incrementNumReceiveFailed() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
incrementSendFailed() - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
incrementSendFailed(long) - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
incrementSendFailed() - Method in interface org.apache.pulsar.client.impl.ProducerStatsRecorder
 
incrementSendFailed(long) - Method in interface org.apache.pulsar.client.impl.ProducerStatsRecorder
 
incrementSendFailed() - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
incrementSendFailed(long) - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
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.
initialSequenceId(long) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
intercept(ConsumerInterceptor<T>...) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Intercept Consumer.
intercept(ProducerInterceptor<T>...) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Intercept Producer.
intercept(ConsumerInterceptor<T>...) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
intercept(ProducerInterceptor<T>...) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
interceptors - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
interceptors - Variable in class org.apache.pulsar.client.impl.ProducerBase
 
internalReceive() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
internalReceive(int, TimeUnit) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
internalReceive() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
internalReceive(int, TimeUnit) - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
internalReceive() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
internalReceive(int, TimeUnit) - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
internalReceiveAsync() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
internalReceiveAsync() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
internalReceiveAsync() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
InvalidConfigurationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
 
InvalidConfigurationException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
 
InvalidMessageException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidMessageException
 
InvalidServiceURL(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidServiceURL
 
InvalidTopicNameException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.InvalidTopicNameException
 
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)
ioThreads(int) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
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
 
isConnected() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
isConnected() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
isConnected() - Method in class org.apache.pulsar.client.impl.PartitionedProducerImpl
 
isConnected() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
isConnected() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
isDuplicate(MessageId) - Method in interface org.apache.pulsar.client.impl.AcknowledgmentsGroupingTracker
 
isDuplicate(MessageId) - Method in class org.apache.pulsar.client.impl.NonPersistentAcknowledgmentGroupingTracker
 
isDuplicate(MessageId) - Method in class org.apache.pulsar.client.impl.PersistentAcknowledgmentsGroupingTracker
Since the ack are delayed, we need to do some best-effort duplicate check to discard messages that are being resent after a disconnection and for which the user has already sent an acknowlowdgement.
isEncryptionEnabled() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Returns true if encryption keys are added
isEncryptionEnabled() - Method in class org.apache.pulsar.client.impl.conf.ProducerConfigurationData
Returns true if encryption keys are added
isExpired(int) - Method in class org.apache.pulsar.client.impl.MessageImpl
 
isHandshakeCompleted() - Method in class org.apache.pulsar.client.impl.ClientCnx
 
isKnownException(Throwable) - Static method in class org.apache.pulsar.client.impl.ClientCnx
 
isReplicated() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
isTlsAllowInsecureConnection() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
isTlsHostnameVerificationEnable() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
isUseTcpNoDelay() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
isUseTls() - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
isWritable() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
ivLen - Static variable in class org.apache.pulsar.client.impl.MessageCrypto
 

J

JavaStringHash - Class in org.apache.pulsar.client.impl
 

K

keepAliveInterval(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
Set keep alive interval in seconds for each client-broker-connection.
keepAliveInterval(int, TimeUnit) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
key(String) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Sets the key of the message for routing policy
key(String) - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
keyBytes(byte[]) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Sets the bytes of the key of the message for routing policy.
keyBytes(byte[]) - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 

L

latest - Static variable in interface org.apache.pulsar.client.api.MessageId
 
ledgerId - Variable in class org.apache.pulsar.client.impl.MessageIdImpl
 
listener - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
listenerExecutor - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
listenerThreads(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
Set the number of threads to be used for message listeners (default: 1 thread)
listenerThreads(int) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.ClientBuilder
Load the configuration from provided config map.
loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Load the configuration from provided config map.
loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Load the configuration from provided config map.
loadConf(Map<String, Object>) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
Load the configuration from provided config map.
loadConf(Map<String, Object>) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
loadConf(Map<String, Object>) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
loadConf(Map<String, Object>) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
loadConf(Map<String, Object>) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
loadData(Map<String, Object>, T, Class<T>) - Static method in class org.apache.pulsar.client.impl.conf.ConfigurationDataUtils
 
LookupDataResult(PulsarApi.CommandLookupTopicResponse) - Constructor for class org.apache.pulsar.client.impl.BinaryProtoLookupService.LookupDataResult
 
LookupDataResult(int) - Constructor for class org.apache.pulsar.client.impl.BinaryProtoLookupService.LookupDataResult
 
LookupException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.LookupException
 
LookupService - Interface in org.apache.pulsar.client.impl
Provides lookup service to find broker which serves given topic.

M

makeHash(String) - Method in interface org.apache.pulsar.client.impl.Hash
Generate the hash of a given String
makeHash(String) - Method in class org.apache.pulsar.client.impl.JavaStringHash
 
makeHash(String) - Method in class org.apache.pulsar.client.impl.Murmur3_32Hash
 
MathUtils - Class in org.apache.pulsar.client.util
 
MathUtils() - Constructor for class org.apache.pulsar.client.util.MathUtils
 
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.
maxConcurrentLookupRequests(int) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
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.
maxLookupRequests(int) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
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)
maxNumberOfRejectedRequestPerConnection(int) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
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.
maxPendingMessages(int) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
maxPendingMessagesAcrossPartitions(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Set the number of max pending messages across all the partitions
maxPendingMessagesAcrossPartitions(int) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
maxReceiverQueueSize - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
maxTotalReceiverQueueSizeAcrossPartitions(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Set the max total receiver queue size across partitons.
maxTotalReceiverQueueSizeAcrossPartitions(int) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
Message<T> - Interface in org.apache.pulsar.client.api
The message abstraction used in Pulsar.
MessageBuilder<T> - Interface in org.apache.pulsar.client.api
Deprecated.
since 2.0. Use TypedMessageBuilder as returned by Producer.newMessage() to create a new message builder.
MessageBuilderImpl<T> - Class in org.apache.pulsar.client.impl
 
MessageBuilderImpl(Schema<T>) - Constructor for class org.apache.pulsar.client.impl.MessageBuilderImpl
 
MessageCrypto - Class in org.apache.pulsar.client.impl
 
MessageCrypto(String, boolean) - Constructor for class org.apache.pulsar.client.impl.MessageCrypto
 
MessageId - Interface in org.apache.pulsar.client.api
Opaque unique identifier of a single message The MessageId can be used to reference a specific message, for example when acknowledging, without having to retain the message content in memory for an extended period of time.
messageId - Variable in class org.apache.pulsar.client.impl.MessageImpl
 
MessageIdImpl - Class in org.apache.pulsar.client.impl
 
MessageIdImpl(long, long, int) - Constructor for class org.apache.pulsar.client.impl.MessageIdImpl
 
MessageImpl<T> - Class in org.apache.pulsar.client.impl
 
MessageImpl(String, String, Map<String, String>, ByteBuf, Schema<T>) - Constructor for class org.apache.pulsar.client.impl.MessageImpl
 
messageListener(MessageListener<T>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Sets a MessageListener for the consumer
MessageListener<T> - Interface in org.apache.pulsar.client.api
A listener that will be called in order for every message received.
messageListener(MessageListener<T>) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
MessageParser - Class in org.apache.pulsar.client.impl
 
MessageParser() - Constructor for class org.apache.pulsar.client.impl.MessageParser
 
MessageParser.MessageProcessor - Interface in org.apache.pulsar.client.impl
 
messageProcessed(Message<?>) - Method in class org.apache.pulsar.client.impl.ConsumerImpl
Record the event that one message has been processed by the application.
MessageRouter - Interface in org.apache.pulsar.client.api
 
messageRouter(MessageRouter) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Set a custom message routing policy by passing an implementation of MessageRouter
messageRouter(MessageRouter) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
MessageRouterBase - Class in org.apache.pulsar.client.impl
 
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
Set the message routing mode for the partitioned producer.
messageRoutingMode(MessageRoutingMode) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
MultiTopicsConsumerImpl<T> - Class in org.apache.pulsar.client.impl
 
Murmur3_32Hash - Class in org.apache.pulsar.client.impl
 

N

namespaceName - Variable in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
newConnectCommand() - Method in class org.apache.pulsar.client.impl.ClientCnx
 
newConsumer() - Method in interface org.apache.pulsar.client.api.PulsarClient
Create a consumer with default for subscribing on a specific topic
newConsumer(Schema<T>) - Method in interface org.apache.pulsar.client.api.PulsarClient
Create a consumer with default for subscribing on a specific topic Since 2.2, if you are creating a consumer with non-bytes schema on a non-existence topic, it will automatically create the topic with the provided schema.
newConsumer() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
newConsumer(Schema<T>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
newGetTopicsOfNamespace(ByteBuf, long) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
newLookup(ByteBuf, long) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
newMessage() - Method in interface org.apache.pulsar.client.api.Producer
Create a new message builder This message builder allows to specify additional properties on the message.
newMessage() - Method in class org.apache.pulsar.client.impl.ProducerBase
 
newProducer() - Method in interface org.apache.pulsar.client.api.PulsarClient
Create a producer with default for publishing on a specific topic
newProducer(Schema<T>) - Method in interface org.apache.pulsar.client.api.PulsarClient
Create a producer with default for publishing on a specific topic
newProducer() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
newProducer(Schema<T>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
newReader() - Method in interface org.apache.pulsar.client.api.PulsarClient
Create a topic reader for reading messages from the specified topic.
newReader(Schema<T>) - Method in interface org.apache.pulsar.client.api.PulsarClient
Create a topic reader for reading messages from the specified topic.
newReader() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
newReader(Schema<T>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
newRequestId() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
next() - Method in class org.apache.pulsar.client.impl.Backoff
 
NonPersistentAcknowledgmentGroupingTracker - Class in org.apache.pulsar.client.impl
A no-op acknowledgment grouping tracker.
NotConnectedException() - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotConnectedException
 
NotFoundException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotFoundException
 
NotFoundException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotFoundException
 
NotSupportedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.NotSupportedException
 
nullData - Variable in class org.apache.pulsar.client.impl.auth.AuthenticationDisabled
 
numMessagesInQueue() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
numMessagesInQueue() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
numMessagesInQueue() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
numPartitions() - Method in interface org.apache.pulsar.client.api.TopicMetadata
Return the number of partitions per topic.

O

of() - Static method in class org.apache.pulsar.client.impl.NonPersistentAcknowledgmentGroupingTracker
 
oldOpenSet - Variable in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
onAcknowledge(Consumer<T>, MessageId, Throwable) - Method in interface org.apache.pulsar.client.api.ConsumerInterceptor
This is called consumer sends the acknowledgment to the broker.
onAcknowledge(MessageId, Throwable) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
onAcknowledge(Consumer<T>, MessageId, Throwable) - Method in class org.apache.pulsar.client.impl.ConsumerInterceptors
This is called when acknowledge request return from 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.
onAcknowledgeCumulative(MessageId, Throwable) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
onAcknowledgeCumulative(Consumer<T>, MessageId, Throwable) - Method in class org.apache.pulsar.client.impl.ConsumerInterceptors
This is called when acknowledge cumulative request return from the broker.
onSendAcknowledgement(Producer<T>, Message<T>, MessageId, Throwable) - Method in interface org.apache.pulsar.client.api.ProducerInterceptor
This method is called when the message sent to the broker has been acknowledged, or when sending the message fails.
onSendAcknowledgement(Message<T>, MessageId, Throwable) - Method in class org.apache.pulsar.client.impl.ProducerBase
 
onSendAcknowledgement(Producer<T>, Message<T>, MessageId, Throwable) - Method in class org.apache.pulsar.client.impl.ProducerInterceptors
This method is called when the message send to the broker has been acknowledged, or when sending the record fails before it gets send to the broker.
openConnection(URL) - Method in class org.apache.pulsar.client.api.url.DataURLStreamHandler
 
openConnection() - Method in class org.apache.pulsar.client.api.url.URL
 
operationTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
Set the operation timeout (default: 30 seconds)
operationTimeout(int, TimeUnit) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
org.apache.pulsar.client.api - package org.apache.pulsar.client.api
 
org.apache.pulsar.client.api.url - package org.apache.pulsar.client.api.url
 
org.apache.pulsar.client.impl - package org.apache.pulsar.client.impl
 
org.apache.pulsar.client.impl.auth - package org.apache.pulsar.client.impl.auth
 
org.apache.pulsar.client.impl.conf - package org.apache.pulsar.client.impl.conf
 
org.apache.pulsar.client.util - package org.apache.pulsar.client.util
 

P

parseMessage(TopicName, long, long, ByteBuf, MessageParser.MessageProcessor) - Static method in class org.apache.pulsar.client.impl.MessageParser
Parse a raw Pulsar entry payload and extract all the individual message that may be included in the batch.
PartitionedProducerImpl<T> - Class in org.apache.pulsar.client.impl
 
PartitionedProducerImpl(PulsarClientImpl, String, ProducerConfigurationData, int, CompletableFuture<Producer<T>>, Schema<T>, ProducerInterceptors<T>) - Constructor for class org.apache.pulsar.client.impl.PartitionedProducerImpl
 
partitionIndex - Variable in class org.apache.pulsar.client.impl.MessageIdImpl
 
partitions - Variable in class org.apache.pulsar.client.impl.BinaryProtoLookupService.LookupDataResult
 
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) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
PatternMultiTopicsConsumerImpl<T> - Class in org.apache.pulsar.client.impl
 
PatternMultiTopicsConsumerImpl(Pattern, PulsarClientImpl, ConsumerConfigurationData<T>, ExecutorService, CompletableFuture<Consumer<T>>, Schema<T>, PulsarApi.CommandGetTopicsOfNamespace.Mode, ConsumerInterceptors<T>) - Constructor for class org.apache.pulsar.client.impl.PatternMultiTopicsConsumerImpl
 
patternTopicSubscribeAsync(ConsumerConfigurationData<byte[]>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
pendingReceives - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
PersistentAcknowledgmentsGroupingTracker - Class in org.apache.pulsar.client.impl
Group the acknowledgments for a certain time and then sends them out in a single protobuf command.
PersistentAcknowledgmentsGroupingTracker(ConsumerImpl<?>, ConsumerConfigurationData<?>, EventLoopGroup) - Constructor for class org.apache.pulsar.client.impl.PersistentAcknowledgmentsGroupingTracker
 
pool - Variable in class org.apache.pulsar.client.impl.ConnectionPool
 
prevBatchMessageId() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
priorityLevel(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Sets priority level for the shared subscription consumers to which broker gives more priority while dispatching messages.
priorityLevel(int) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
privateKey - Variable in class org.apache.pulsar.client.impl.auth.AuthenticationDataTls
 
process(MessageId, Message<?>, ByteBuf) - Method in interface org.apache.pulsar.client.impl.MessageParser.MessageProcessor
 
Producer<T> - Interface in org.apache.pulsar.client.api
Producer object.
ProducerBase<T> - Class in org.apache.pulsar.client.impl
 
ProducerBase(PulsarClientImpl, String, ProducerConfigurationData, CompletableFuture<Producer<T>>, Schema<T>, ProducerInterceptors<T>) - Constructor for class org.apache.pulsar.client.impl.ProducerBase
 
ProducerBlockedQuotaExceededError(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerBlockedQuotaExceededError
 
ProducerBlockedQuotaExceededException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerBlockedQuotaExceededException
 
ProducerBuilder<T> - Interface in org.apache.pulsar.client.api
ProducerBuilder is used to configure and create instances of Producer.
ProducerBuilderImpl<T> - Class in org.apache.pulsar.client.impl
 
ProducerBuilderImpl(PulsarClientImpl, Schema<T>) - Constructor for class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
ProducerBusyException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerBusyException
 
ProducerConfiguration - Class in org.apache.pulsar.client.api
Deprecated.
use PulsarClient.newProducer() to construct and configure a Producer instance
ProducerConfiguration() - Constructor for class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
ProducerConfiguration.HashingScheme - Enum in org.apache.pulsar.client.api
Deprecated.
ProducerConfiguration.MessageRoutingMode - Enum in org.apache.pulsar.client.api
Deprecated.
ProducerConfigurationData - Class in org.apache.pulsar.client.impl.conf
 
ProducerConfigurationData() - Constructor for class org.apache.pulsar.client.impl.conf.ProducerConfigurationData
 
producerCreatedFuture - Variable in class org.apache.pulsar.client.impl.ProducerBase
 
producerCreatedFuture() - Method in class org.apache.pulsar.client.impl.ProducerBase
 
ProducerCryptoFailureAction - Enum in org.apache.pulsar.client.api
 
ProducerImpl<T> - Class in org.apache.pulsar.client.impl
 
ProducerImpl(PulsarClientImpl, String, ProducerConfigurationData, CompletableFuture<Producer<T>>, int, Schema<T>, ProducerInterceptors<T>) - Constructor for class org.apache.pulsar.client.impl.ProducerImpl
 
ProducerImpl.OpSendMsg - Class in org.apache.pulsar.client.impl
 
ProducerInterceptor<T> - Interface in org.apache.pulsar.client.api
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.
ProducerInterceptors<T> - Class in org.apache.pulsar.client.impl
A container that holds the listProducerInterceptor and wraps calls to the chain of custom interceptors.
ProducerInterceptors(List<ProducerInterceptor<T>>) - Constructor for class org.apache.pulsar.client.impl.ProducerInterceptors
 
producerName(String) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Specify a name for the producer
producerName(String) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
ProducerQueueIsFullError(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ProducerQueueIsFullError
 
ProducerResponse - Class in org.apache.pulsar.client.impl
 
ProducerResponse() - Constructor for class org.apache.pulsar.client.impl.ProducerResponse
 
ProducerStats - Interface in org.apache.pulsar.client.api
Producer statistics recorded by client.
ProducerStatsDisabled - Class in org.apache.pulsar.client.impl
 
ProducerStatsDisabled() - Constructor for class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
ProducerStatsRecorder - Interface in org.apache.pulsar.client.impl
 
ProducerStatsRecorderImpl - Class in org.apache.pulsar.client.impl
 
ProducerStatsRecorderImpl() - Constructor for class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
ProducerStatsRecorderImpl(PulsarClientImpl, ProducerConfigurationData, ProducerImpl<?>) - Constructor for class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
properties(Map<String, String>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Add all the properties in the provided map
properties(Map<String, String>) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Add all the properties in the provided map
properties(Map<String, String>) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Add all the properties in the provided map
properties(Map<String, String>) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
properties(Map<String, String>) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
properties(Map<String, String>) - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
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.TypedMessageBuilder
Sets a new property on a message.
property(String, String) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
property(String, String) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
property(String, String) - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
proxyThroughServiceUrl - Variable in class org.apache.pulsar.client.impl.BinaryProtoLookupService.LookupDataResult
 
proxyToTargetBrokerAddress - Variable in class org.apache.pulsar.client.impl.ClientCnx
 
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
 
PulsarClientException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException
 
PulsarClientException.AlreadyClosedException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.AuthenticationException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.AuthorizationException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.BrokerMetadataException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.BrokerPersistenceException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.ChecksumException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.ConnectException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.ConsumerBusyException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.CryptoException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.GettingAuthenticationDataException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.InvalidConfigurationException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.InvalidMessageException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.InvalidServiceURL - Exception in org.apache.pulsar.client.api
 
PulsarClientException.InvalidTopicNameException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.LookupException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.NotConnectedException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.NotFoundException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.NotSupportedException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.ProducerBlockedQuotaExceededError - Exception in org.apache.pulsar.client.api
 
PulsarClientException.ProducerBlockedQuotaExceededException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.ProducerBusyException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.ProducerQueueIsFullError - Exception in org.apache.pulsar.client.api
 
PulsarClientException.TimeoutException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.TooManyRequestsException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.TopicTerminatedException - Exception in org.apache.pulsar.client.api
 
PulsarClientException.UnsupportedAuthenticationException - Exception in org.apache.pulsar.client.api
 
PulsarClientImpl - Class in org.apache.pulsar.client.impl
 
PulsarClientImpl(String, ClientConfiguration) - Constructor for class org.apache.pulsar.client.impl.PulsarClientImpl
Deprecated.
PulsarClientImpl(String, ClientConfiguration, EventLoopGroup) - Constructor for class org.apache.pulsar.client.impl.PulsarClientImpl
Deprecated.
PulsarClientImpl(String, ClientConfiguration, EventLoopGroup, ConnectionPool) - Constructor for class org.apache.pulsar.client.impl.PulsarClientImpl
Deprecated.
PulsarClientImpl(ClientConfigurationData) - Constructor for class org.apache.pulsar.client.impl.PulsarClientImpl
 
PulsarClientImpl(ClientConfigurationData, EventLoopGroup) - Constructor for class org.apache.pulsar.client.impl.PulsarClientImpl
 
PulsarClientImpl(ClientConfigurationData, EventLoopGroup, ConnectionPool) - Constructor for class org.apache.pulsar.client.impl.PulsarClientImpl
 
PulsarURLStreamHandlerFactory - Class in org.apache.pulsar.client.api.url
 
PulsarURLStreamHandlerFactory() - Constructor for class org.apache.pulsar.client.api.url.PulsarURLStreamHandlerFactory
 

R

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
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.
readCompacted(boolean) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
readCompacted(boolean) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
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
ReaderBuilder is used to configure and create instances of Reader.
ReaderBuilderImpl<T> - Class in org.apache.pulsar.client.impl
 
ReaderConfiguration - Class in org.apache.pulsar.client.api
Deprecated.
Use PulsarClient.newReader() to construct and configure a Reader instance
ReaderConfiguration() - Constructor for class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
 
ReaderConfigurationData<T> - Class in org.apache.pulsar.client.impl.conf
 
ReaderConfigurationData() - Constructor for class org.apache.pulsar.client.impl.conf.ReaderConfigurationData
 
ReaderImpl<T> - Class in org.apache.pulsar.client.impl
 
ReaderImpl(PulsarClientImpl, ReaderConfigurationData<T>, ExecutorService, CompletableFuture<Consumer<T>>, Schema<T>) - Constructor for class org.apache.pulsar.client.impl.ReaderImpl
 
readerListener(ReaderListener<T>) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
Sets a ReaderListener for the reader
ReaderListener<T> - Interface in org.apache.pulsar.client.api
A listener that will be called in order for every message received.
readerListener(ReaderListener<T>) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
readerName(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
Set the reader name.
readerName(String) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
readLock - Variable in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
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 of timeout time units.
readNext() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
readNext(int, TimeUnit) - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
readNextAsync() - Method in interface org.apache.pulsar.client.api.Reader
 
readNextAsync() - Method in class org.apache.pulsar.client.impl.ReaderImpl
 
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
receive() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
receive(int, TimeUnit) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
receiveAsync() - Method in interface org.apache.pulsar.client.api.Consumer
Receive a single message
receiveAsync() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
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.
receiveIndividualMessagesFromBatch(String, PulsarApi.MessageMetadata, ByteBuf, PulsarApi.MessageIdData, ClientCnx, int, MessageParser.MessageProcessor) - Static method in class org.apache.pulsar.client.impl.MessageParser
 
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.
receiverQueueSize(int) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
receiverQueueSize(int) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
recoverChecksumError(ClientCnx, long) - Method in class org.apache.pulsar.client.impl.ProducerImpl
Checks message checksum to retry if message was corrupted while sending to broker.
recycle() - Method in class org.apache.pulsar.client.impl.MessageImpl
 
redeliverUnacknowledgedMessages() - Method in interface org.apache.pulsar.client.api.Consumer
Redelivers all the unacknowledged messages.
redeliverUnacknowledgedMessages(Set<MessageId>) - Method in class org.apache.pulsar.client.impl.ConsumerBase
Redelivers the given unacknowledged messages.
redeliverUnacknowledgedMessages() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
redeliverUnacknowledgedMessages(Set<MessageId>) - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
redeliverUnacknowledgedMessages() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
redeliverUnacknowledgedMessages(Set<MessageId>) - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
redirect - Variable in class org.apache.pulsar.client.impl.BinaryProtoLookupService.LookupDataResult
 
reduceToHalf() - Method in class org.apache.pulsar.client.impl.Backoff
 
reloadLookUp() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
remove(MessageId) - Method in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
removeEncryptionKey(String) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
removeKeyCipher(String) - Method in class org.apache.pulsar.client.impl.MessageCrypto
 
removeMessagesTill(MessageId) - Method in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
removeTopicMessages(String) - Method in class org.apache.pulsar.client.impl.UnAckedTopicMessageTracker
 
replicationClusters(List<String>) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Override the replication clusters for this message.
replicationClusters(List<String>) - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
reset() - Method in class org.apache.pulsar.client.impl.Backoff
 
reset() - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
reset() - Method in interface org.apache.pulsar.client.impl.ConsumerStatsRecorder
 
reset() - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
RoundRobinPartitionMessageRouterImpl - Class in org.apache.pulsar.client.impl
The routing strategy here: If a key is present, choose a partition based on a hash of the key.
RoundRobinPartitionMessageRouterImpl(HashingScheme, int, boolean, long) - Constructor for class org.apache.pulsar.client.impl.RoundRobinPartitionMessageRouterImpl
 
RoundRobinPartitionMessageRouterImpl(HashingScheme, int, boolean, long, Clock) - Constructor for class org.apache.pulsar.client.impl.RoundRobinPartitionMessageRouterImpl
 
run(Timeout) - Method in class org.apache.pulsar.client.impl.PatternMultiTopicsConsumerImpl
 
run(Timeout) - Method in class org.apache.pulsar.client.impl.ProducerImpl
Process sendTimeout events

S

schema - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
schema - Variable in class org.apache.pulsar.client.impl.ProducerBase
 
schema(Schema<T>) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
Allow to override schema in builder implementation
seek(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
Reset the subscription associated with this consumer to a specific message id.
seek(MessageId) - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
seek(MessageId) - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
seekAsync(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
Reset the subscription associated with this consumer to a specific message id.
seekAsync(MessageId) - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
seekAsync(MessageId) - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
send(T) - Method in interface org.apache.pulsar.client.api.Producer
Sends a message.
send(Message<T>) - Method in interface org.apache.pulsar.client.api.Producer
Deprecated.
since 2.0. Use TypedMessageBuilder as returned by Producer.newMessage() to create a new message builder.
send() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Send a message synchronously.
send(T) - Method in class org.apache.pulsar.client.impl.ProducerBase
 
send(Message<T>) - Method in class org.apache.pulsar.client.impl.ProducerBase
 
send() - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
sendAsync(T) - Method in interface org.apache.pulsar.client.api.Producer
Send a message asynchronously
sendAsync(Message<T>) - Method in interface org.apache.pulsar.client.api.Producer
Deprecated.
since 2.0. Use TypedMessageBuilder as returned by Producer.newMessage() to create a new message builder.
sendAsync() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Send a message asynchronously
sendAsync(T) - Method in class org.apache.pulsar.client.impl.ProducerBase
 
sendAsync(Message<T>) - Method in class org.apache.pulsar.client.impl.ProducerBase
 
sendAsync(Message<T>, SendCallback) - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
sendAsync() - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
SendCallback - Interface in org.apache.pulsar.client.impl
 
sendComplete(Exception) - Method in interface org.apache.pulsar.client.impl.SendCallback
invoked when send operation completes
sendGetLastMessageId(ByteBuf, long) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
sendGetSchema(ByteBuf, long) - Method in class org.apache.pulsar.client.impl.ClientCnx
 
sendTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
Set the send timeout (default: 30 seconds)
sendTimeout(int, TimeUnit) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
sequenceId(long) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Specify a custom sequence id for the message being published.
sequenceId(long) - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
serviceAddress - Variable in class org.apache.pulsar.client.impl.BinaryProtoLookupService
 
serviceUrl(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
Configure the service URL for the Pulsar service.
serviceUrl(String) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
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.
serviceUrlProvider(ServiceUrlProvider) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
setAckTimeout(long, TimeUnit) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Set the timeout for unacked messages, truncated to the nearest millisecond.
setAuthentication(Authentication) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Set the authentication provider to use in the Pulsar client instance.
setAuthentication(String, String) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Set the authentication provider to use in the Pulsar client instance.
setAuthentication(String, Map<String, String>) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Set the authentication provider to use in the Pulsar client instance.
setBatchingEnabled(boolean) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Control whether automatic batching of messages is enabled for the producer.
setBatchingMaxMessages(int) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set the maximum number of messages permitted in a batch.
setBatchingMaxPublishDelay(long, TimeUnit) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set the time period within which the messages sent will be batched default: 10ms if batch messages are enabled.
setBlockIfQueueFull(boolean) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set whether the Producer.send(T) and Producer.sendAsync(T) operations should block when the outgoing message queue is full.
setCompressionType(CompressionType) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set the compression type for the producer.
setConcurrentLookupRequest(int) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Number of concurrent lookup-requests allowed on each broker-connection to prevent overload on broker.
setConnectionsPerBroker(int) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Sets the max number of connection that the client library will open to a single broker.
setConsumerEventListener(ConsumerEventListener) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Sets a ConsumerEventListener for the consumer.
setConsumerName(String) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Set the consumer name.
setContent(byte[]) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Set the content of the message
setContent(byte[], int, int) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Set the content of the message
setContent(ByteBuffer) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Set the content of the message
setContent(byte[]) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
setContent(byte[], int, int) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
setContent(ByteBuffer) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
setCryptoFailureAction(ConsumerCryptoFailureAction) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Sets the ConsumerCryptoFailureAction to the value specified
setCryptoFailureAction(ProducerCryptoFailureAction) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Sets the ProducerCryptoFailureAction to the value specified
setCryptoFailureAction(ConsumerCryptoFailureAction) - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
Sets the ConsumerCryptoFailureAction to the value specified
setCryptoKeyReader(CryptoKeyReader) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
setCryptoKeyReader(CryptoKeyReader) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
setCryptoKeyReader(CryptoKeyReader) - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
setEventTime(long) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Set the event time for a given message.
setEventTime(long) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
setHashingScheme(ProducerConfiguration.HashingScheme) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
 
setInitialSequenceId(long) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set the baseline for the sequence ids for messages published by the producer.
setIoThreads(int) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Set the number of threads to be used for handling connections to brokers (default: 1 thread)
setKey(byte[]) - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
 
setKey(String) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Sets the key of the message for routing policy
setKey(String) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
setListenerThreads(int) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Set the number of threads to be used for message listeners (default: 1 thread)
setMaxNumberOfRejectedRequestPerConnection(int) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
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)
setMaxPendingMessages(int) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set the max size of the queue holding the messages pending to receive an acknowledgment from the broker.
setMaxPendingMessagesAcrossPartitions(int) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set the number of max pending messages across all the partitions
setMaxReceiverQueueSize(int) - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
setMaxTotalReceiverQueueSizeAcrossPartitions(int) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Set the max total receiver queue size across partitons.
setMessageListener(MessageListener<byte[]>) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Sets a MessageListener for the consumer
setMessageRouter(MessageRouter) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set a custom message routing policy by passing an implementation of MessageRouter
setMessageRoutingMode(ProducerConfiguration.MessageRoutingMode) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set the message routing mode for the partitioned producer.
setMetadata(Map<String, String>) - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
 
setOperationTimeout(int, TimeUnit) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Set the operation timeout (default: 30 seconds)
setPriorityLevel(int) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Sets priority level for the shared subscription consumers to which broker gives more priority while dispatching messages.
setProducerName(String) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Specify a name for the producer
setProperties(Map<String, String>) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Add all the properties in the provided map
setProperties(Map<String, String>) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Add all the properties in the provided map
setProperties(Map<String, String>) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Add all the properties in the provided map
setProperties(Map<String, String>) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
setProperty(String, String) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Set a name/value property with this consumer.
setProperty(String, String) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Sets a new property on a message.
setProperty(String, String) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set a name/value property with this producer.
setProperty(String, String) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
setReadCompacted(boolean) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
If enabled, the consumer will read messages from the compacted topic rather than reading the full message backlog of the topic.
setReaderListener(ReaderListener<byte[]>) - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
Sets a ReaderListener for the reader
setReaderName(String) - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
Set the consumer name.
setReceiverQueueSize(int) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Sets the size of the consumer receive queue.
setReceiverQueueSize(int) - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
Sets the size of the consumer receive queue.
setReplicatedFrom(String) - Method in class org.apache.pulsar.client.impl.MessageImpl
 
setReplicationClusters(List<String>) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Override the replication clusters for this message.
setReplicationClusters(List<String>) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
setSendTimeout(int, TimeUnit) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
Deprecated.
Set the send timeout (default: 30 seconds)
setSequenceId(long) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Specify a custom sequence id for the message being published.
setSequenceId(long) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
setServiceUrl(String) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
 
setStatsInterval(long, TimeUnit) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Set the interval between each stat info (default: 60 seconds) Stats will be activated with positive statsIntervalSeconds It should be set to at least 1 second
setSubscriptionInitialPosition(SubscriptionInitialPosition) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
 
setSubscriptionRolePrefix(String) - Method in class org.apache.pulsar.client.api.ReaderConfiguration
Deprecated.
Set the subscription role prefix for subscription auth.
setSubscriptionType(SubscriptionType) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
Deprecated.
Select the subscription type to be used when subscribing to the topic.
setTlsAllowInsecureConnection(boolean) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Configure whether the Pulsar client accept untrusted TLS certificate from broker (default: false)
setTlsHostnameVerificationEnable(boolean) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
It allows to validate hostname verification when client connects to broker over tls.
setTlsTrustCertsFilePath(String) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Set the path to the trusted TLS certificate file
setUseTcpNoDelay(boolean) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Configure whether to use TCP no-delay flag on the connection, to disable Nagle algorithm.
setUseTls(boolean) - Method in class org.apache.pulsar.client.api.ClientConfiguration
Deprecated.
Configure whether to use TLS encryption on the connection (default: false)
setValue(T) - Method in interface org.apache.pulsar.client.api.MessageBuilder
Deprecated.
Set a domain object on the message
setValue(T) - Method in class org.apache.pulsar.client.impl.MessageBuilderImpl
 
shouldBackoff(long, TimeUnit, int) - Static method in class org.apache.pulsar.client.impl.Backoff
 
shutdown() - Method in interface org.apache.pulsar.client.api.PulsarClient
Perform immediate shutdown of PulsarClient.
shutdown() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
shutdownNow() - Method in class org.apache.pulsar.client.util.ExecutorProvider
 
signSafeMod(long, int) - Static method in class org.apache.pulsar.client.impl.ConnectionPool
 
signSafeMod(long, int) - Static method in class org.apache.pulsar.client.util.MathUtils
Compute sign safe mod
SinglePartitionMessageRouterImpl - Class in org.apache.pulsar.client.impl
 
SinglePartitionMessageRouterImpl(int, HashingScheme) - Constructor for class org.apache.pulsar.client.impl.SinglePartitionMessageRouterImpl
 
start() - Method in interface org.apache.pulsar.client.api.Authentication
Initialize the authentication provider
start() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationBasic
 
start() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationDisabled
 
start() - Method in class org.apache.pulsar.client.impl.auth.AuthenticationTls
 
start(PulsarClientImpl, ConsumerBase<?>, long) - Method in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
startMessageId(MessageId) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
The initial reader positioning is done by specifying a message id.
startMessageId(MessageId) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
stats - Variable in class org.apache.pulsar.client.impl.ConsumerImpl
 
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 statsIntervalSeconds It should be set to at least 1 second
statsInterval(long, TimeUnit) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
subscribe() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Finalize the Consumer creation by subscribing to the topic.
subscribe(String, String) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
Use PulsarClient.newConsumer() to build a new consumer
subscribe(String, String, ConsumerConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
Use PulsarClient.newConsumer() to build a new consumer
subscribe() - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
subscribe(String, String) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
subscribe(String, String, ConsumerConfiguration) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
subscribeAsync() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Finalize the Consumer creation by subscribing to the topic in asynchronous mode.
subscribeAsync(String, String) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
Use PulsarClient.newConsumer() to build a new consumer
subscribeAsync(String, String, ConsumerConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
Deprecated.
Use PulsarClient.newConsumer() to build a new consumer
subscribeAsync() - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
subscribeAsync(String) - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
subscribeAsync(String, String) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
subscribeAsync(String, String, ConsumerConfiguration) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
subscribeAsync(ConsumerConfigurationData<byte[]>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
subscribeAsync(ConsumerConfigurationData<T>, Schema<T>, ConsumerInterceptors<T>) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
subscribeFuture - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
subscribeFuture() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
subscription - Variable in class org.apache.pulsar.client.impl.ConsumerBase
 
subscriptionInitialPosition(SubscriptionInitialPosition) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Set subscriptionInitialPosition for the consumer
SubscriptionInitialPosition - Enum in org.apache.pulsar.client.api
intial position at which the cursor will be set when subscribe
subscriptionInitialPosition(SubscriptionInitialPosition) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
subscriptionName(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Specify the subscription name for this consumer.
subscriptionName(String) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
subscriptionRolePrefix(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
Set the subscription role prefix.
subscriptionRolePrefix(String) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
subscriptionTopicsMode(PulsarApi.CommandGetTopicsOfNamespace.Mode) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
Determines to which topics this consumer should be subscribed to - Persistent, Non-Persistent, or both.
subscriptionTopicsMode(PulsarApi.CommandGetTopicsOfNamespace.Mode) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
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
subscriptionType(SubscriptionType) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 

T

terminated(ClientCnx) - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
TimeoutException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TimeoutException
 
timer() - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
visiable for pulsar-functions
TLS_HANDLER - Static variable in class org.apache.pulsar.client.impl.ConnectionPool
 
tlsTrustCertsFilePath(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
Set the path to the trusted TLS certificate file
tlsTrustCertsFilePath(String) - Method in class org.apache.pulsar.client.impl.ClientBuilderImpl
 
toByteArray() - Method in interface org.apache.pulsar.client.api.MessageId
Serialize the message ID into a byte array
toByteArray() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
toByteArray(int) - Method in class org.apache.pulsar.client.impl.MessageIdImpl
 
toByteArray() - Method in class org.apache.pulsar.client.impl.MessageIdImpl
 
toByteArray() - Method in class org.apache.pulsar.client.impl.TopicMessageIdImpl
 
TooManyRequestsException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TooManyRequestsException
 
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 consumer will subscribe on.
topic(String...) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
topic(String) - Method in class org.apache.pulsar.client.impl.ProducerBuilderImpl
 
topic(String) - Method in class org.apache.pulsar.client.impl.ReaderBuilderImpl
 
TopicMessageIdImpl - Class in org.apache.pulsar.client.impl
 
TopicMessageImpl<T> - Class in org.apache.pulsar.client.impl
 
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.
topics(List<String>) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
topics - Variable in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
topicsListsMinus(List<String>, List<String>) - Static method in class org.apache.pulsar.client.impl.PatternMultiTopicsConsumerImpl
 
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.
topicsPattern(Pattern) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
topicsPattern(String) - Method in class org.apache.pulsar.client.impl.ConsumerBuilderImpl
 
topicsPatternFilter(List<String>, Pattern) - Static method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
TopicTerminatedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.TopicTerminatedException
 
toString() - Method in class org.apache.pulsar.client.impl.BatchMessageIdImpl
 
toString() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
toString() - Method in class org.apache.pulsar.client.impl.MessageIdImpl
 
toString() - Method in class org.apache.pulsar.client.impl.ProducerBase
 
triggerFlush() - Method in class org.apache.pulsar.client.impl.ProducerImpl
 
TypedMessageBuilder<T> - Interface in org.apache.pulsar.client.api
Message builder that constructs a message to be published through a producer.
TypedMessageBuilderImpl<T> - Class in org.apache.pulsar.client.impl
 
TypedMessageBuilderImpl(ProducerBase<T>, Schema<T>) - Constructor for class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 

U

UNACKED_MESSAGE_TRACKER_DISABLED - Static variable in class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
UnAckedMessageTracker - Class in org.apache.pulsar.client.impl
 
UnAckedMessageTracker() - Constructor for class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
UnAckedMessageTracker(PulsarClientImpl, ConsumerBase<?>, long) - Constructor for class org.apache.pulsar.client.impl.UnAckedMessageTracker
 
UnAckedTopicMessageTracker - Class in org.apache.pulsar.client.impl
 
UnAckedTopicMessageTracker(PulsarClientImpl, ConsumerBase<?>, long) - Constructor for class org.apache.pulsar.client.impl.UnAckedTopicMessageTracker
 
uncompressPayloadIfNeeded(PulsarApi.MessageIdData, PulsarApi.MessageMetadata, ByteBuf, String, String) - Static method in class org.apache.pulsar.client.impl.MessageParser
 
unsubscribe() - Method in interface org.apache.pulsar.client.api.Consumer
Unsubscribe the consumer
unsubscribe() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
unsubscribeAsync() - Method in interface org.apache.pulsar.client.api.Consumer
Asynchronously unsubscribe the consumer
unsubscribeAsync() - Method in class org.apache.pulsar.client.impl.ConsumerBase
 
unsubscribeAsync() - Method in class org.apache.pulsar.client.impl.ConsumerImpl
 
unsubscribeAsync() - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
unsubscribeAsync(String) - Method in class org.apache.pulsar.client.impl.MultiTopicsConsumerImpl
 
UnsupportedAuthenticationException(Throwable) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.UnsupportedAuthenticationException
 
UnsupportedAuthenticationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.UnsupportedAuthenticationException
 
updateCumulativeStats(ConsumerStats) - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
updateCumulativeStats(ConsumerStats) - Method in interface org.apache.pulsar.client.impl.ConsumerStatsRecorder
 
updateCumulativeStats(ConsumerStats) - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
updateNumMsgsReceived(Message<?>) - Method in class org.apache.pulsar.client.impl.ConsumerStatsDisabled
 
updateNumMsgsReceived(Message<?>) - Method in interface org.apache.pulsar.client.impl.ConsumerStatsRecorder
 
updateNumMsgsReceived(Message<?>) - Method in class org.apache.pulsar.client.impl.ConsumerStatsRecorderImpl
 
updateNumMsgsSent(long, long) - Method in class org.apache.pulsar.client.impl.ProducerStatsDisabled
 
updateNumMsgsSent(long, long) - Method in interface org.apache.pulsar.client.impl.ProducerStatsRecorder
 
updateNumMsgsSent(long, long) - Method in class org.apache.pulsar.client.impl.ProducerStatsRecorderImpl
 
updateServiceUrl(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
Update the service URL this client is using.
updateServiceUrl(String) - Method in class org.apache.pulsar.client.impl.BinaryProtoLookupService
 
updateServiceUrl(String) - Method in interface org.apache.pulsar.client.impl.LookupService
Instruct the LookupService to switch to a new service URL for all subsequent requests
updateServiceUrl(String) - Method in class org.apache.pulsar.client.impl.PulsarClientImpl
 
URL - Class in org.apache.pulsar.client.api.url
 
URL(String) - Constructor for class org.apache.pulsar.client.api.url.URL
 
url - Variable in class org.apache.pulsar.client.impl.HttpClient
 

V

value(T) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
Set a domain object on the message
value(T) - Method in class org.apache.pulsar.client.impl.TypedMessageBuilderImpl
 
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.MessageRoutingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pulsar.client.api.ProducerConfiguration.HashingScheme
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pulsar.client.api.ProducerConfiguration.MessageRoutingMode
Deprecated.
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.SubscriptionInitialPosition
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.
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.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.ProducerConfiguration.HashingScheme
Deprecated.
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.ProducerConfiguration.MessageRoutingMode
Deprecated.
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.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.SubscriptionType
Returns an array containing the constants of this enum type, in the order they are declared.
verifyChecksum(ByteBuf, PulsarApi.MessageIdData, String, String) - Static method in class org.apache.pulsar.client.impl.MessageParser
 
verifyLocalBufferIsNotCorrupted(ProducerImpl.OpSendMsg) - Method in class org.apache.pulsar.client.impl.ProducerImpl
Computes checksum again and verifies it against existing checksum.
A B C D E F G H I J K L M N O P R S T U V 
Skip navigation links

Copyright © 2017–2018 Apache Software Foundation. All rights reserved.