- 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.
- addProperty(String, String) - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
-
Set schema info properties
- aliases(String...) - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
-
The optional name aliases of this field.
- 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
-
Configure the authentication provider to use in the Pulsar client instance.
- authentication(String, Map<String, String>) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Configure the authentication provider to use in the Pulsar client instance
using a config map.
- AuthenticationDataProvider - Interface in org.apache.pulsar.client.api
-
Interface for accessing data which are used in variety of authentication schemes on client side
- AuthenticationException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.AuthenticationException
-
- AuthenticationFactory - Class in org.apache.pulsar.client.api
-
Factory class that allows to create
Authentication
instances
for all the supported authentication methods.
- AuthenticationFactory() - Constructor for class org.apache.pulsar.client.api.AuthenticationFactory
-
- 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
-
Create a schema instance that automatically deserialize messages
based on the current topic schema.
- AUTO_PRODUCE_BYTES() - Static method in interface org.apache.pulsar.client.api.Schema
-
Create a schema instance that accepts a serialized payload
and validates it against the topic schema.
- autoUpdatePartitions(boolean) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
If enabled, the consumer will auto subscribe for partitions increasement.
- autoUpdatePartitions(boolean) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
If enabled, partitioned producer will automatically discover new partitions at runtime.
- AVRO(Class<T>) - Static method in interface org.apache.pulsar.client.api.Schema
-
Create a Avro schema type by default configuration of the class
- AVRO(SchemaDefinition<T>) - Static method in interface org.apache.pulsar.client.api.Schema
-
Create a Avro schema type with schema definition
- 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 configure and construct a
PulsarClient
instance.
- 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
-
The compression type that can be specified on a
Producer
.
- compressionType(CompressionType) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set the compression type for the producer.
- 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.
- 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
-
- ConsumerCryptoFailureAction - Enum in org.apache.pulsar.client.api
-
The action a consumer should take when a consumer receives a
message that it cannot decrypt.
- consumerEventListener(ConsumerEventListener) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
- ConsumerEventListener - Interface in org.apache.pulsar.client.api
-
Listener on the consumer state changes.
- ConsumerInterceptor<T> - Interface in org.apache.pulsar.client.api
-
A plugin interface that allows you to intercept (and possibly mutate)
messages received by the consumer.
- consumerName(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set the consumer name.
- ConsumerStats - Interface in org.apache.pulsar.client.api
-
Consumer statistics recorded by client.
- create(String, String) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
-
Create an instance of the
Authentication
object by using
the plugin class name.
- create(String, Map<String, String>) - Static method in class org.apache.pulsar.client.api.AuthenticationFactory
-
Create an instance of the Authentication-Plugin
- create() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Finalize the creation of the
Producer
instance.
- create() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Finalize the creation of the
Reader
instance.
- createAsync() - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Finalize the creation of the
Producer
instance in asynchronous mode.
- createAsync() - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Finalize the creation of the
Reader
instance in asynchronous mode.
- createAuthentication(String, String) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- createAuthentication(String, Map<String, String>) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- CryptoException(String) - Constructor for exception org.apache.pulsar.client.api.PulsarClientException.CryptoException
-
- cryptoFailureAction(ConsumerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Sets the ConsumerCryptoFailureAction to the value specified
- cryptoFailureAction(ProducerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Sets the ProducerCryptoFailureAction to the value specified
- cryptoFailureAction(ConsumerCryptoFailureAction) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
- CryptoKeyReader - Interface in org.apache.pulsar.client.api
-
Interface that abstracts the access to a key store.
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
- generic(SchemaInfo) - Static method in interface org.apache.pulsar.client.api.Schema
-
Returns a generic schema of existing schema info.
- GenericRecord - Interface in org.apache.pulsar.client.api.schema
-
An interface represents a message with schema.
- GenericSchema - Interface in org.apache.pulsar.client.api.schema
-
A schema that serializes and deserializes between
GenericRecord
and bytes.
- getAlwaysAllowNull() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
-
get schema whether always allow null or not
- getAuthData() - Method in interface org.apache.pulsar.client.api.Authentication
-
- getAuthMethodName() - Method in interface org.apache.pulsar.client.api.Authentication
-
- getCommandData() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
-
- getConsumerName() - Method in interface org.apache.pulsar.client.api.Consumer
-
Get the name of consumer.
- getData() - Method in interface org.apache.pulsar.client.api.Message
-
Get the raw payload of the message.
- getEncryptionCtx() - Method in interface org.apache.pulsar.client.api.Message
-
EncryptionContext
contains encryption and compression information in it using which application can
decrypt consumed message with encrypted-payload.
- getEventTime() - Method in interface org.apache.pulsar.client.api.Message
-
Get the event time associated with this message.
- getField(Field) - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
-
Retrieve the value of the provided field.
- getField(String) - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
-
Retrieve the value of the provided fieldName.
- getFields() - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
-
Returns the list of fields associated with the record.
- getFields() - Method in interface org.apache.pulsar.client.api.schema.GenericSchema
-
Returns the list of fields.
- getGenericSchema(SchemaInfo) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- getHttpAuthType() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
-
- getHttpHeaders() - Method in interface org.apache.pulsar.client.api.AuthenticationDataProvider
-
- getJsonDef() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
-
Get json schema definition
- getKey() - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
-
- getKey() - Method in interface org.apache.pulsar.client.api.Message
-
Get the key of the message
- getKey() - Method in class org.apache.pulsar.common.schema.KeyValue
-
- getKeyBytes() - Method in interface org.apache.pulsar.client.api.Message
-
Get bytes in key.
- getLastSequenceId() - Method in interface org.apache.pulsar.client.api.Producer
-
Get the last sequence id that was published by this producer.
- getMessageId() - Method in interface org.apache.pulsar.client.api.Message
-
Get the unique message ID associated with this message.
- getMetadata() - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
-
- getNumAcksFailed() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getNumAcksReceived() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getNumAcksSent() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- 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
-
- getPartitionsForTopic(String) - Method in interface org.apache.pulsar.client.api.PulsarClient
-
Get the list of partitions for a given topic.
- getPojo() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
-
Get pojo schema definition
- getPrivateKey(String, Map<String, String>) - Method in interface org.apache.pulsar.client.api.CryptoKeyReader
-
- getProducerName() - Method in interface org.apache.pulsar.client.api.Message
-
Get the producer name who produced this message.
- getProducerName() - Method in interface org.apache.pulsar.client.api.Producer
-
- getProperties() - Method in interface org.apache.pulsar.client.api.Message
-
Return the properties attached to the message.
- getProperties() - Method in interface org.apache.pulsar.client.api.schema.SchemaDefinition
-
Get schema class
- getProperty(String) - Method in interface org.apache.pulsar.client.api.Message
-
Get the value of a specific property
- getPublicKey(String, Map<String, String>) - Method in interface org.apache.pulsar.client.api.CryptoKeyReader
-
Return the encryption key corresponding to the key name in the argument
- getPublishTime() - Method in interface org.apache.pulsar.client.api.Message
-
Get the publish time of this message.
- getRateBytesReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getRateMsgsReceived() - Method in interface org.apache.pulsar.client.api.ConsumerStats
-
- getRedeliveryCount() - Method in interface org.apache.pulsar.client.api.Message
-
Get message redelivery count, redelivery count maintain in pulsar broker.
- getSchema(SchemaInfo) - Static method in interface org.apache.pulsar.client.api.Schema
-
- getSchema(SchemaInfo) - Static method in class org.apache.pulsar.client.internal.DefaultImplementation
-
- getSchemaInfo() - Method in interface org.apache.pulsar.client.api.Schema
-
- getSchemaVersion() - Method in interface org.apache.pulsar.client.api.Message
-
Get schema version of the message.
- getSchemaVersion() - Method in interface org.apache.pulsar.client.api.schema.GenericRecord
-
Return schema version.
- getSendBytesRate() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis50pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis75pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis95pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis999pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillis99pct() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendLatencyMillisMax() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSendMsgsRate() - Method in interface org.apache.pulsar.client.api.ProducerStats
-
- getSequenceId() - Method in interface org.apache.pulsar.client.api.Message
-
Get the sequence id associated with this message.
- 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
- getSubscription() - Method in interface org.apache.pulsar.client.api.Consumer
-
Get a subscription for the consumer
- 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
-
- 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
-
Get the de-serialized value of the message, according the configured
Schema
.
- getValue() - Method in enum org.apache.pulsar.client.api.SubscriptionInitialPosition
-
- getValue() - Method in class org.apache.pulsar.common.schema.KeyValue
-
- getValue() - Method in enum org.apache.pulsar.common.schema.SchemaType
-
- 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.
- maxLookupRequests(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Number of max lookup-requests allowed on each broker-connection to prevent overload on broker.
- maxNumberOfRejectedRequestPerConnection(int) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Set max number of broker-rejected requests in a certain time-frame (30 seconds) after which current connection
will be closed and client creates a new connection that give chance to connect a different broker (default:
50)
- maxPendingMessages(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set the max size of the queue holding the messages pending to receive an acknowledgment from the broker.
- maxPendingMessagesAcrossPartitions(int) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set the number of max pending messages across all the partitions
- maxTotalReceiverQueueSizeAcrossPartitions(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Set the max total receiver queue size across partitons.
- Message<T> - Interface in org.apache.pulsar.client.api
-
The message abstraction used in Pulsar.
- MessageId - Interface in org.apache.pulsar.client.api
-
Opaque unique identifier of a single message
- messageListener(MessageListener<T>) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
- MessageListener<T> - Interface in org.apache.pulsar.client.api
-
A listener that will be called in order for every message received.
- MessageRouter - Interface in org.apache.pulsar.client.api
-
Interface for custom message router that can be passed
to a producer to select the partition that a particular
messsage should be published on.
- messageRouter(MessageRouter) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set a custom message routing policy by passing an implementation of MessageRouter.
- MessageRoutingMode - Enum in org.apache.pulsar.client.api
-
Default routing mode for messages to partition.
- messageRoutingMode(MessageRoutingMode) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
- 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.
- Reader<T> - Interface in org.apache.pulsar.client.api
-
A Reader can be used to scan through all the messages currently available in a topic.
- ReaderBuilder<T> - Interface in org.apache.pulsar.client.api
-
- readerListener(ReaderListener<T>) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
- ReaderListener<T> - Interface in org.apache.pulsar.client.api
-
A listener that will be called in order for every message received.
- readerName(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Specify a reader name.
- readNext() - Method in interface org.apache.pulsar.client.api.Reader
-
Read the next message in the topic.
- readNext(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.Reader
-
Read the next message in the topic waiting for a maximum time.
- readNextAsync() - Method in interface org.apache.pulsar.client.api.Reader
-
Read asynchronously the next message in the topic.
- receive() - Method in interface org.apache.pulsar.client.api.Consumer
-
Receives a single message.
- receive(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.Consumer
-
Receive a single message
- receiveAsync() - Method in interface org.apache.pulsar.client.api.Consumer
-
Receive a single message
- received(Consumer<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.MessageListener
-
This method is called whenever a new message is received.
- received(Reader<T>, Message<T>) - Method in interface org.apache.pulsar.client.api.ReaderListener
-
This method is called whenever a new message is received.
- receiverQueueSize(int) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Sets the size of the consumer receive queue.
- receiverQueueSize(int) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Sets the size of the consumer receive queue.
- record(String) - Static method in interface org.apache.pulsar.client.api.schema.SchemaBuilder
-
Build the schema for a record.
- RecordSchemaBuilder - Interface in org.apache.pulsar.client.api.schema
-
- redeliverUnacknowledgedMessages() - Method in interface org.apache.pulsar.client.api.Consumer
-
Redelivers all the unacknowledged messages.
- RegexSubscriptionMode - Enum in org.apache.pulsar.client.api
-
When subscribing to topics using a regular expression, one can specify
to only pick a certain type of topics.
- replicationClusters(List<String>) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Override the geo-replication clusters for this message.
- required() - Method in interface org.apache.pulsar.client.api.schema.FieldSchemaBuilder
-
Make this field required.
- resume() - Method in interface org.apache.pulsar.client.api.Consumer
-
Resume requesting messages from the broker.
- Schema<T> - Interface in org.apache.pulsar.client.api
-
Message schema definition
- SchemaBuilder - Interface in org.apache.pulsar.client.api.schema
-
Builder to build schema.
- SchemaDefinition<T> - Interface in org.apache.pulsar.client.api.schema
-
- SchemaDefinitionBuilder<T> - Interface in org.apache.pulsar.client.api.schema
-
- SchemaInfo - Class in org.apache.pulsar.common.schema
-
- SchemaInfo() - Constructor for class org.apache.pulsar.common.schema.SchemaInfo
-
- 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
-
- SchemaType - Enum in org.apache.pulsar.common.schema
-
Types of supported schema for Pulsar messages
- 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() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Send a message synchronously.
- sendAsync(T) - Method in interface org.apache.pulsar.client.api.Producer
-
Send a message asynchronously
- sendAsync() - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Send a message asynchronously
- sendTimeout(int, TimeUnit) - Method in interface org.apache.pulsar.client.api.ProducerBuilder
-
Set the send timeout (default: 30 seconds)
- sequenceId(long) - Method in interface org.apache.pulsar.client.api.TypedMessageBuilder
-
Specify a custom sequence id for the message being published.
- serviceUrl(String) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Configure the service URL for the Pulsar service.
- serviceUrlProvider(ServiceUrlProvider) - Method in interface org.apache.pulsar.client.api.ClientBuilder
-
Configure the service URL provider for Pulsar service
- ServiceUrlProvider - Interface in org.apache.pulsar.client.api
-
The provider to provide the service url.
- setKey(byte[]) - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
-
- setMetadata(Map<String, String>) - Method in class org.apache.pulsar.client.api.EncryptionKeyInfo
-
- 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.
- subscribeAsync() - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Finalize the
Consumer
creation by subscribing to the topic in asynchronous mode.
- subscriptionInitialPosition(SubscriptionInitialPosition) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
- SubscriptionInitialPosition - Enum in org.apache.pulsar.client.api
-
When creating a consumer, if the subscription does not exist, a new subscription will be created.
- subscriptionName(String) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Specify the subscription name for this consumer.
- subscriptionRolePrefix(String) - Method in interface org.apache.pulsar.client.api.ReaderBuilder
-
Set the subscription role prefix.
- subscriptionTopicsMode(RegexSubscriptionMode) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Determines to which topics this consumer should be subscribed to - Persistent, Non-Persistent, or both.
- subscriptionType(SubscriptionType) - Method in interface org.apache.pulsar.client.api.ConsumerBuilder
-
Select the subscription type to be used when subscribing to the topic.
- SubscriptionType - Enum in org.apache.pulsar.client.api
-
Types of subscription supported by Pulsar
- supportSchemaVersioning() - Method in interface org.apache.pulsar.client.api.Schema
-
Returns whether this schema supports versioning.
- 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.ProducerCryptoFailureAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.RegexSubscriptionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.SubscriptionInitialPosition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.client.api.SubscriptionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.pulsar.common.schema.SchemaType
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.apache.pulsar.common.schema.SchemaType
-
- values() - Static method in enum org.apache.pulsar.client.api.CompressionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.ConsumerCryptoFailureAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.HashingScheme
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.MessageRoutingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.ProducerCryptoFailureAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.RegexSubscriptionMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.SubscriptionInitialPosition
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.client.api.SubscriptionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.pulsar.common.schema.SchemaType
-
Returns an array containing the constants of this enum type, in
the order they are declared.