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

A

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.
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
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(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.
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
aliases(String...) - 接口 中的方法org.apache.pulsar.client.api.schema.FieldSchemaBuilder
The optional name aliases of this field.
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
 
AuthData - org.apache.pulsar.common.api中的类
 
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
 
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
 
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.
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.
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.
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
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<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
 
BrokerPersistenceException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.BrokerPersistenceException
 
build() - 接口 中的方法org.apache.pulsar.client.api.BatcherBuilder
Build a new batch message container.
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.
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
 
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.
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.
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.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.
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
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.
ConnectException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ConnectException
 
ConnectException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ConnectException
 
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.
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
 
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.
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
 
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 By default some message will redelivery so many times possible, even to the extent that it can be never stop.
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.
DEFAULT - 接口 中的静态变量org.apache.pulsar.client.api.BatcherBuilder
Default batch message container incoming single messages: (k1, v1), (k2, v1), (k3, v1), (k1, v2), (k2, v2), (k3, v2), (k1, v3), (k2, v3), (k3, v3) batched into single batch message: [(k1, v1), (k2, v1), (k3, v1), (k1, v2), (k2, v2), (k3, v2), (k1, v3), (k2, v3), (k3, v3)]
DefaultImplementation - org.apache.pulsar.client.internal中的类
 
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
enableBatching(boolean) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Control whether automatic batching of messages is enabled for the producer.
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.
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中的接口
 
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.
EncryptionContext - org.apache.pulsar.common.api中的类
 
EncryptionContext() - 类 的构造器org.apache.pulsar.common.api.EncryptionContext
 
EncryptionContext.EncryptionKey - org.apache.pulsar.common.api中的类
 
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.common.schema.KeyValue
 
eventTime(long) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Set the event time for a given message.

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<S extends FieldSchemaBuilder<S>> - 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.
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
 
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.
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.
getMessageId() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the unique message ID associated with this message.
getMetadata() - 类 中的方法org.apache.pulsar.client.api.EncryptionKeyInfo
 
getNumAcksFailed() - 接口 中的方法org.apache.pulsar.client.api.ConsumerStats
 
getNumAcksReceived() - 接口 中的方法org.apache.pulsar.client.api.ProducerStats
 
getNumAcksSent() - 接口 中的方法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 This method should be implemented to return the EncryptionKeyInfo.
getPublishTime() - 接口 中的方法org.apache.pulsar.client.api.Message
Get the publish time of this message.
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
 
getSchemaVersion() - 接口 中的方法org.apache.pulsar.client.api.Message
Get schema version of the message.
getSchemaVersion() - 接口 中的方法org.apache.pulsar.client.api.schema.GenericRecord
Return schema version.
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.
getServiceUrl() - 接口 中的方法org.apache.pulsar.client.api.ServiceUrlProvider
Get the current service URL the Pulsar client should connect to.
getStats() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Get statistics for the consumer.
getStats() - 接口 中的方法org.apache.pulsar.client.api.Producer
Get statistics for the producer numMsgsSent : Number of messages sent in the current interval numBytesSent : Number of bytes sent in the current interval numSendFailed : Number of messages failed to send in the current interval numAcksReceived : Number of acks received in the current interval totalMsgsSent : Total number of messages sent totalBytesSent : Total number of bytes sent totalSendFailed : Total number of messages failed to send totalAcksReceived: Total number of acks received
getSubscription() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Get a subscription for the consumer
getSupportSchemaVersioning() - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinition
Get supportSchemaVersioning schema definition
GettingAuthenticationDataException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
 
GettingAuthenticationDataException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.GettingAuthenticationDataException
 
getTlsCertificates() - 接口 中的方法org.apache.pulsar.client.api.AuthenticationDataProvider
 
getTlsPrivateKey() - 接口 中的方法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.
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.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
 
IncompatibleSchemaException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.IncompatibleSchemaException
 
INIT_AUTH_DATA - 类 中的静态变量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.
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
Add a set of ProducerInterceptor to the producer.
InvalidConfigurationException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
 
InvalidConfigurationException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidConfigurationException
 
InvalidMessageException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidMessageException
 
InvalidServiceURL(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidServiceURL
 
InvalidTopicNameException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.InvalidTopicNameException
 
ioThreads(int) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the number of threads to be used for handling connections to brokers (default: 1 thread)
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.
isMultiBatches() - 接口 中的方法org.apache.pulsar.client.api.BatchMessageContainer
Return the batch container batch message in multiple batches
isReplicated() - 接口 中的方法org.apache.pulsar.client.api.Message
Check whether the message is replicated from other cluster.

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.

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 incoming single messages: (k1, v1), (k2, v1), (k3, v1), (k1, v2), (k2, v2), (k3, v2), (k1, v3), (k2, v3), (k3, v3) batched into multiple batch messages: [(k1, v1), (k1, v2), (k1, v3)], [(k2, v1), (k2, v2), (k2, v3)], [(k3, v1), (k3, v2), (k3, v3)]
keyBytes(byte[]) - 接口 中的方法org.apache.pulsar.client.api.TypedMessageBuilder
Sets the bytes of the key of the message for routing policy.
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
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.
LookupException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.LookupException
 

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.
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)
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 This setting will be used to lower the max pending messages for each partition (ProducerBuilder.maxPendingMessages(int)), if the total exceeds the configured value.
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.
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.

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.
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
 
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
 
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
 
newLongSchema() - 类 中的静态方法org.apache.pulsar.client.internal.DefaultImplementation
 
newMessage() - 接口 中的方法org.apache.pulsar.client.api.Producer
Create a new message builder This message builder allows to specify additional properties on the message.
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 Example: Producer<String> producer = client.newProducer(Schema.STRING) .topic("my-topic") .create(); producer.send("test");
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
 
NotConnectedException() - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotConnectedException
 
NotFoundException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotFoundException
 
NotFoundException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotFoundException
 
NotSupportedException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.NotSupportedException
 
numPartitions() - 接口 中的方法org.apache.pulsar.client.api.TopicMetadata
Return the number of partitions per topic.

O

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<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) Producer-create, subscribe and unsubscribe operations will be retried until this interval, after which the operation will be marked as failed
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
 
