跳过导航链接
A B C D E F G H I J K L M N O P R S T U V W 

A

abort() - 接口 中的方法org.apache.pulsar.client.api.transaction.Transaction
Abort the transaction.
abort(TxnID, List<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Abort txn.
abortAsync(TxnID, List<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Abort txn asynchronously.
abortTxnOnSubscription(String, String, long, long) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionBufferClient
Abort the transaction associated with the topic subscription.
abortTxnOnTopic(String, long, long, List<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionBufferClient
Abort the transaction associated with the topic.
acknowledge(Message<?>) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Acknowledge the consumption of a single message.
acknowledge(MessageId) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Acknowledge the consumption of a single message, identified by its MessageId.
acknowledge(Messages<?>) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Acknowledge the consumption of Messages.
acknowledge(List<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Acknowledge the consumption of a list of message.
acknowledgeAsync(Message<?>) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously acknowledge the consumption of a single message.
acknowledgeAsync(MessageId) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously acknowledge the consumption of a single message.
acknowledgeAsync(MessageId, Transaction) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously acknowledge the consumption of a single message, it will store in pending ack.
acknowledgeAsync(Messages<?>) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously acknowledge the consumption of Messages.
acknowledgeAsync(List<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously acknowledge the consumption of a list of message.
acknowledgeCumulative(Message<?>) - 接口 中的方法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) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.
acknowledgeCumulativeAsync(MessageId, Transaction) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Acknowledge the reception of all the messages in the stream up to (and including) the provided message with this transaction, it will store in transaction pending ack.
acknowledgeCumulativeAsync(Message<?>) - 接口 中的方法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) - 接口 中的方法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) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Group the consumer acknowledgments for the specified time.
ackTimeout(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set the timeout for unacked messages, truncated to the nearest millisecond.
ackTimeoutTickTime(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Define the granularity of the ack-timeout redelivery.
addEncryptionKey(String) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Add public encryption key, used by producer to encrypt the data key.
addProperty(String, String) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema info properties.
addPublicKeyCipher(Set<String>, CryptoKeyReader) - 接口 中的方法org.apache.pulsar.client.api.MessageCrypto
 
addPublishPartitionToTxn(TxnID, List<String>) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Add publish partition to txn.
addPublishPartitionToTxnAsync(TxnID, List<String>) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Add publish partition to txn asynchronously.
addSubscriptionToTxn(TxnID, String, String) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Add ack subscription to txn.
addSubscriptionToTxnAsync(TxnID, String, String) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Add ack subscription to txn asynchronously.
aliases(String...) - 接口 中的方法org.apache.pulsar.client.api.schema.FieldSchemaBuilder
The optional name aliases of this field.
allowOutOfOrderDelivery - 类 中的变量org.apache.pulsar.client.api.KeySharedPolicy
 
allowTlsInsecureConnection(boolean) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Configure whether the Pulsar client accept untrusted TLS certificate from broker (default: false).
AlreadyClosedException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.AlreadyClosedException
Constructs an AlreadyClosedException with the specified detail message.
AlreadyClosedException(String, long) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.AlreadyClosedException
Constructs an AlreadyClosedException with the specified detail message.
AuthData - org.apache.pulsar.common.api中的类
Authentication data.
AuthData() - 类 的构造器org.apache.pulsar.common.api.AuthData
 
authenticate(AuthData) - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
For mutual authentication, This method use passed in `data` to evaluate and challenge, then returns null if authentication has completed; returns authenticated data back to server side, if authentication has not completed.
Authentication - org.apache.pulsar.client.api中的接口
Interface of authentication providers.
authentication(Authentication) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the authentication provider to use in the Pulsar client instance.
authentication(String, String) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Configure the authentication provider to use in the Pulsar client instance.
authentication(String, Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Configure the authentication provider to use in the Pulsar client instance using a config map.
AuthenticationDataProvider - org.apache.pulsar.client.api中的接口
Interface for accessing data which are used in variety of authentication schemes on client side.
AuthenticationException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.AuthenticationException
Constructs an AuthenticationException with the specified detail message.
AuthenticationFactory - org.apache.pulsar.client.api中的类
Factory class that allows to create Authentication instances for all the supported authentication methods.
AuthenticationFactory() - 类 的构造器org.apache.pulsar.client.api.AuthenticationFactory
 
authenticationStage(String, AuthenticationDataProvider, Map<String, String>, CompletableFuture<Map<String, String>>) - 接口 中的方法org.apache.pulsar.client.api.Authentication
An authentication Stage.
AuthorizationException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.AuthorizationException
Constructs an AuthorizationException with the specified detail message.
AUTO() - 接口 中的静态方法org.apache.pulsar.client.api.Schema
已过时。
AUTO_CONSUME() - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a schema instance that automatically deserialize messages based on the current topic schema.
AUTO_PRODUCE_BYTES() - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a schema instance that accepts a serialized payload and validates it against the topic schema.
AUTO_PRODUCE_BYTES(Schema<?>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a schema instance that accepts a serialized payload and validates it against the schema specified.
autoAckOldestChunkedMessageOnQueueFull(boolean) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Buffering large number of outstanding uncompleted chunked messages can create memory pressure and it can be guarded by providing this @maxPendingChuckedMessage threshold.
autoSplitHashRange() - 类 中的静态方法org.apache.pulsar.client.api.KeySharedPolicy
 
autoUpdatePartitions(boolean) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
If enabled, the consumer will auto subscribe for partitions increasement.
autoUpdatePartitions(boolean) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
If enabled, partitioned producer will automatically discover new partitions at runtime.
autoUpdatePartitionsInterval(int, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set the interval of updating partitions (default: 1 minute).
autoUpdatePartitionsInterval(int, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the interval of updating partitions (default: 1 minute).
AVRO(Class<T>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a Avro schema type by default configuration of the class.
AVRO(SchemaDefinition<T>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a Avro schema type with schema definition.

B

BatcherBuilder - org.apache.pulsar.client.api中的接口
Batcher builder.
batcherBuilder(BatcherBuilder) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the batcher builder BatcherBuilder of the producer.
batchingMaxBytes(int) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the maximum number of bytes permitted in a batch.
batchingMaxMessages(int) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the maximum number of messages permitted in a batch.
batchingMaxPublishDelay(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the time period within which the messages sent will be batched default: 1 ms if batch messages are enabled.
BatchMessageContainer - org.apache.pulsar.client.api中的接口
Batch message container for individual messages being published until they are batched and sent to broker.
batchReceive() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Batch receiving messages.
batchReceiveAsync() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Batch receiving messages.
BatchReceivePolicy - org.apache.pulsar.client.api中的类
Configuration for message batch receive Consumer.batchReceive() Consumer.batchReceiveAsync().
batchReceivePolicy(BatchReceivePolicy) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set batch receive policy BatchReceivePolicy for consumer.
BatchReceivePolicy.Builder - org.apache.pulsar.client.api中的类
Builder of BatchReceivePolicy.
becameActive(Consumer<?>, int) - 接口 中的方法org.apache.pulsar.client.api.ConsumerEventListener
Notified when the consumer group is changed, and the consumer becomes the active consumer.
becameInactive(Consumer<?>, int) - 接口 中的方法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>) - 接口 中的方法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.
beforeSend(Producer, Message) - 接口 中的方法org.apache.pulsar.client.api.interceptor.ProducerInterceptor
This is called from Producer.send(Object) and Producer.sendAsync(Object) methods, before send the message to the brokers.
beforeSend(Producer, Message) - 类 中的方法org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
 
beforeSend(Producer<T>, Message<T>) - 接口 中的方法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.
blockIfQueueFull(boolean) - 接口 中的方法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.
BOOL - 接口 中的静态变量org.apache.pulsar.client.api.Schema
Boolean Schema.
BrokerMetadataException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.BrokerMetadataException
Constructs an BrokerMetadataException with the specified detail message.
BrokerPersistenceException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.BrokerPersistenceException
Constructs an BrokerPersistenceException with the specified detail message.
build() - 接口 中的方法org.apache.pulsar.client.api.BatcherBuilder
Build a new batch message container.
build() - 类 中的方法org.apache.pulsar.client.api.BatchReceivePolicy.Builder
 
build() - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Construct the final PulsarClient instance.
build() - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecordBuilder
Build a generic record.
build(SchemaType) - 接口 中的方法org.apache.pulsar.client.api.schema.RecordSchemaBuilder
Build the schema info.
build() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Build the schema definition.
build() - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionBuilder
Build the transaction with the configured settings.
builder() - 类 中的静态方法org.apache.pulsar.client.api.BatchReceivePolicy
 
Builder() - 类 的构造器org.apache.pulsar.client.api.BatchReceivePolicy.Builder
 
builder() - 接口 中的静态方法org.apache.pulsar.client.api.PulsarClient
Get a new builder instance that can used to configure and build a PulsarClient instance.
builder() - 接口 中的静态方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get a new builder instance that can used to configure and build a SchemaDefinition instance.
BYTEBUFFER - 接口 中的静态变量org.apache.pulsar.client.api.Schema
ByteBuffer Schema.
BYTES - 接口 中的静态变量org.apache.pulsar.client.api.Schema
Schema that doesn't perform any encoding on the message payloads.

C

ChecksumException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ChecksumException
Constructs an ChecksumException with the specified detail message.
choosePartition(Message<?>) - 接口 中的方法org.apache.pulsar.client.api.MessageRouter
已过时。
choosePartition(Message<?>, TopicMetadata) - 接口 中的方法org.apache.pulsar.client.api.MessageRouter
Choose a partition based on msg and the topic metadata.
clear() - 接口 中的方法org.apache.pulsar.client.api.BatchMessageContainer
Clear the message batch container.
clear(String) - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecordBuilder
Clears the value of the given field.
clear(Field) - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecordBuilder
Clears the value of the given field.
ClientBuilder - org.apache.pulsar.client.api中的接口
Builder interface that is used to configure and construct a PulsarClient instance.
clock(Clock) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
The clock used by the pulsar client.
clone() - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Create a copy of the current client builder.
clone() - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Create a copy of the current consumer builder.
clone() - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Create a copy of the current ProducerBuilder.
clone() - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Create a copy of the current ReaderBuilder.
clone() - 接口 中的方法org.apache.pulsar.client.api.Schema
Duplicates the schema.
close() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Close the consumer and stop the broker to push more messages.
close() - 接口 中的方法org.apache.pulsar.client.api.ConsumerInterceptor
Close the interceptor.
close() - 接口 中的方法org.apache.pulsar.client.api.interceptor.ProducerInterceptor
Close the interceptor.
close() - 类 中的方法org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
 
close() - 接口 中的方法org.apache.pulsar.client.api.Producer
Close the producer and releases resources allocated.
close() - 接口 中的方法org.apache.pulsar.client.api.ProducerInterceptor
已过时。
Close the interceptor.
close() - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Close the PulsarClient and release all the resources.
close() - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionBufferClient
 
closeAsync() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously close the consumer and stop the broker to push more messages.
closeAsync() - 接口 中的方法org.apache.pulsar.client.api.Producer
Close the producer and releases resources allocated.
closeAsync() - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Asynchronously close the PulsarClient and release all the resources.
closeAsync() - 接口 中的方法org.apache.pulsar.client.api.Reader
Asynchronously close the reader and stop the broker to push more messages.
closeAsync() - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Close the transaction meta store client asynchronous.
commit() - 接口 中的方法org.apache.pulsar.client.api.transaction.Transaction
Commit the transaction.
commit(TxnID, List<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Commit txn.
commitAsync(TxnID, List<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Commit txn asynchronously.
commitTxnOnSubscription(String, String, long, long) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionBufferClient
Commit the transaction associated with the topic subscription.
commitTxnOnTopic(String, long, long, List<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionBufferClient
Commit the transaction associated with the topic.
CompressionType - org.apache.pulsar.client.api中的枚举
The compression type that can be specified on a Producer.
compressionType(CompressionType) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the compression type for the producer.
CONF_DELIVERY_AFTER_SECONDS - 接口 中的静态变量org.apache.pulsar.client.api.TypedMessageBuilder
 
CONF_DELIVERY_AT - 接口 中的静态变量org.apache.pulsar.client.api.TypedMessageBuilder
 
CONF_DISABLE_REPLICATION - 接口 中的静态变量org.apache.pulsar.client.api.TypedMessageBuilder
 
CONF_EVENT_TIME - 接口 中的静态变量org.apache.pulsar.client.api.TypedMessageBuilder
 
CONF_KEY - 接口 中的静态变量org.apache.pulsar.client.api.TypedMessageBuilder
 
CONF_PROPERTIES - 接口 中的静态变量org.apache.pulsar.client.api.TypedMessageBuilder
 
CONF_REPLICATION_CLUSTERS - 接口 中的静态变量org.apache.pulsar.client.api.TypedMessageBuilder
 
CONF_SEQUENCE_ID - 接口 中的静态变量org.apache.pulsar.client.api.TypedMessageBuilder
 
configure(Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.Authentication
已过时。
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) - 接口 中的方法org.apache.pulsar.client.api.EncodedAuthenticationParameterSupport
Plugins which use ":" and/or "," in a configuration parameter value need to implement this interface.
configureSchemaInfo(String, String, SchemaInfo) - 接口 中的方法org.apache.pulsar.client.api.Schema
Configure the schema to use the provided schema info.
ConnectException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ConnectException
Constructs an ConnectException with the specified cause.
ConnectException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ConnectException
Constructs an ConnectException with the specified detail message.
connectionsPerBroker(int) - 接口 中的方法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) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the duration of time to wait for a connection to a broker to be established.
Consumer<T> - org.apache.pulsar.client.api中的接口
An interface that abstracts behavior of Pulsar's consumer.
ConsumerAssignException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ConsumerAssignException
Constructs an ConsumerAssignException with the specified detail message.
ConsumerBuilder<T> - org.apache.pulsar.client.api中的接口
ConsumerBuilder is used to configure and create instances of Consumer.
ConsumerBusyException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ConsumerBusyException
Constructs an ConsumerBusyException with the specified detail message.
ConsumerCryptoFailureAction - org.apache.pulsar.client.api中的枚举
The action a consumer should take when a consumer receives a message that it cannot decrypt.
consumerEventListener(ConsumerEventListener) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Sets a ConsumerEventListener for the consumer.
ConsumerEventListener - org.apache.pulsar.client.api中的接口
Listener on the consumer state changes.
ConsumerInterceptor<T> - org.apache.pulsar.client.api中的接口
A plugin interface that allows you to intercept (and possibly mutate) messages received by the consumer.
consumerName(String) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set the consumer name.
ConsumerStats - org.apache.pulsar.client.api中的接口
Consumer statistics recorded by client.
convertKeyValueDataStringToSchemaInfoSchema(byte[]) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
Convert the key/value schema info data json bytes to key/value schema info data bytes.
convertKeyValueSchemaInfoDataToString(KeyValue<SchemaInfo, SchemaInfo>) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
Convert the key/value schema data.
CoordinatorClientStateException() - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.CoordinatorClientStateException
 
CoordinatorClientStateException(String) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.CoordinatorClientStateException
 
CoordinatorNotFoundException(String) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.CoordinatorNotFoundException
 
create(String, String) - 类 中的静态方法org.apache.pulsar.client.api.AuthenticationFactory
Create an instance of the Authentication object by using the plugin class name.
create(String, Map<String, String>) - 类 中的静态方法org.apache.pulsar.client.api.AuthenticationFactory
Create an instance of the Authentication-Plugin.
create() - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Finalize the creation of the Producer instance.
create() - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Finalize the creation of the Reader instance.
createAsync() - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Finalize the creation of the Producer instance in asynchronous mode.
createAsync() - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Finalize the creation of the Reader instance in asynchronous mode.
createAuthentication(String, String) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
createAuthentication(String, Map<String, String>) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
CryptoException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.CryptoException
Constructs an CryptoException with the specified detail message.
cryptoFailureAction(ConsumerCryptoFailureAction) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Sets the ConsumerCryptoFailureAction to the value specified.
cryptoFailureAction(ProducerCryptoFailureAction) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Sets the ProducerCryptoFailureAction to the value specified.
cryptoFailureAction(ConsumerCryptoFailureAction) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Sets the ConsumerCryptoFailureAction to specify.
cryptoKeyReader(CryptoKeyReader) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
CryptoKeyReader - org.apache.pulsar.client.api中的接口
Interface that abstracts the access to a key store.
cryptoKeyReader(CryptoKeyReader) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
cryptoKeyReader(CryptoKeyReader) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Sets a CryptoKeyReader to decrypt the message payloads.

D

DATE - 接口 中的静态变量org.apache.pulsar.client.api.Schema
Date Schema.
deadLetterPolicy(DeadLetterPolicy) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set dead letter policy for consumer.
DeadLetterPolicy - org.apache.pulsar.client.api中的类
Configuration for the "dead letter queue" feature in consumer.
DeadLetterPolicy() - 类 的构造器org.apache.pulsar.client.api.DeadLetterPolicy
 
decode(byte[]) - 接口 中的方法org.apache.pulsar.client.api.Schema
Decode a byte array into an object using the schema definition and deserializer implementation.
decode(byte[], byte[]) - 接口 中的方法org.apache.pulsar.client.api.Schema
Decode a byte array into an object using a given version.
decode(byte[], KeyValue.KeyValueDecoder<K, V>) - 类 中的静态方法org.apache.pulsar.common.schema.KeyValue
Decode the value into a key/value pair.
decode(byte[], byte[]) - 接口 中的方法org.apache.pulsar.common.schema.KeyValue.KeyValueDecoder
Decode key and value bytes into a KeyValue pair.
decodeKeyValueEncodingType(SchemaInfo) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
Decode the kv encoding type from the schema info.
decodeKeyValueSchemaInfo(SchemaInfo) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
Decode the key/value schema info to get key schema info and value schema info.
decrypt(Supplier<MetadataT>, ByteBuf, CryptoKeyReader) - 接口 中的方法org.apache.pulsar.client.api.MessageCrypto
 
DEFAULT - 接口 中的静态变量org.apache.pulsar.client.api.BatcherBuilder
Default batch message container.
DEFAULT_HASH_RANGE_SIZE - 类 中的静态变量org.apache.pulsar.client.api.KeySharedPolicy
 
DEFAULT_POLICY - 类 中的静态变量org.apache.pulsar.client.api.BatchReceivePolicy
Default batch receive policy.
DEFAULT_TXN_TTL_MS - 接口 中的静态变量org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Default transaction ttl in mills.
defaultCryptoKeyReader(String) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Sets the default implementation of CryptoKeyReader.
defaultCryptoKeyReader(Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Sets the default implementation of CryptoKeyReader.
defaultCryptoKeyReader(String) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Sets the default implementation of CryptoKeyReader.
defaultCryptoKeyReader(Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Sets the default implementation of CryptoKeyReader.
defaultCryptoKeyReader(String) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Sets the default implementation of CryptoKeyReader.
defaultCryptoKeyReader(Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Sets the default implementation of CryptoKeyReader.
DefaultImplementation - org.apache.pulsar.client.internal中的类
Helper class for class instantiations and it also contains methods to work with schemas.
DefaultImplementation() - 类 的构造器org.apache.pulsar.client.internal.DefaultImplementation
 
defaultValue(Object) - 接口 中的方法org.apache.pulsar.client.api.schema.FieldSchemaBuilder
Set the default value of this field.
deliverAfter(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Request to deliver the message only after the specified relative delay.
deliverAt(long) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Deliver the message only at or after the specified absolute timestamp.
disableReplication() - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Disable geo-replication for this message.
discard(Exception) - 接口 中的方法org.apache.pulsar.client.api.BatchMessageContainer
Release the payload and clear the container.
doc(String) - 接口 中的方法org.apache.pulsar.client.api.schema.FieldSchemaBuilder
The documentation of this field.
doc(String) - 接口 中的方法org.apache.pulsar.client.api.schema.RecordSchemaBuilder
Add doc to the record schema.
DOUBLE - 接口 中的静态变量org.apache.pulsar.client.api.Schema
Double Schema.

E

earliest - 接口 中的静态变量org.apache.pulsar.client.api.MessageId
MessageId that represents the oldest message available in the topic.
eligible(Message) - 接口 中的方法org.apache.pulsar.client.api.interceptor.ProducerInterceptor
Check whether the interceptor is eligible for this message.
eligible(Message) - 类 中的方法org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
 
enableBatchIndexAcknowledgment(boolean) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Enable or disable the batch index acknowledgment.
enableBatching(boolean) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Control whether automatic batching of messages is enabled for the producer.
enableChunking(boolean) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
If message size is higher than allowed max publish-payload size by broker then enableChunking helps producer to split message into multiple chunks and publish them to broker separately and in order.
enableMultiSchema(boolean) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Control whether enable the multiple schema mode for producer.
enableRetry(boolean) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
If enabled, the consumer will auto retry message.
enableTcpNoDelay(boolean) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Configure whether to use TCP no-delay flag on the connection, to disable Nagle algorithm.
enableTls(boolean) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
已过时。
use "pulsar+ssl://" in serviceUrl to enable
enableTlsHostnameVerification(boolean) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
It allows to validate hostname verification when client connects to broker over tls.
enableTransaction(boolean) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
If enable transaction, start the transactionCoordinatorClient with pulsar client.
encode(T) - 接口 中的方法org.apache.pulsar.client.api.Schema
Encode an object representing the message content into a byte array.
encode(K, Schema<K>, V, Schema<V>) - 类 中的静态方法org.apache.pulsar.common.schema.KeyValue
Encode a key and value pair into a bytes array.
EncodedAuthenticationParameterSupport - org.apache.pulsar.client.api中的接口
Support for encoded authentication configuration parameters.
encodeKeyValueSchemaInfo(Schema<K>, Schema<V>, KeyValueEncodingType) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
Encode key & value into schema into a KeyValue schema.
encodeKeyValueSchemaInfo(String, Schema<K>, Schema<V>, KeyValueEncodingType) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
Encode key & value into schema into a KeyValue schema.
encrypt(Set<String>, CryptoKeyReader, Supplier<BuilderT>, ByteBuf) - 接口 中的方法org.apache.pulsar.client.api.MessageCrypto
 
EncryptionContext - org.apache.pulsar.common.api中的类
Class representing an encryption context.
EncryptionContext() - 类 的构造器org.apache.pulsar.common.api.EncryptionContext
 
EncryptionContext.EncryptionKey - org.apache.pulsar.common.api中的类
Encryption key with metadata.
EncryptionKey() - 类 的构造器org.apache.pulsar.common.api.EncryptionContext.EncryptionKey
 
EncryptionKeyInfo - org.apache.pulsar.client.api中的类
EncryptionKeyInfo contains the encryption key and corresponding metadata which contains additional information about the key such as version, timestamp.
EncryptionKeyInfo() - 类 的构造器org.apache.pulsar.client.api.EncryptionKeyInfo
 
EncryptionKeyInfo(byte[], Map<String, String>) - 类 的构造器org.apache.pulsar.client.api.EncryptionKeyInfo
 
equals(Object) - 类 中的方法org.apache.pulsar.client.api.transaction.TxnID
 
equals(Object) - 类 中的方法org.apache.pulsar.common.schema.KeyValue
 
eventTime(long) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Set the event time for a given message.
expireTimeOfIncompleteChunkedMessage(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
If producer fails to publish all the chunks of a message then consumer can expire incomplete chunks if consumer won't be able to receive all chunks in expire times (default 1 hour).

F

Field - org.apache.pulsar.client.api.schema中的类
A field in a record, consisting of a field name, index, and Schema for the field value.
Field() - 类 的构造器org.apache.pulsar.client.api.schema.Field
 
field(String) - 接口 中的方法org.apache.pulsar.client.api.schema.RecordSchemaBuilder
Add a field with the given name to the record.
field(String, GenericSchema) - 接口 中的方法org.apache.pulsar.client.api.schema.RecordSchemaBuilder
Add a field with the given name and genericSchema to the record.
FieldSchemaBuilder<T extends FieldSchemaBuilder<T>> - org.apache.pulsar.client.api.schema中的接口
Build a field for a record.
FLOAT - 接口 中的静态变量org.apache.pulsar.client.api.Schema
Float Schema.
flush() - 接口 中的方法org.apache.pulsar.client.api.Producer
Flush all the messages buffered in the client and wait until all messages have been successfully persisted.
flushAsync() - 接口 中的方法org.apache.pulsar.client.api.Producer
Flush all the messages buffered in the client and wait until all messages have been successfully persisted.
fromByteArray(byte[]) - 接口 中的静态方法org.apache.pulsar.client.api.MessageId
De-serialize a message id from a byte array.
fromByteArrayWithTopic(byte[], String) - 接口 中的静态方法org.apache.pulsar.client.api.MessageId
De-serialize a message id from a byte array with its topic information attached.

G

generic(SchemaInfo) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Returns a generic schema of existing schema info.
GenericRecord - org.apache.pulsar.client.api.schema中的接口
An interface represents a message with schema.
GenericRecordBuilder - org.apache.pulsar.client.api.schema中的接口
Generic Record Builder to build a GenericRecord.
GenericSchema<T extends GenericRecord> - org.apache.pulsar.client.api.schema中的接口
A schema that serializes and deserializes between GenericRecord and bytes.
getAlwaysAllowNull() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get schema whether always allow null or not.
getAuthData() - 接口 中的方法org.apache.pulsar.client.api.Authentication
 
getAuthData(String) - 接口 中的方法org.apache.pulsar.client.api.Authentication
Get/Create an authentication data provider which provides the data that this client will be sent to the broker.
getAuthMethodName() - 接口 中的方法org.apache.pulsar.client.api.Authentication
 
getCommandData() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
 
getConsumerName() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Get the name of consumer.
getCurrentBatchSize() - 接口 中的方法org.apache.pulsar.client.api.BatchMessageContainer
Get current message batch size of the message batch container in bytes.
getData() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the raw payload of the message.
getEncryptionCtx() - 接口 中的方法org.apache.pulsar.client.api.Message
EncryptionContext contains encryption and compression information in it using which application can decrypt consumed message with encrypted-payload.
getEnd() - 类 中的方法org.apache.pulsar.client.api.Range
 
getEventTime() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the event time associated with this message.
getField(Field) - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecord
Retrieve the value of the provided field.
getField(String) - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecord
Retrieve the value of the provided fieldName.
getFields() - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecord
Returns the list of fields associated with the record.
getFields() - 接口 中的方法org.apache.pulsar.client.api.schema.GenericSchema
Returns the list of fields.
getGenericSchema(SchemaInfo) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
getHashRangeTotal() - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy
 
getHttpAuthType() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
 
getHttpHeaders() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
 
getJsonDef() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get json schema definition.
getKey() - 类 中的方法org.apache.pulsar.client.api.EncryptionKeyInfo
 
getKey() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the key of the message.
getKey() - 类 中的方法org.apache.pulsar.common.schema.KeyValue
 
getKeyBytes() - 接口 中的方法org.apache.pulsar.client.api.Message
Get bytes in key.
getKeySharedMode() - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy
 
getLastDisconnectedTimestamp() - 接口 中的方法org.apache.pulsar.client.api.Consumer
 
getLastDisconnectedTimestamp() - 接口 中的方法org.apache.pulsar.client.api.Producer
 
getLastMessageId() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Get the last message id available available for consume.
getLastMessageIdAsync() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Get the last message id available available for consume.
getLastSequenceId() - 接口 中的方法org.apache.pulsar.client.api.Producer
Get the last sequence id that was published by this producer.
getLatestSchema() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaInfoProvider
Retrieve the latest schema info.
getMaxNumBytes() - 类 中的方法org.apache.pulsar.client.api.BatchReceivePolicy
 
getMaxNumMessages() - 类 中的方法org.apache.pulsar.client.api.BatchReceivePolicy
 
getMessageId() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the unique message ID associated with this message.
getMetadata() - 类 中的方法org.apache.pulsar.client.api.EncryptionKeyInfo
 
getMsgNumInReceiverQueue() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
Get the size of receiver queue.
getMsgNumInSubReceiverQueue() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
Get the receiver queue size of sub-consumers.
getNumAcksFailed() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getNumAcksReceived() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getNumAcksSent() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getNumBatchReceiveFailed() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getNumBytesReceived() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getNumBytesSent() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getNumMessagesInBatch() - 接口 中的方法org.apache.pulsar.client.api.BatchMessageContainer
Get count of messages in the message batch container.
getNumMsgsReceived() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getNumMsgsSent() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getNumReceiveFailed() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getNumSendFailed() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getOrderingKey() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the ordering key of the message.
getPartitionsForTopic(String) - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Get the list of partitions for a given topic.
getPojo() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get pojo schema definition.
getPrivateKey(String, Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.CryptoKeyReader
 
getProducerName() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the producer name who produced this message.
getProducerName() - 接口 中的方法org.apache.pulsar.client.api.Producer
 
getProperties() - 接口 中的方法org.apache.pulsar.client.api.Message
Return the properties attached to the message.
getProperties() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get schema class.
getProperty(String) - 接口 中的方法org.apache.pulsar.client.api.Message
Get the value of a specific property.
getPublicKey(String, Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.CryptoKeyReader
Return the encryption key corresponding to the key name in the argument.
getPublishTime() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the publish time of this message.
getRanges() - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
 
getRateBytesReceived() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getRateMsgsReceived() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getRedeliveryCount() - 接口 中的方法org.apache.pulsar.client.api.Message
Get message redelivery count, redelivery count maintain in pulsar broker.
getReplicatedFrom() - 接口 中的方法org.apache.pulsar.client.api.Message
Get name of cluster, from which the message is replicated.
getSchema(SchemaInfo) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
 
getSchema(SchemaInfo) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
getSchemaByVersion(byte[]) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaInfoProvider
Retrieve the schema info of a given schemaVersion.
getSchemaDefinition() - 类 中的方法org.apache.pulsar.common.schema.SchemaInfo
 
getSchemaInfo() - 接口 中的方法org.apache.pulsar.client.api.Schema
 
getSchemaReaderOpt() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get a configured schema reader.
getSchemaVersion() - 接口 中的方法org.apache.pulsar.client.api.Message
Get schema version of the message.
getSchemaVersion() - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecord
Return schema version.
getSchemaWriterOpt() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get a configured schema writer.
getSendBytesRate() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis50pct() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis75pct() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis95pct() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis999pct() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillis99pct() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getSendLatencyMillisMax() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getSendMsgsRate() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getSequenceId() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the sequence id associated with this message.
getSequenceId() - 异常错误 中的方法org.apache.pulsar.client.api.PulsarClientException
 
getServiceUrl() - 接口 中的方法org.apache.pulsar.client.api.ServiceUrlProvider
Get the current service URL the Pulsar client should connect to.
getStart() - 类 中的方法org.apache.pulsar.client.api.Range
 
getState() - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Get current state of the transaction meta store.
getStats() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Get statistics for the consumer.
getStats() - 接口 中的方法org.apache.pulsar.client.api.Producer
Get statistics for the producer.
getSubscription() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Get a subscription for the consumer.
getSupportSchemaVersioning() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get supportSchemaVersioning schema definition.
getTimeoutMs() - 类 中的方法org.apache.pulsar.client.api.BatchReceivePolicy
 
GettingAuthenticationDataException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
Constructs an GettingAuthenticationDataException with the specified cause.
GettingAuthenticationDataException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
Constructs an GettingAuthenticationDataException with the specified detail message.
getTlsCertificates() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
 
getTlsKeyStoreParams() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
Used for TLS authentication with keystore type.
getTlsPrivateKey() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
 
getTlsTrustStoreStream() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
 
getTopic() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Get a topic for the consumer.
getTopic() - 接口 中的方法org.apache.pulsar.client.api.Producer
 
getTopic() - 接口 中的方法org.apache.pulsar.client.api.Reader
 
getTopicName() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the topic the message was published to.
getTopicName() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaInfoProvider
Retrieve the topic name.
getTotaBatchReceivedFailed() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getTotalAcksFailed() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getTotalAcksReceived() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getTotalAcksSent() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getTotalBytesReceived() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getTotalBytesSent() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getTotalMsgsReceived() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getTotalMsgsSent() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getTotalReceivedFailed() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getTotalSendFailed() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getValue() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the de-serialized value of the message, according the configured Schema.
getValue() - 枚举 中的方法org.apache.pulsar.client.api.SubscriptionInitialPosition
 
getValue() - 类 中的方法org.apache.pulsar.common.schema.KeyValue
 
getValue() - 枚举 中的方法org.apache.pulsar.common.schema.SchemaType
 

H

hasBase64EncodedKey() - 接口 中的方法org.apache.pulsar.client.api.Message
Check whether the key has been base64 encoded.
hasDataForHttp() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
Check if data for HTTP are available.
hasDataForTls() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
Check if data for TLS are available.
hasDataFromCommand() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
Check if data from Pulsar protocol are available.
hashCode() - 类 中的方法org.apache.pulsar.client.api.transaction.TxnID
 
hashCode() - 类 中的方法org.apache.pulsar.common.schema.KeyValue
 
HashingScheme - org.apache.pulsar.client.api中的枚举
Standard hashing functions available when choosing the partition to use for a particular message.
hashingScheme(HashingScheme) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Change the HashingScheme used to chose the partition on where to publish a particular message.
hasKey() - 接口 中的方法org.apache.pulsar.client.api.Message
Check whether the message has a key.
hasMessageAvailable() - 接口 中的方法org.apache.pulsar.client.api.Reader
Check if there is any message available to read from the current position.
hasMessageAvailableAsync() - 接口 中的方法org.apache.pulsar.client.api.Reader
Asynchronously check if there is any message available to read from the current position.
hasOrderingKey() - 接口 中的方法org.apache.pulsar.client.api.Message
Check whether the message has a ordering key.
hasProperty(String) - 接口 中的方法org.apache.pulsar.client.api.Message
Check whether the message has a specific property attached.
hasReachedEndOfTopic() - 接口 中的方法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() - 接口 中的方法org.apache.pulsar.client.api.Reader
Return true if the topic was terminated and this reader has reached the end of the topic.

I

IncompatibleSchemaException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.IncompatibleSchemaException
Constructs an IncompatibleSchemaException with the specified cause.
IncompatibleSchemaException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.IncompatibleSchemaException
Constructs an IncompatibleSchemaException with the specified detail message.
INIT_AUTH_DATA - 类 中的静态变量org.apache.pulsar.common.api.AuthData
 
INIT_AUTH_DATA_BYTES - 类 中的静态变量org.apache.pulsar.common.api.AuthData
 
initialize(PulsarClient) - 接口 中的方法org.apache.pulsar.client.api.ServiceUrlProvider
Initialize the service url provider with Pulsar client instance.
initialSequenceId(long) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the baseline for the sequence ids for messages published by the producer.
INSTANT - 接口 中的静态变量org.apache.pulsar.client.api.Schema
Instant Schema.
INT16 - 接口 中的静态变量org.apache.pulsar.client.api.Schema
INT16 Schema.
INT32 - 接口 中的静态变量org.apache.pulsar.client.api.Schema
INT32 Schema.
INT64 - 接口 中的静态变量org.apache.pulsar.client.api.Schema
INT64 Schema.
INT8 - 接口 中的静态变量org.apache.pulsar.client.api.Schema
INT8 Schema.
intercept(ConsumerInterceptor<T>...) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Intercept Consumer.
intercept(ProducerInterceptor<T>...) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
已过时。
intercept(ProducerInterceptor...) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Add a set of ProducerInterceptor to the producer.
InterfaceAudience - org.apache.pulsar.common.classification中的类
Annotation to inform users of a package, class or method's intended audience.
InterfaceAudience.LimitedPrivate - org.apache.pulsar.common.classification中的注释类型
Intended for use only within the project(s) specified in the annotation.
InterfaceAudience.Private - org.apache.pulsar.common.classification中的注释类型
Intended for use only within the project itself.
InterfaceAudience.Public - org.apache.pulsar.common.classification中的注释类型
Intended for use by any project or application.
InterfaceStability - org.apache.pulsar.common.classification中的类
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability.Evolving - org.apache.pulsar.common.classification中的注释类型
Evolving, but can break compatibility at minor release (i.e. m.x)
InterfaceStability.Stable - org.apache.pulsar.common.classification中的注释类型
Can evolve while retaining compatibility for minor release boundaries.; can break compatibility only at major release (ie. at m.0).
InterfaceStability.Unstable - org.apache.pulsar.common.classification中的注释类型
No guarantee is provided as to reliability or stability across any level of release granularity.
intersect(Range) - 类 中的方法org.apache.pulsar.client.api.Range
 
InvalidConfigurationException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
Constructs an InvalidConfigurationException with the specified detail message.
InvalidConfigurationException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
Constructs an InvalidConfigurationException with the specified cause.
InvalidConfigurationException(String, Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
Constructs an InvalidConfigurationException with the specified cause.
InvalidMessageException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidMessageException
Constructs an InvalidMessageException with the specified detail message.
InvalidMessageException(String, long) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidMessageException
Constructs an InvalidMessageException with the specified detail message.
InvalidServiceURL(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidServiceURL
Constructs an InvalidServiceURL with the specified cause.
InvalidServiceURL(String, Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidServiceURL
Constructs an InvalidServiceURL with the specified cause.
InvalidTopicNameException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidTopicNameException
Constructs an InvalidTopicNameException with the specified detail message.
InvalidTxnStatusException(String) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.InvalidTxnStatusException
 
ioThreads(int) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the number of threads to be used for handling connections to brokers (default: 1 thread).
isAllowOutOfOrderDelivery() - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy
 
isClosed() - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Return internal state of the client.
isComplete() - 类 中的方法org.apache.pulsar.common.api.AuthData
 
isConnected() - 接口 中的方法org.apache.pulsar.client.api.Consumer
 
isConnected() - 接口 中的方法org.apache.pulsar.client.api.Producer
 
isConnected() - 接口 中的方法org.apache.pulsar.client.api.Reader
 
isEmpty() - 接口 中的方法org.apache.pulsar.client.api.BatchMessageContainer
Check the message batch container is empty.
isJsr310ConversionEnabled() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get JSR310 conversion enabled.
isMultiBatches() - 接口 中的方法org.apache.pulsar.client.api.BatchMessageContainer
Return the batch container batch message in multiple batches.
isPrimitive() - 枚举 中的方法org.apache.pulsar.common.schema.SchemaType
 
isPrimitiveType(SchemaType) - 枚举 中的静态方法org.apache.pulsar.common.schema.SchemaType
 
isReplicated() - 接口 中的方法org.apache.pulsar.client.api.Message
Check whether the message is replicated from other cluster.
isRetriableError(Throwable) - 异常错误 中的静态方法org.apache.pulsar.client.api.PulsarClientException
 
isStruct() - 枚举 中的方法org.apache.pulsar.common.schema.SchemaType
 
isStructType(SchemaType) - 枚举 中的静态方法org.apache.pulsar.common.schema.SchemaType
 
IV_LEN - 接口 中的静态变量org.apache.pulsar.client.api.MessageCrypto
 

J

JSON(Class<T>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a JSON schema type by extracting the fields of the specified class.
JSON(SchemaDefinition) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a JSON schema type with schema definition.
jsonifyKeyValueSchemaInfo(KeyValue<SchemaInfo, SchemaInfo>) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
Jsonify the key/value schema info.
jsonifySchemaInfo(SchemaInfo) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
Jsonify the schema info.
jsonifySchemaInfoWithVersion(SchemaInfoWithVersion) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
Jsonify the schema info with version.

K

keepAliveInterval(int, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set keep alive interval for each client-broker-connection.
key(String) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Sets the key of the message for routing policy.
KEY_BASED - 接口 中的静态变量org.apache.pulsar.client.api.BatcherBuilder
Key based batch message container.
keyBytes(byte[]) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Sets the bytes of the key of the message for routing policy.
keyHashRange(Range...) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Set key hash range of the reader, broker will only dispatch messages which hash of the message key contains by the specified key hash range.
KeySharedMode - org.apache.pulsar.client.api中的枚举
KeyShared mode of KeyShared subscription.
keySharedMode - 类 中的变量org.apache.pulsar.client.api.KeySharedPolicy
 
keySharedPolicy(KeySharedPolicy) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set KeyShared subscription policy for consumer.
KeySharedPolicy - org.apache.pulsar.client.api中的类
KeyShared policy for KeyShared subscription.
KeySharedPolicy() - 类 的构造器org.apache.pulsar.client.api.KeySharedPolicy
 
KeySharedPolicy.KeySharedPolicyAutoSplit - org.apache.pulsar.client.api中的类
Auto split hash range key shared policy.
KeySharedPolicy.KeySharedPolicySticky - org.apache.pulsar.client.api中的类
Sticky attach topic with fixed hash range.
KeyStoreParams - org.apache.pulsar.client.api中的类
KeyStore parameters used for tls authentication.
KeyStoreParams() - 类 的构造器org.apache.pulsar.client.api.KeyStoreParams
 
KeyValue(Class<K>, Class<V>, SchemaType) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Key Value Schema using passed in schema type, support JSON and AVRO currently.
KeyValue(Class<K>, Class<V>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Key Value Schema whose underneath key and value schemas are JSONSchema.
KeyValue(Schema<K>, Schema<V>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Key Value Schema using passed in key and value schemas.
KeyValue(Schema<K>, Schema<V>, KeyValueEncodingType) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Key Value Schema using passed in key, value and encoding type schemas.
KeyValue<K,V> - org.apache.pulsar.common.schema中的类
A simple KeyValue class.
KeyValue(K, V) - 类 的构造器org.apache.pulsar.common.schema.KeyValue
 
KeyValue.KeyValueDecoder<K,V> - org.apache.pulsar.common.schema中的接口
Decoder to decode key/value bytes.
KeyValueEncodingType - org.apache.pulsar.common.schema中的枚举
Encoding types of supported KeyValueSchema for Pulsar messages.
KV_BYTES() - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Schema that can be used to encode/decode KeyValue.

L

latest - 接口 中的静态变量org.apache.pulsar.client.api.MessageId
MessageId that represents the next message published in the topic.
listenerName(String) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Configure the listenerName that the broker will return the corresponding `advertisedListener`.
listenerThreads(int) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the number of threads to be used for message listeners (default: 1 thread).
loadConf(Map<String, Object>) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Load the configuration from provided config map.
loadConf(Map<String, Object>) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Load the configuration from provided config map.
loadConf(Map<String, Object>) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Load the configuration from provided config map.
loadConf(Map<String, Object>) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Load the configuration from provided config map.
loadConf(Map<String, Object>) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Configure the TypedMessageBuilder from a config map, as an alternative compared to call the individual builder methods.
LOCAL_DATE - 接口 中的静态变量org.apache.pulsar.client.api.Schema
LocalDate Schema.
LOCAL_DATE_TIME - 接口 中的静态变量org.apache.pulsar.client.api.Schema
LocalDateTime Schema.
LOCAL_TIME - 接口 中的静态变量org.apache.pulsar.client.api.Schema
LocalTime Schema.
LookupException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.LookupException
Constructs an LookupException with the specified detail message.

M

maxBackoffInterval(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the maximum duration of time for a backoff interval.
maxConcurrentLookupRequests(int) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Number of concurrent lookup-requests allowed to send on each broker-connection to prevent overload on broker.
maxLookupRedirects(int) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the maximum number of times a lookup-request to a broker will be redirected.
maxLookupRequests(int) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Number of max lookup-requests allowed on each broker-connection to prevent overload on broker.
maxNumberOfRejectedRequestPerConnection(int) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set max number of broker-rejected requests in a certain time-frame (30 seconds) after which current connection will be closed and client creates a new connection that give chance to connect a different broker (default: 50).
maxNumBytes(int) - 类 中的方法org.apache.pulsar.client.api.BatchReceivePolicy.Builder
 
maxNumMessages(int) - 类 中的方法org.apache.pulsar.client.api.BatchReceivePolicy.Builder
 
maxPendingChuckedMessage(int) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Consumer buffers chunk messages into memory until it receives all the chunks of the original message.
maxPendingMessages(int) - 接口 中的方法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) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the number of max pending messages across all the partitions.
maxTotalReceiverQueueSizeAcrossPartitions(int) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set the max total receiver queue size across partitons.
Message<T> - org.apache.pulsar.client.api中的接口
The message abstraction used in Pulsar.
MessageAcknowledgeException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.MessageAcknowledgeException
Constructs an MessageAcknowledgeException with the specified cause.
MessageAcknowledgeException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.MessageAcknowledgeException
Constructs an MessageAcknowledgeException with the specified detail message.
messageCrypto(MessageCrypto) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
MessageCrypto<MetadataT,BuilderT> - org.apache.pulsar.client.api中的接口
Interface that abstracts the method to encrypt/decrypt message for End to End Encryption.
MessageId - 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.
messageListener(MessageListener<T>) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Sets a MessageListener for the consumer When a MessageListener is set, application will receive messages through it.
MessageListener<T> - org.apache.pulsar.client.api中的接口
A listener that will be called in order for every message received.
MessageRouter - 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) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set a custom message routing policy by passing an implementation of MessageRouter.
MessageRoutingMode - org.apache.pulsar.client.api中的枚举
Default routing mode for messages to partition.
messageRoutingMode(MessageRoutingMode) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the MessageRoutingMode for a partitioned producer.
Messages<T> - org.apache.pulsar.client.api中的接口
A container that holds the list Message for a topic.
MetaStoreHandlerNotExistsException(long) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.MetaStoreHandlerNotExistsException
 
MetaStoreHandlerNotExistsException(String) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.MetaStoreHandlerNotExistsException
 
MetaStoreHandlerNotReadyException(long) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.MetaStoreHandlerNotReadyException
 
MetaStoreHandlerNotReadyException(String) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.MetaStoreHandlerNotReadyException
 

N

negativeAcknowledge(Message<?>) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Acknowledge the failure to process a single message.
negativeAcknowledge(MessageId) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Acknowledge the failure to process a single message.
negativeAcknowledge(Messages<?>) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Acknowledge the failure to process Messages.
negativeAckRedeliveryDelay(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set the delay to wait before re-delivering messages that have failed to be process.
newAuthenticationTLS(String, String) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newAuthenticationToken(String) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newAuthenticationToken(Supplier<String>) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newAutoConsumeSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newAutoProduceSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newAutoProduceSchema(Schema<?>) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newAvroSchema(SchemaDefinition) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newBooleanSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newByteBufferSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newByteSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newBytesSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newClientBuilder() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newConsumer() - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Create a consumer builder with no schema (Schema.BYTES) for subscribing to one or more topics.
newConsumer(Schema<T>) - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Create a consumer builder with a specific schema 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.
newDateSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newDefaultBatcherBuilder() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newDoubleSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newFloatSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newInstantSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newIntSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newJSONSchema(SchemaDefinition) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newKeyBasedBatcherBuilder() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newKeyValueBytesSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newKeyValueSchema(Schema<K>, Schema<V>) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newKeyValueSchema(Schema<K>, Schema<V>, KeyValueEncodingType) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newKeyValueSchema(Class<K>, Class<V>, SchemaType) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newLocalDateSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newLocalDateTimeSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newLocalTimeSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newLongSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newMessage() - 接口 中的方法org.apache.pulsar.client.api.Producer
Create a new message builder.
newMessage(Schema<V>) - 接口 中的方法org.apache.pulsar.client.api.Producer
Create a new message builder with schema, not required same parameterized type with the producer.
newMessage(Transaction) - 接口 中的方法org.apache.pulsar.client.api.Producer
Create a new message builder with transaction.
newMessageId(long, long, int) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newMessageIdFromByteArray(byte[]) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newMessageIdFromByteArrayWithTopic(byte[], String) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newProducer() - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Create a producer builder that can be used to configure and construct a producer with default Schema.BYTES.
newProducer(Schema<T>) - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Create a producer builder that can be used to configure and construct a producer with the specified schema.
newProtobufNativeSchema(SchemaDefinition) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newProtobufSchema(SchemaDefinition) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newReader() - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Create a topic reader builder with no schema (Schema.BYTES) to read from the specified topic.
newReader(Schema<T>) - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Create a topic reader builder with a specific Schema) to read from the specified topic.
newRecordBuilder() - 接口 中的方法org.apache.pulsar.client.api.schema.GenericSchema
Create a builder to build GenericRecord.
newRecordSchemaBuilder(String) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newRequestHeader(String, AuthenticationDataProvider, Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.Authentication
Add an authenticationStage that will complete along with authFuture.
newSchemaDefinitionBuilder() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newShortSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newStringSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newStringSchema(Charset) - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newTimeSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newTimestampSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newTransaction() - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Create a transaction builder that can be used to configure and construct a transaction.
newTransaction() - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Create a new transaction.
newTransaction(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Create a new transaction.
newTransactionAsync() - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Create a new transaction asynchronously.
newTransactionAsync(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Create a new transaction asynchronously.
NotAllowedException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotAllowedException
Constructs an NotAllowedException with the specified detail message.
NotConnectedException() - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotConnectedException
 
NotConnectedException(long) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotConnectedException
 
NotFoundException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotFoundException
Constructs an NotFoundException with the specified detail message.
NotFoundException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotFoundException
Constructs an NotFoundException with the specified cause.
NotSupportedException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotSupportedException
Constructs an NotSupportedException with the specified detail message.
numPartitions() - 接口 中的方法org.apache.pulsar.client.api.TopicMetadata
Return the number of partitions per topic.

O

of(int, int) - 类 中的静态方法org.apache.pulsar.client.api.Range
 
of(SchemaInfo) - 接口 中的静态方法org.apache.pulsar.client.api.schema.GenericSchema
 
of(SchemaInfo, boolean) - 接口 中的静态方法org.apache.pulsar.client.api.schema.GenericSchema
 
onAcknowledge(Consumer<T>, MessageId, Throwable) - 接口 中的方法org.apache.pulsar.client.api.ConsumerInterceptor
This is called consumer sends the acknowledgment to the broker.
onAcknowledgeCumulative(Consumer<T>, MessageId, Throwable) - 接口 中的方法org.apache.pulsar.client.api.ConsumerInterceptor
This is called consumer send the cumulative acknowledgment to the broker.
onAckTimeoutSend(Consumer<T>, Set<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.ConsumerInterceptor
This method will be called when a redelivery from an acknowledge timeout occurs.
onNegativeAcksSend(Consumer<T>, Set<MessageId>) - 接口 中的方法org.apache.pulsar.client.api.ConsumerInterceptor
This method will be called when a redelivery from a negative acknowledge occurs.
onSendAcknowledgement(Producer, Message, MessageId, Throwable) - 接口 中的方法org.apache.pulsar.client.api.interceptor.ProducerInterceptor
This method is called when the message sent to the broker has been acknowledged, or when sending the message fails.
onSendAcknowledgement(Producer, Message, MessageId, Throwable) - 类 中的方法org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
 
onSendAcknowledgement(Producer<T>, Message<T>, MessageId, Throwable) - 接口 中的方法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.
operationTimeout(int, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the operation timeout (default: 30 seconds).
optional() - 接口 中的方法org.apache.pulsar.client.api.schema.FieldSchemaBuilder
Make this field optional.
orderingKey(byte[]) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Sets the ordering key of the message for message dispatch in SubscriptionType.Key_Shared mode.
org.apache.pulsar.client.api - 程序包 org.apache.pulsar.client.api
Pulsar Client API.
org.apache.pulsar.client.api.interceptor - 程序包 org.apache.pulsar.client.api.interceptor
Pulsar interceptors.
org.apache.pulsar.client.api.schema - 程序包 org.apache.pulsar.client.api.schema
Schema definitions for Pulsar Client API.
org.apache.pulsar.client.api.transaction - 程序包 org.apache.pulsar.client.api.transaction
Pulsar transaction related API.
org.apache.pulsar.client.internal - 程序包 org.apache.pulsar.client.internal
Helpers which provide useful functionality for the implementation of Pulsar Client API.
org.apache.pulsar.common.api - 程序包 org.apache.pulsar.common.api
Common data classes used in the Pulsar Client API.
org.apache.pulsar.common.classification - 程序包 org.apache.pulsar.common.classification
Annotations used across the whole project.
org.apache.pulsar.common.schema - 程序包 org.apache.pulsar.common.schema
This package contains data structures for schema definitions used in the Pulsar Client API.

P

patternAutoDiscoveryPeriod(int) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set topics auto discovery period when using a pattern for topics consumer.
patternAutoDiscoveryPeriod(int, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set topics auto discovery period when using a pattern for topics consumer.
pause() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Stop requesting new messages from the broker until Consumer.resume() is called.
priorityLevel(int) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Shared subscription Sets priority level for the shared subscription consumers to which broker gives more priority while dispatching messages.
Producer<T> - org.apache.pulsar.client.api中的接口
Producer is used to publish messages on a topic.
ProducerBlockedQuotaExceededError(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ProducerBlockedQuotaExceededError
Constructs an ProducerBlockedQuotaExceededError with the specified detail message.
ProducerBlockedQuotaExceededException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ProducerBlockedQuotaExceededException
Constructs an ProducerBlockedQuotaExceededException with the specified detail message.
ProducerBuilder<T> - org.apache.pulsar.client.api中的接口
ProducerBuilder is used to configure and create instances of Producer.
ProducerBusyException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ProducerBusyException
Constructs an ProducerBusyException with the specified detail message.
ProducerCryptoFailureAction - org.apache.pulsar.client.api中的枚举
The action the producer will take in case of encryption failures.
ProducerInterceptor - org.apache.pulsar.client.api.interceptor中的接口
A plugin interface that allows you to intercept (and possibly mutate) the messages received by the producer before they are published to the Pulsar brokers.
ProducerInterceptor<T> - org.apache.pulsar.client.api中的接口
已过时。
ProducerInterceptorWrapper - org.apache.pulsar.client.api.interceptor中的类
A wrapper for old style producer interceptor.
ProducerInterceptorWrapper(ProducerInterceptor<?>) - 类 的构造器org.apache.pulsar.client.api.interceptor.ProducerInterceptorWrapper
 
producerName(String) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Specify a name for the producer.
ProducerQueueIsFullError(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ProducerQueueIsFullError
Constructs an ProducerQueueIsFullError with the specified detail message.
ProducerQueueIsFullError(String, long) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ProducerQueueIsFullError
Constructs an ProducerQueueIsFullError with the specified detail message.
ProducerStats - org.apache.pulsar.client.api中的接口
Producer statistics recorded by client.
properties(Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Add all the properties in the provided map to the consumer.
properties(Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Add all the properties in the provided map to the producer.
properties(Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Add all the properties in the provided map.
property(String, String) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set a name/value property with this consumer.
property(String, String) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set a name/value property with this producer.
property(String, String) - 接口 中的方法org.apache.pulsar.client.api.schema.FieldSchemaBuilder
Set name-value pair properties for this field.
property(String, String) - 接口 中的方法org.apache.pulsar.client.api.schema.RecordSchemaBuilder
Attach val-name property pair to the record schema.
property(String, String) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Sets a new property on a message.
PROTOBUF(Class<T>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a Protobuf schema type by extracting the fields of the specified class.
PROTOBUF(SchemaDefinition<T>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a Protobuf schema type with schema definition.
PROTOBUF_NATIVE(Class<T>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a Protobuf-Native schema type by extracting the fields of the specified class.
PROTOBUF_NATIVE(SchemaDefinition<T>) - 接口 中的静态方法org.apache.pulsar.client.api.Schema
Create a Protobuf-Native schema type with schema definition.
ProxyProtocol - org.apache.pulsar.client.api中的枚举
Protcol type to determine type of proxy routing when client connects to proxy using ClientBuilder::proxyServiceUrl.
proxyServiceUrl(String, ProxyProtocol) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Proxy-service url when client would like to connect to broker via proxy.
PulsarClient - org.apache.pulsar.client.api中的接口
Class that provides a client interface to Pulsar.
PulsarClientException - org.apache.pulsar.client.api中的异常错误
Base type of exception thrown by Pulsar client.
PulsarClientException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException
Constructs an PulsarClientException with the specified detail message.
PulsarClientException(String, long) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException
Constructs an PulsarClientException with the specified detail message.
PulsarClientException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException
Constructs an PulsarClientException with the specified cause.
PulsarClientException(String, Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException
Constructs an PulsarClientException with the specified cause.
PulsarClientException(Throwable, long) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException
Constructs an PulsarClientException with the specified cause.
PulsarClientException.AlreadyClosedException - org.apache.pulsar.client.api中的异常错误
Already closed exception thrown by Pulsar client.
PulsarClientException.AuthenticationException - org.apache.pulsar.client.api中的异常错误
Authentication exception thrown by Pulsar client.
PulsarClientException.AuthorizationException - org.apache.pulsar.client.api中的异常错误
Authorization exception thrown by Pulsar client.
PulsarClientException.BrokerMetadataException - org.apache.pulsar.client.api中的异常错误
Broker metadata exception thrown by Pulsar client.
PulsarClientException.BrokerPersistenceException - org.apache.pulsar.client.api中的异常错误
Broker persistence exception thrown by Pulsar client.
PulsarClientException.ChecksumException - org.apache.pulsar.client.api中的异常错误
Checksum exception thrown by Pulsar client.
PulsarClientException.ConnectException - org.apache.pulsar.client.api中的异常错误
Connect exception thrown by Pulsar client.
PulsarClientException.ConsumerAssignException - org.apache.pulsar.client.api中的异常错误
Consumer assign exception thrown by Pulsar client.
PulsarClientException.ConsumerBusyException - org.apache.pulsar.client.api中的异常错误
Consumer busy exception thrown by Pulsar client.
PulsarClientException.CryptoException - org.apache.pulsar.client.api中的异常错误
Crypto exception thrown by Pulsar client.
PulsarClientException.GettingAuthenticationDataException - org.apache.pulsar.client.api中的异常错误
Getting authentication data exception thrown by Pulsar client.
PulsarClientException.IncompatibleSchemaException - org.apache.pulsar.client.api中的异常错误
Incompatible schema exception thrown by Pulsar client.
PulsarClientException.InvalidConfigurationException - org.apache.pulsar.client.api中的异常错误
Invalid Configuration exception thrown by Pulsar client.
PulsarClientException.InvalidMessageException - org.apache.pulsar.client.api中的异常错误
Invalid message exception thrown by Pulsar client.
PulsarClientException.InvalidServiceURL - org.apache.pulsar.client.api中的异常错误
Invalid Service URL exception thrown by Pulsar client.
PulsarClientException.InvalidTopicNameException - org.apache.pulsar.client.api中的异常错误
Invalid topic name exception thrown by Pulsar client.
PulsarClientException.LookupException - org.apache.pulsar.client.api中的异常错误
Lookup exception thrown by Pulsar client.
PulsarClientException.MessageAcknowledgeException - org.apache.pulsar.client.api中的异常错误
Consumer assign exception thrown by Pulsar client.
PulsarClientException.NotAllowedException - org.apache.pulsar.client.api中的异常错误
Not allowed exception thrown by Pulsar client.
PulsarClientException.NotConnectedException - org.apache.pulsar.client.api中的异常错误
Not connected exception thrown by Pulsar client.
PulsarClientException.NotFoundException - org.apache.pulsar.client.api中的异常错误
Not Found exception thrown by Pulsar client.
PulsarClientException.NotSupportedException - org.apache.pulsar.client.api中的异常错误
Not supported exception thrown by Pulsar client.
PulsarClientException.ProducerBlockedQuotaExceededError - org.apache.pulsar.client.api中的异常错误
Producer blocked quota exceeded error thrown by Pulsar client.
PulsarClientException.ProducerBlockedQuotaExceededException - org.apache.pulsar.client.api中的异常错误
Producer blocked quota exceeded exception thrown by Pulsar client.
PulsarClientException.ProducerBusyException - org.apache.pulsar.client.api中的异常错误
Producer busy exception thrown by Pulsar client.
PulsarClientException.ProducerQueueIsFullError - org.apache.pulsar.client.api中的异常错误
Full producer queue error thrown by Pulsar client.
PulsarClientException.TimeoutException - org.apache.pulsar.client.api中的异常错误
Timeout exception thrown by Pulsar client.
PulsarClientException.TooManyRequestsException - org.apache.pulsar.client.api中的异常错误
Too many requests exception thrown by Pulsar client.
PulsarClientException.TopicDoesNotExistException - org.apache.pulsar.client.api中的异常错误
Topic does not exist and cannot be created.
PulsarClientException.TopicTerminatedException - org.apache.pulsar.client.api中的异常错误
Topic terminated exception thrown by Pulsar client.
PulsarClientException.TransactionConflictException - org.apache.pulsar.client.api中的异常错误
Consumer assign exception thrown by Pulsar client.
PulsarClientException.UnsupportedAuthenticationException - org.apache.pulsar.client.api中的异常错误
Unsupported authentication exception thrown by Pulsar client.

R

Range - org.apache.pulsar.client.api中的类
Int range.
Range(int, int) - 类 的构造器org.apache.pulsar.client.api.Range
 
ranges - 类 中的变量org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
 
ranges(List<Range>) - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
 
ranges(Range...) - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
 
reachedEndOfTopic(Consumer<T>) - 接口 中的方法org.apache.pulsar.client.api.MessageListener
Get the notification when a topic is terminated.
reachedEndOfTopic(Reader<T>) - 接口 中的方法org.apache.pulsar.client.api.ReaderListener
Get the notification when a topic is terminated.
read(byte[]) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaReader
Serialize bytes convert pojo.
read(byte[], int, int) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaReader
serialize bytes convert pojo.
read(InputStream) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaReader
serialize bytes convert pojo.
read(byte[], byte[]) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaReader
Serialize bytes convert pojo.
read(InputStream, byte[]) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaReader
serialize bytes convert pojo.
readCompacted(boolean) - 接口 中的方法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) - 接口 中的方法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> - org.apache.pulsar.client.api中的接口
A Reader can be used to scan through all the messages currently available in a topic.
ReaderBuilder<T> - org.apache.pulsar.client.api中的接口
ReaderBuilder is used to configure and create instances of Reader.
readerListener(ReaderListener<T>) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Sets a ReaderListener for the reader.
ReaderListener<T> - org.apache.pulsar.client.api中的接口
A listener that will be called in order for every message received.
readerName(String) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Specify a reader name.
readNext() - 接口 中的方法org.apache.pulsar.client.api.Reader
Read the next message in the topic.
readNext(int, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.Reader
Read the next message in the topic waiting for a maximum time.
readNextAsync() - 接口 中的方法org.apache.pulsar.client.api.Reader
Read asynchronously the next message in the topic.
receive() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Receives a single message.
receive(int, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Receive a single message.
receiveAsync() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Receive a single message Retrieves a message when it will be available and completes CompletableFuture with received message.
received(Consumer<T>, Message<T>) - 接口 中的方法org.apache.pulsar.client.api.MessageListener
This method is called whenever a new message is received.
received(Reader<T>, Message<T>) - 接口 中的方法org.apache.pulsar.client.api.ReaderListener
This method is called whenever a new message is received.
receiverQueueSize(int) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Sets the size of the consumer receive queue.
receiverQueueSize(int) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Sets the size of the consumer receive queue.
reconsumeLater(Message<?>, long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.Consumer
reconsumeLater the consumption of Messages.
reconsumeLater(Messages<?>, long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.Consumer
reconsumeLater the consumption of Messages.
reconsumeLaterAsync(Message<?>, long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously reconsumeLater the consumption of a single message.
reconsumeLaterAsync(Messages<?>, long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously reconsumeLater the consumption of Messages.
reconsumeLaterCumulative(Message<?>, long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.Consumer
reconsumeLater the reception of all the messages in the stream up to (and including) the provided message.
reconsumeLaterCumulativeAsync(Message<?>, long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously ReconsumeLater the reception of all the messages in the stream up to (and including) the provided message.
record(String) - 接口 中的静态方法org.apache.pulsar.client.api.schema.SchemaBuilder
Build the schema for a record.
RecordSchemaBuilder - org.apache.pulsar.client.api.schema中的接口
Building the schema for a GenericRecord.
redeliverUnacknowledgedMessages() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Redelivers all the unacknowledged messages.
REFRESH_AUTH_DATA - 类 中的静态变量org.apache.pulsar.common.api.AuthData
 
REFRESH_AUTH_DATA_BYTES - 类 中的静态变量org.apache.pulsar.common.api.AuthData
 
RegexSubscriptionMode - org.apache.pulsar.client.api中的枚举
When subscribing to topics using a regular expression, one can specify to only pick a certain type of topics.
removeKeyCipher(String) - 接口 中的方法org.apache.pulsar.client.api.MessageCrypto
 
replicateSubscriptionState(boolean) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
 
replicationClusters(List<String>) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Override the geo-replication clusters for this message.
RequestTimeoutException() - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionBufferClientException.RequestTimeoutException
 
RequestTimeoutException(String) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionBufferClientException.RequestTimeoutException
 
required() - 接口 中的方法org.apache.pulsar.client.api.schema.FieldSchemaBuilder
Make this field required.
requireFetchingSchemaInfo() - 接口 中的方法org.apache.pulsar.client.api.Schema
Check if this schema requires fetching schema info to configure the schema.
resume() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Resume requesting messages from the broker.
roundRobinRouterBatchingPartitionSwitchFrequency(int) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the partition switch frequency while batching of messages is enabled and using round-robin routing mode for non-keyed message default: 10.

S

Schema<T> - org.apache.pulsar.client.api中的接口
Message schema definition.
SchemaBuilder - org.apache.pulsar.client.api.schema中的接口
Builder to build schema.
SchemaDefinition<T> - org.apache.pulsar.client.api.schema中的接口
Interface for schema definition.
SchemaDefinitionBuilder<T> - org.apache.pulsar.client.api.schema中的接口
Builder to build schema definition SchemaDefinition.
SchemaInfo - org.apache.pulsar.common.schema中的类
Information about the schema.
SchemaInfo() - 类 的构造器org.apache.pulsar.common.schema.SchemaInfo
 
SchemaInfoProvider - org.apache.pulsar.client.api.schema中的接口
Schema Provider.
SchemaInfoWithVersion - org.apache.pulsar.common.schema中的类
Data structure representing a schema information including its version.
SchemaInfoWithVersion() - 类 的构造器org.apache.pulsar.common.schema.SchemaInfoWithVersion
 
SchemaReader<T> - org.apache.pulsar.client.api.schema中的接口
Deserialize messages from bytes.
SchemaSerializationException - org.apache.pulsar.client.api中的异常错误
Schema serialization exception.
SchemaSerializationException(String) - 异常错误 的构造器org.apache.pulsar.client.api.SchemaSerializationException
Constructs an SchemaSerializationException with the specified detail message.
SchemaSerializationException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.SchemaSerializationException
Constructs an SchemaSerializationException with the specified cause.
SchemaType - org.apache.pulsar.common.schema中的枚举
Types of supported schema for Pulsar messages.
SchemaWriter<T> - org.apache.pulsar.client.api.schema中的接口
Serialize messages into bytes.
seek(MessageId) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Reset the subscription associated with this consumer to a specific message id.
seek(long) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Reset the subscription associated with this consumer to a specific message publish time.
seek(MessageId) - 接口 中的方法org.apache.pulsar.client.api.Reader
Reset the subscription associated with this reader to a specific message id.
seek(long) - 接口 中的方法org.apache.pulsar.client.api.Reader
Reset the subscription associated with this reader to a specific message publish time.
seekAsync(MessageId) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Reset the subscription associated with this consumer to a specific message id.
seekAsync(long) - 接口 中的方法org.apache.pulsar.client.api.Consumer
Reset the subscription associated with this consumer to a specific message publish time.
seekAsync(MessageId) - 接口 中的方法org.apache.pulsar.client.api.Reader
Reset the subscription associated with this reader to a specific message id.
seekAsync(long) - 接口 中的方法org.apache.pulsar.client.api.Reader
Reset the subscription associated with this reader to a specific message publish time.
send(T) - 接口 中的方法org.apache.pulsar.client.api.Producer
Sends a message.
send() - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Send a message synchronously.
sendAsync(T) - 接口 中的方法org.apache.pulsar.client.api.Producer
Send a message asynchronously.
sendAsync() - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Send a message asynchronously This method returns a future that can be used to track the completion of the send operation and yields the MessageId assigned by the broker to the published message.
sendTimeout(int, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Set the send timeout (default: 30 seconds).
sequenceId(long) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Specify a custom sequence id for the message being published.
serviceUrl(String) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Configure the service URL for the Pulsar service.
serviceUrlProvider(ServiceUrlProvider) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Configure the service URL provider for Pulsar service.
ServiceUrlProvider - org.apache.pulsar.client.api中的接口
The provider to provide the service url.
set(String, Object) - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecordBuilder
Sets the value of a field.
set(Field, Object) - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecordBuilder
Sets the value of a field.
setAllowOutOfOrderDelivery(boolean) - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy
If enabled, it will relax the ordering requirement, allowing the broker to send out-of-order messages in case of failures.
setKey(byte[]) - 类 中的方法org.apache.pulsar.client.api.EncryptionKeyInfo
 
setMetadata(Map<String, String>) - 类 中的方法org.apache.pulsar.client.api.EncryptionKeyInfo
 
setSchemaInfoProvider(SchemaInfoProvider) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaReader
Set schema info provider, this method support multi version reader.
setSchemaInfoProvider(SchemaInfoProvider) - 接口 中的方法org.apache.pulsar.client.api.Schema
 
setSequenceId(long) - 异常错误 中的方法org.apache.pulsar.client.api.PulsarClientException
 
shutdown() - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Perform immediate shutdown of PulsarClient.
size() - 接口 中的方法org.apache.pulsar.client.api.Messages
Get number of messages.
sslProvider(String) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
The name of the security provider used for SSL connections.
start() - 接口 中的方法org.apache.pulsar.client.api.Authentication
Initialize the authentication provider.
start() - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Start transaction meta store client.
startAsync() - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient
Start transaction meta store client asynchronous.
startingBackoffInterval(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the duration of time for a backoff interval.
startMessageFromRollbackDuration(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
The initial reader positioning can be set at specific timestamp by providing total rollback duration. so, broker can find a latest message that was published before given duration.
startMessageId(MessageId) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
The initial reader positioning is done by specifying a message id.
startMessageIdInclusive() - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set the consumer to include the given position of any reset operation like or {@link Consumer#seek(MessageId)}.
startMessageIdInclusive() - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Set the reader to include the given position of ReaderBuilder.startMessageId(MessageId) This configuration option also applies for any cursor reset operation like Reader.seek(MessageId).
statsInterval(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the interval between each stat info (default: 60 seconds) Stats will be activated with positive statsInterval It should be set to at least 1 second.
stickyHashRange() - 类 中的静态方法org.apache.pulsar.client.api.KeySharedPolicy
 
STRING - 接口 中的静态变量org.apache.pulsar.client.api.Schema
Schema that can be used to encode/decode messages whose values are String.
subscribe() - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Finalize the Consumer creation by subscribing to the topic.
subscribeAsync() - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Finalize the Consumer creation by subscribing to the topic in asynchronous mode.
subscriptionInitialPosition(SubscriptionInitialPosition) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Set the SubscriptionInitialPosition for the consumer.
SubscriptionInitialPosition - org.apache.pulsar.client.api中的枚举
When creating a consumer, if the subscription does not exist, a new subscription will be created.
subscriptionMode(SubscriptionMode) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Select the subscription mode to be used when subscribing to the topic.
SubscriptionMode - org.apache.pulsar.client.api中的枚举
Types of subscription mode supported by Pulsar.
subscriptionName(String) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Specify the subscription name for this consumer.
subscriptionRolePrefix(String) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Set the subscription role prefix.
subscriptionTopicsMode(RegexSubscriptionMode) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Determines to which topics this consumer should be subscribed to - Persistent, Non-Persistent, or both.
subscriptionType(SubscriptionType) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Select the subscription type to be used when subscribing to the topic.
SubscriptionType - org.apache.pulsar.client.api中的枚举
Types of subscription supported by Pulsar.
supportSchemaVersioning() - 接口 中的方法org.apache.pulsar.client.api.Schema
Returns whether this schema supports versioning.

T

TIME - 接口 中的静态变量org.apache.pulsar.client.api.Schema
Time Schema.
timeout(int, TimeUnit) - 类 中的方法org.apache.pulsar.client.api.BatchReceivePolicy.Builder
 
TimeoutException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TimeoutException
Constructs an TimeoutException with the specified cause.
TimeoutException(Throwable, long) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TimeoutException
Constructs an TimeoutException with the specified cause.
TimeoutException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TimeoutException
Constructs an TimeoutException with the specified detail message.
TimeoutException(String, long) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TimeoutException
Constructs an TimeoutException with the specified detail message.
TIMESTAMP - 接口 中的静态变量org.apache.pulsar.client.api.Schema
Timestamp Schema.
TLS(String, String) - 类 中的静态方法org.apache.pulsar.client.api.AuthenticationFactory
Create an authentication provider for TLS based authentication.
tlsCiphers(Set<String>) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
A list of cipher suites.
tlsProtocols(Set<String>) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
The SSL protocol used to generate the SSLContext.
tlsTrustCertsFilePath(String) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the path to the trusted TLS certificate file.
tlsTrustStorePassword(String) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
The store password for the key store file.
tlsTrustStorePath(String) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
The location of the trust store file.
tlsTrustStoreType(String) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
The file format of the trust store file.
toByteArray() - 接口 中的方法org.apache.pulsar.client.api.MessageId
Serialize the message ID into a byte array.
token(String) - 类 中的静态方法org.apache.pulsar.client.api.AuthenticationFactory
Create an authentication provider for token based authentication.
token(Supplier<String>) - 类 中的静态方法org.apache.pulsar.client.api.AuthenticationFactory
Create an authentication provider for token based authentication.
TooManyRequestsException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TooManyRequestsException
Constructs an TooManyRequestsException with the specified detail message.
topic(String...) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Specify the topics this consumer will subscribe on.
topic(String) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Specify the topic this producer will be publishing on.
topic(String) - 接口 中的方法org.apache.pulsar.client.api.ReaderBuilder
Specify the topic this reader will read from.
TopicDoesNotExistException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TopicDoesNotExistException
Constructs an TopicDoesNotExistException with the specified detail message.
TopicMetadata - org.apache.pulsar.client.api中的接口
Metadata of a topic that can be used for message routing.
topics(List<String>) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Specify a list of topics that this consumer will subscribe on.
topicsPattern(Pattern) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Specify a pattern for topics that this consumer will subscribe on.
topicsPattern(String) - 接口 中的方法org.apache.pulsar.client.api.ConsumerBuilder
Specify a pattern for topics that this consumer will subscribe on.
TopicTerminatedException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TopicTerminatedException
Constructs an TopicTerminatedException with the specified detail message.
TopicTerminatedException(String, long) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TopicTerminatedException
Constructs an TopicTerminatedException with the specified detail message.
toString() - 类 中的方法org.apache.pulsar.client.api.BatchReceivePolicy
 
toString() - 类 中的方法org.apache.pulsar.client.api.Range
 
toString() - 类 中的方法org.apache.pulsar.client.api.transaction.TxnID
 
toString() - 类 中的方法org.apache.pulsar.common.schema.KeyValue
 
toString() - 类 中的方法org.apache.pulsar.common.schema.SchemaInfo
 
toString() - 类 中的方法org.apache.pulsar.common.schema.SchemaInfoWithVersion
 
Transaction - org.apache.pulsar.client.api.transaction中的接口
The class represents a transaction within Pulsar.
TransactionBufferClient - org.apache.pulsar.client.api.transaction中的接口
The transaction buffer client to commit and abort transactions on topics or subscription.
TransactionBufferClientException - org.apache.pulsar.client.api.transaction中的异常错误
Exceptions for transaction buffer client.
TransactionBufferClientException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionBufferClientException
 
TransactionBufferClientException(String) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionBufferClientException
 
TransactionBufferClientException.RequestTimeoutException - org.apache.pulsar.client.api.transaction中的异常错误
Thrown when operation timeout.
TransactionBuilder - org.apache.pulsar.client.api.transaction中的接口
The builder to build a transaction for Pulsar.
TransactionConflictException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TransactionConflictException
Constructs an TransactionConflictException with the specified cause.
TransactionConflictException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TransactionConflictException
Constructs an TransactionConflictException with the specified detail message.
TransactionCoordinatorClient - org.apache.pulsar.client.api.transaction中的接口
Transaction coordinator client.
TransactionCoordinatorClient.State - org.apache.pulsar.client.api.transaction中的枚举
State of the transaction coordinator client.
TransactionCoordinatorClientException - org.apache.pulsar.client.api.transaction中的异常错误
Exceptions for transaction coordinator client.
TransactionCoordinatorClientException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException
 
TransactionCoordinatorClientException(String) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException
 
TransactionCoordinatorClientException.CoordinatorClientStateException - org.apache.pulsar.client.api.transaction中的异常错误
Thrown when transaction coordinator with unexpected state.
TransactionCoordinatorClientException.CoordinatorNotFoundException - org.apache.pulsar.client.api.transaction中的异常错误
Thrown when transaction coordinator not found in broker side.
TransactionCoordinatorClientException.InvalidTxnStatusException - org.apache.pulsar.client.api.transaction中的异常错误
Thrown when transaction switch to a invalid status.
TransactionCoordinatorClientException.MetaStoreHandlerNotExistsException - org.apache.pulsar.client.api.transaction中的异常错误
Thrown when transaction meta store handler not exists.
TransactionCoordinatorClientException.MetaStoreHandlerNotReadyException - org.apache.pulsar.client.api.transaction中的异常错误
Thrown when send request to transaction meta store but the transaction meta store handler not ready.
TransactionCoordinatorClientException.TransactionNotFoundException - org.apache.pulsar.client.api.transaction中的异常错误
Thrown when transaction not found in transaction coordinator.
TransactionNotFoundException(String) - 异常错误 的构造器org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException.TransactionNotFoundException
 
TxnID - org.apache.pulsar.client.api.transaction中的类
An identifier for representing a transaction.
TxnID() - 类 的构造器org.apache.pulsar.client.api.transaction.TxnID
 
type(SchemaType) - 接口 中的方法org.apache.pulsar.client.api.schema.FieldSchemaBuilder
The type of this field.
TypedMessageBuilder<T> - org.apache.pulsar.client.api中的接口
Message builder that constructs a message to be published through a producer.

U

unsubscribe() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Unsubscribe the consumer.
unsubscribeAsync() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously unsubscribe the consumer.
UnsupportedAuthenticationException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.UnsupportedAuthenticationException
Constructs an UnsupportedAuthenticationException with the specified cause.
UnsupportedAuthenticationException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.UnsupportedAuthenticationException
Constructs an UnsupportedAuthenticationException with the specified detail message.
unwrap(Throwable) - 异常错误 中的静态方法org.apache.pulsar.client.api.PulsarClientException
 
unwrap(Throwable) - 异常错误 中的静态方法org.apache.pulsar.client.api.transaction.TransactionBufferClientException
 
unwrap(Throwable) - 异常错误 中的静态方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClientException
 
updateServiceUrl(String) - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Update the service URL this client is using.
useKeyStoreTls(boolean) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
If Tls is enabled, whether use KeyStore type as tls configuration parameter.

V

validate() - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicyAutoSplit
 
validate() - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy.KeySharedPolicySticky
 
validate() - 类 中的方法org.apache.pulsar.client.api.KeySharedPolicy
 
validate(byte[]) - 接口 中的方法org.apache.pulsar.client.api.Schema
Check if the message is a valid object for this schema.
value(T) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Set a domain object on the message.
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.CompressionType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.ConsumerCryptoFailureAction
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.HashingScheme
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.KeySharedMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.MessageRoutingMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.ProducerCryptoFailureAction
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.ProxyProtocol
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.RegexSubscriptionMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionInitialPosition
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.common.schema.KeyValueEncodingType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.common.schema.SchemaType
返回带有指定名称的该类型的枚举常量。
valueOf(int) - 枚举 中的静态方法org.apache.pulsar.common.schema.SchemaType
 
values() - 枚举 中的静态方法org.apache.pulsar.client.api.CompressionType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.ConsumerCryptoFailureAction
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.HashingScheme
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.KeySharedMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.MessageRoutingMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.ProducerCryptoFailureAction
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.ProxyProtocol
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.RegexSubscriptionMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionInitialPosition
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.transaction.TransactionCoordinatorClient.State
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.common.schema.KeyValueEncodingType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.common.schema.SchemaType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
verify() - 类 中的方法org.apache.pulsar.client.api.BatchReceivePolicy
 

W

withAlwaysAllowNull(boolean) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema whether always allow null or not.
withJsonDef(String) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema of json definition.
withJSR310ConversionEnabled(boolean) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema use JRS310 conversion or not.
withPojo(Class) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema of pojo definition.
withProperties(Map<String, String>) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema info properties.
withSchemaReader(SchemaReader<T>) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema reader for deserialization of object data.
withSchemaWriter(SchemaWriter<T>) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema writer for serialization of objects.
withSupportSchemaVersioning(boolean) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema whether decode by schema version.
withTransactionTimeout(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.transaction.TransactionBuilder
Configure the maximum amount of time that the transaction coordinator will for a transaction to be completed by the client before proactively aborting the ongoing transaction.
wrap(Throwable, String) - 异常错误 中的静态方法org.apache.pulsar.client.api.PulsarClientException
 
write(T) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaWriter
Serialize the message into bytes.
A B C D E F G H I J K L M N O P R S T U V W 
跳过导航链接

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