- 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
- 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
- acknowledgeCumulative(Message<?>) - Method in interface org.apache.pulsar.client.api.Consumer
-
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.
- acknowledgeCumulative(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
-
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.
- acknowledgeCumulativeAsync(Message<?>) - Method in interface org.apache.pulsar.client.api.Consumer
-
Asynchronously Acknowledge the reception of all the messages in the stream up to (and including) the provided
message.
- acknowledgeCumulativeAsync(MessageId) - Method in interface org.apache.pulsar.client.api.Consumer
-
Asynchronously Acknowledge the reception of all the messages in the stream up to (and including) the provided
message.
- acknowledgmentGroupTime(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Group the consumer acknowledgments for the specified time.
- ackTimeout(long, TimeUnit) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set the timeout for unacked messages, truncated to the nearest millisecond.
- 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.
- allowTlsInsecureConnection(boolean) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Configure whether the Pulsar client accept untrusted TLS certificate from broker (default: false)
- AlreadyClosedException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AlreadyClosedException
-
- Authentication - Interface in org.apache.pulsar.client.api
-
Interface of authentication providers.
- authentication(Authentication) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Set the authentication provider to use in the Pulsar client instance.
- authentication(String, String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
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.
- AuthenticationDataProvider - Interface in org.apache.pulsar.client.api
-
Interface for accessing data which are used in variety of authentication schemes on client side
- AuthenticationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AuthenticationException
-
- AuthenticationFactory - Class in org.apache.pulsar.client.api
-
- AuthenticationFactory() - Constructor for class org.apache.pulsar.client.api.AuthenticationFactory
-
- AuthenticationUtil - Class in org.apache.pulsar.client.api
-
- AuthenticationUtil() - Constructor for class org.apache.pulsar.client.api.AuthenticationUtil
-
- AuthorizationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AuthorizationException
-
- AUTO() - Static method in interface org.apache.pulsar.client.api.Schema
-
Deprecated.
- AUTO_CONSUME() - Static method in interface org.apache.pulsar.client.api.Schema
-
- AUTO_PRODUCE_BYTES() - Static method in interface org.apache.pulsar.client.api.Schema
-
- AVRO(Class<T>) - Static method in interface org.apache.pulsar.client.api.Schema
-
- ChecksumException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ChecksumException
-
- choosePartition(Message<?>) - Method in interface org.apache.pulsar.client.api.MessageRouter
-
- choosePartition(Message<?>, TopicMetadata) - Method in interface org.apache.pulsar.client.api.MessageRouter
-
Choose a partition based on msg and the topic metadata.
- ClientBuilder - Interface in org.apache.pulsar.client.api
-
Builder interface that is used to construct a
PulsarClient
instance.
- ClientConfiguration - Class in org.apache.pulsar.client.api
-
- ClientConfiguration() - Constructor for class org.apache.pulsar.client.api.ClientConfiguration
-
Deprecated.
- clone() - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Create a copy of the current client builder.
- clone() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Create a copy of the current consumer builder.
- clone() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
- clone() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
- 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.
- 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
- 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.
- configure(Map<String, String>) - Method in interface org.apache.pulsar.client.api.Authentication
-
- configure(String) - Method in interface org.apache.pulsar.client.api.EncodedAuthenticationParameterSupport
-
Plugins which use ":" and/or "," in a configuration parameter value need to implement this interface.
- 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
-
- connectionsPerBroker(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Sets the max number of connection that the client library will open to a single broker.
- connectionTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Set the duration of time to wait for a connection to a broker to be established.
- Consumer<T> - Interface in org.apache.pulsar.client.api
-
An interface that abstracts behavior of Pulsar's consumer.
- ConsumerBuilder<T> - Interface in org.apache.pulsar.client.api
-
- ConsumerBusyException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.ConsumerBusyException
-
- ConsumerConfiguration - Class in org.apache.pulsar.client.api
-
- ConsumerConfiguration() - Constructor for class org.apache.pulsar.client.api.ConsumerConfiguration
-
Deprecated.
- ConsumerCryptoFailureAction - Enum in org.apache.pulsar.client.api
-
- consumerEventListener(ConsumerEventListener) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
- ConsumerEventListener - Interface in org.apache.pulsar.client.api
-
Listener on the consumer state changes.
- ConsumerInterceptor<T> - Interface in org.apache.pulsar.client.api
-
A plugin interface that allows you to intercept (and possibly mutate)
messages received by the consumer.
- consumerName(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set the consumer name.
- ConsumerStats - Interface in org.apache.pulsar.client.api
-
Consumer statistics recorded by client.
- 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
-
- create(String, ClientConfiguration) - Static method in interface org.apache.pulsar.client.api.PulsarClient
-
- create() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Finalize the creation of the
Reader
instance.
- createAsync() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Finalize the creation of the
Producer
instance in asynchronous mode.
- createAsync() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Finalize the creation of the
Reader
instance in asynchronous mode.
- createProducer(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
- createProducer(String, ProducerConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
- createProducerAsync(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
- createProducerAsync(String, ProducerConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
- createReader(String, MessageId, ReaderConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
- createReaderAsync(String, MessageId, ReaderConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
- 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
- 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
-
- getAckTimeoutMillis() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
-
Deprecated.
- getAuthData() - Method in interface org.apache.pulsar.client.api.Authentication
-
- getAuthentication() - Method in class org.apache.pulsar.client.api.ClientConfiguration
-
Deprecated.
- getAuthMethodName() - Method in interface org.apache.pulsar.client.api.Authentication
-
- 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.
- getBlockIfQueueFull() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
-
Deprecated.
- getCommandData() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
-
- 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.
- getConfigurationData() - Method in class org.apache.pulsar.client.api.ClientConfiguration
-
Deprecated.
- getConfigurationData() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
-
Deprecated.
- getConnectionsPerBroker() - Method in class org.apache.pulsar.client.api.ClientConfiguration
-
Deprecated.
- getConnectionTimeoutMs() - Method in class org.apache.pulsar.client.api.ClientConfiguration
-
Deprecated.
Get the duration of time for which the client will wait for a connection to a broker to be
established before giving up.
- 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.
- 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
- 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.
- getEncryptionKeys() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
-
Deprecated.
- getEventTime() - Method in interface org.apache.pulsar.client.api.Message
-
Get the event time associated with this message.
- 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
-
- getInitialSequenceId() - Method in class org.apache.pulsar.client.api.ProducerConfiguration
-
Deprecated.
- 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
- getKeyBytes() - Method in interface org.apache.pulsar.client.api.Message
-
Get bytes in key.
- getLastSequenceId() - Method in interface org.apache.pulsar.client.api.Producer
-
Get the last sequence id that was published by this producer.
- getListenerThreads() - Method in class org.apache.pulsar.client.api.ClientConfiguration
-
Deprecated.
- 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.
- getMessageId() - Method in interface org.apache.pulsar.client.api.Message
-
Get the unique message ID associated with this message.
- getMessageListener() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
-
Deprecated.
- getMessageRouter(int) - Method in class org.apache.pulsar.client.api.ProducerConfiguration
-
- 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
-
- getNumAcksFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getNumAcksReceived() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getNumAcksSent() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getNumBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getNumBytesSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getNumMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getNumMsgsSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getNumReceiveFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getNumSendFailed() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getOperationTimeoutMs() - Method in class org.apache.pulsar.client.api.ClientConfiguration
-
Deprecated.
- getPartitionsForTopic(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
Get the list of partitions for a given topic.
- 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.
- 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.
- getProperty(String) - Method in interface org.apache.pulsar.client.api.Message
-
Get the value of a specific property
- getPublicKey(String, Map<String, String>) - Method in interface org.apache.pulsar.client.api.CryptoKeyReader
-
Return the encryption key corresponding to the key name in the argument
- getPublishTime() - Method in interface org.apache.pulsar.client.api.Message
-
Get the publish time of this message.
- getRateBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getRateMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- 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.
- getRedeliveryCount() - Method in interface org.apache.pulsar.client.api.Message
-
Get message redelivery count, redelivery count maintain in pulsar broker.
- getSchema(SchemaInfo) - Static method in interface org.apache.pulsar.client.api.Schema
-
- getSchemaInfo() - Method in interface org.apache.pulsar.client.api.Schema
-
- getSendBytesRate() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis50pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis75pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis95pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis999pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis99pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillisMax() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendMsgsRate() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- 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.
- getServiceUrl() - Method in interface org.apache.pulsar.client.api.ServiceUrlProvider
-
Get the current service URL the Pulsar client should connect to.
- 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
- getStatsIntervalSeconds() - Method in class org.apache.pulsar.client.api.ClientConfiguration
-
Deprecated.
Stats will be activated with positive statsIntervalSeconds
- getSubscription() - Method in interface org.apache.pulsar.client.api.Consumer
-
Get a subscription for the consumer
- 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.
- getTickDurationMillis() - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
-
Deprecated.
- 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
-
- getTlsPrivateKey() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
-
- 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
-
- getTopicName() - Method in interface org.apache.pulsar.client.api.Message
-
Get the topic the message was published to
- getTotalAcksFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getTotalAcksReceived() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getTotalAcksSent() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getTotalBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getTotalBytesSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getTotalMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getTotalMsgsSent() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getTotalReceivedFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getTotalSendFailed() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getValue() - Method in interface org.apache.pulsar.client.api.Message
-
- getValue() - Method in enum org.apache.pulsar.client.api.SubscriptionInitialPosition
-
- Schema<T> - Interface in org.apache.pulsar.client.api
-
Message schema definition
- SchemaSerializationException - Exception in org.apache.pulsar.client.api
-
- SchemaSerializationException(String) - Constructor for exception org.apache.pulsar.client.api.SchemaSerializationException
-
- SchemaSerializationException(Throwable) - Constructor for exception org.apache.pulsar.client.api.SchemaSerializationException
-
- seek(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 interface org.apache.pulsar.client.api.Consumer
-
Reset the subscription associated with this consumer to a specific message id.
- 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
-
- send() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Send a message synchronously.
- sendAsync(T) - Method in interface org.apache.pulsar.client.api.Producer
-
Send a message asynchronously
- sendAsync(Message<T>) - Method in interface org.apache.pulsar.client.api.Producer
-
- sendAsync() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Send a message asynchronously
- sendTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set the send timeout (default: 30 seconds)
- sequenceId(long) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Specify a custom sequence id for the message being published.
- serviceUrl(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Configure the service URL for the Pulsar service.
- serviceUrlProvider(ServiceUrlProvider) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Configure the service URL provider for Pulsar service
- ServiceUrlProvider - Interface in org.apache.pulsar.client.api
-
The provider to provide the service url.
- 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.
- 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.
- setConnectionTimeout(int, TimeUnit) - Method in class org.apache.pulsar.client.api.ClientConfiguration
-
Deprecated.
Set the duration of time to wait for a connection to a broker to be established.
- setConsumerEventListener(ConsumerEventListener) - Method in class org.apache.pulsar.client.api.ConsumerConfiguration
-
Deprecated.
- 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
- 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.
- 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
- 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
- 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.
- 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
- 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.
- 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.
- 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.
- setReplicationClusters(List<String>) - Method in interface org.apache.pulsar.client.api.MessageBuilder
-
Deprecated.
Override the replication clusters for this message.
- 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.
- 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
- shutdown() - Method in interface org.apache.pulsar.client.api.PulsarClient
-
Perform immediate shutdown of PulsarClient.
- start() - Method in interface org.apache.pulsar.client.api.Authentication
-
Initialize the authentication provider
- startMessageId(MessageId) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
The initial reader positioning is done by specifying a message id.
- 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
- STRING - Static variable in interface org.apache.pulsar.client.api.Schema
-
Schema that can be used to encode/decode messages whose values are String.
- subscribe() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Finalize the
Consumer
creation by subscribing to the topic.
- subscribe(String, String) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
- subscribe(String, String, ConsumerConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
- 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
-
- subscribeAsync(String, String, ConsumerConfiguration) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
- 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
- subscriptionName(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Specify the subscription name for this consumer.
- subscriptionRolePrefix(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Set the subscription role prefix.
- subscriptionTopicsMode(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.
- 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
- validate(byte[]) - Method in interface org.apache.pulsar.client.api.Schema
-
Check if the message is a valid object for this schema.
- value(T) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Set a domain object on the message
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.CompressionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.ConsumerCryptoFailureAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.HashingScheme
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.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.