org.apache.pulsar.client.api.schema - 程序包 org.apache.pulsar.client.api.schema
 
org.apache.pulsar.client.internal - 程序包 org.apache.pulsar.client.internal
 
org.apache.pulsar.common.api - 程序包 org.apache.pulsar.common.api
 
org.apache.pulsar.common.schema - 程序包 org.apache.pulsar.common.schema
 

P

patternAutoDiscoveryPeriod(int) - 接口 中的方法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
 
ProducerBlockedQuotaExceededException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ProducerBlockedQuotaExceededException
 
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
 
ProducerCryptoFailureAction - org.apache.pulsar.client.api中的枚举
The action the producer will take in case of encryption failures
ProducerInterceptor<T> - org.apache.pulsar.client.api中的接口
A plugin interface that allows you to intercept (and possibly mutate) the messages received by the producer before they are published to the Pulsar brokers.
producerName(String) - 接口 中的方法org.apache.pulsar.client.api.ProducerBuilder
Specify a name for the producer If not assigned, the system will generate a globally unique name which can be accessed with Producer.getProducerName().
ProducerQueueIsFullError(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.ProducerQueueIsFullError
 
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.
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
 
PulsarClientException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException
 
PulsarClientException.AlreadyClosedException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.AuthenticationException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.AuthorizationException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.BrokerMetadataException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.BrokerPersistenceException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.ChecksumException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.ConnectException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.ConsumerBusyException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.CryptoException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.GettingAuthenticationDataException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.IncompatibleSchemaException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.InvalidConfigurationException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.InvalidMessageException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.InvalidServiceURL - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.InvalidTopicNameException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.LookupException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.NotConnectedException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.NotFoundException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.NotSupportedException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.ProducerBlockedQuotaExceededError - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.ProducerBlockedQuotaExceededException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.ProducerBusyException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.ProducerQueueIsFullError - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.TimeoutException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.TooManyRequestsException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.TopicTerminatedException - org.apache.pulsar.client.api中的异常错误
 
PulsarClientException.UnsupportedAuthenticationException - org.apache.pulsar.client.api中的异常错误
 

R

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
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 When a ReaderListener is set, application will receive messages through it.
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 Retrieves a message, waiting up to the specified wait time if necessary.
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.
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.
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.
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.
required() - 接口 中的方法org.apache.pulsar.client.api.schema.FieldSchemaBuilder
Make this field required.
resume() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Resume requesting messages from the broker.

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中的接口
 
SchemaDefinitionBuilder<T> - org.apache.pulsar.client.api.schema中的接口
Builder to build schema definition SchemaDefinition.
SchemaInfo - org.apache.pulsar.common.schema中的类
 
SchemaInfo() - 类 的构造器org.apache.pulsar.common.schema.SchemaInfo
 
SchemaInfoProvider - org.apache.pulsar.client.api.schema中的接口
Schema Provider.
SchemaReader<T> - org.apache.pulsar.client.api.schema中的接口
 
SchemaSerializationException - org.apache.pulsar.client.api中的异常错误
 
SchemaSerializationException(String) - 异常错误 的构造器org.apache.pulsar.client.api.SchemaSerializationException
 
SchemaSerializationException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.SchemaSerializationException
 
SchemaType - org.apache.pulsar.common.schema中的枚举
Types of supported schema for Pulsar messages Ideally we should have just one single set of enum definitions for schema type. but we have 3 locations of defining schema types.
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 When the producer queue is full, by default this method will complete the future with an exception PulsarClientException.ProducerQueueIsFullError See ProducerBuilder.maxPendingMessages(int) to configure the producer queue size and ProducerBuilder.blockIfQueueFull(boolean) to change the blocking behavior.
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) If a message is not acknowledged by the server before the sendTimeout expires, an error will be reported.
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 Instead of specifying a static service URL string (with ClientBuilder.serviceUrl(String)), an application can pass a ServiceUrlProvider instance that dynamically provide a service URL.
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.
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
 
shutdown() - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Perform immediate shutdown of PulsarClient.
start() - 接口 中的方法org.apache.pulsar.client.api.Authentication
Initialize the authentication provider
startingBackoffInterval(long, TimeUnit) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the duration of time for a backoff interval.
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.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
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.
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
TimeoutException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TimeoutException
 
TimeoutException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.TimeoutException
 
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.
tlsTrustCertsFilePath(String) - 接口 中的方法org.apache.pulsar.client.api.ClientBuilder
Set the path to the trusted TLS certificate 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
 
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.
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
 
toString() - 类 中的方法org.apache.pulsar.common.schema.KeyValue
 
toString() - 类 中的方法org.apache.pulsar.common.schema.SchemaInfo
 
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 This call blocks until the consumer is unsubscribed.
unsubscribeAsync() - 接口 中的方法org.apache.pulsar.client.api.Consumer
Asynchronously unsubscribe the consumer
UnsupportedAuthenticationException(Throwable) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.UnsupportedAuthenticationException
 
UnsupportedAuthenticationException(String) - 异常错误 的构造器org.apache.pulsar.client.api.PulsarClientException.UnsupportedAuthenticationException
 
unwrap(Throwable) - 异常错误 中的静态方法org.apache.pulsar.client.api.PulsarClientException
 
updateServiceUrl(String) - 接口 中的方法org.apache.pulsar.client.api.PulsarClient
Update the service URL this client is using.

V

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.MessageRoutingMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.ProducerCryptoFailureAction
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.RegexSubscriptionMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionInitialPosition
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionType
返回带有指定名称的该类型的枚举常量。
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.MessageRoutingMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.ProducerCryptoFailureAction
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.RegexSubscriptionMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionInitialPosition
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.client.api.SubscriptionType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.common.schema.KeyValueEncodingType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.pulsar.common.schema.SchemaType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。

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
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
withSupportSchemaVersioning(boolean) - 接口 中的方法org.apache.pulsar.client.api.schema.SchemaDefinitionBuilder
Set schema whether decode by schema version
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–2019 Apache Software Foundation. All rights reserved.