All Classes Interface Summary Class Summary Enum Summary Exception Summary
| Class |
Description |
| ActionType |
Pulsar event action type.
|
| AdvertisedListener |
The advertisedListener for broker with brokerServiceUrl and brokerServiceUrlTls.
|
| AirliftUtils |
Utilities.
|
| AppendBrokerTimestampMetadataInterceptor |
A plugin interface that allows you to intercept the client requests to
the Pulsar brokers and add timestamp from broker side metadata for each entry.
|
| AppendIndexMetadataInterceptor |
|
| AuthData |
|
| AuthMethod |
|
| AuthPoliciesImpl |
|
| AuthPoliciesImpl.AuthPoliciesImplBuilder |
|
| AutoFailoverPolicyDataImpl |
The auto failover policy configuration data.
|
| AutoFailoverPolicyDataImpl.AutoFailoverPolicyDataImplBuilder |
|
| BaseCommand |
|
| BaseCommand.Type |
|
| BCLoader |
This interface declares a Bouncy Castle provider Loader.
|
| BitSetRecyclable |
This this copy of BitSet.
|
| BrokerEntryMetadata |
|
| BrokerEntryMetadataInterceptor |
A plugin interface that allows you to intercept the client requests to
the Pulsar brokers and add metadata for each entry from broker side.
|
| BrokerEntryMetadataUtils<T> |
A tool class for loading BrokerEntryMetadataInterceptor classes.
|
| BrokerNamespaceIsolationDataImpl |
The namespace isolation data for a given broker.
|
| BrokerNamespaceIsolationDataImpl.BrokerNamespaceIsolationDataImplBuilder |
|
| BrokerUsage |
BrokerUsage object encapsulates the resources that are only used by broker, for now, it's connections both to
outside JVM and to the local.
|
| ByteBufPair |
ByteBuf holder that contains 2 buffers.
|
| ByteBufPair.CopyingEncoder |
|
| ByteBufPair.Encoder |
|
| BytesSchemaVersion |
Bytes schema version.
|
| BytesSchemaVersion.ByteArrayComparator |
This interface helps to compare byte arrays.
|
| ChannelFutures |
Static utility methods for operating on ChannelFutures.
|
| ClassLoaderUtils |
Helper methods wrt Classloading.
|
| ClusterDataImpl |
The configuration data for a cluster.
|
| ClusterDataImpl.ClusterDataImplBuilder |
|
| ClusterMessageId |
|
| CmdGenerateDocs |
|
| Codec |
|
| CommandAck |
|
| CommandAck.AckType |
|
| CommandAck.ValidationError |
|
| CommandAckResponse |
|
| CommandActiveConsumerChange |
|
| CommandAddPartitionToTxn |
|
| CommandAddPartitionToTxnResponse |
|
| CommandAddSubscriptionToTxn |
|
| CommandAddSubscriptionToTxnResponse |
|
| CommandAuthChallenge |
|
| CommandAuthResponse |
|
| CommandCloseConsumer |
|
| CommandCloseProducer |
|
| CommandConnect |
|
| CommandConnected |
|
| CommandConsumerStats |
|
| CommandConsumerStatsResponse |
|
| CommandEndTxn |
|
| CommandEndTxnOnPartition |
|
| CommandEndTxnOnPartitionResponse |
|
| CommandEndTxnOnSubscription |
|
| CommandEndTxnOnSubscriptionResponse |
|
| CommandEndTxnResponse |
|
| CommandError |
|
| CommandFlow |
|
| CommandGetLastMessageId |
|
| CommandGetLastMessageIdResponse |
|
| CommandGetOrCreateSchema |
|
| CommandGetOrCreateSchemaResponse |
|
| CommandGetSchema |
|
| CommandGetSchemaResponse |
|
| CommandGetTopicsOfNamespace |
|
| CommandGetTopicsOfNamespace.Mode |
|
| CommandGetTopicsOfNamespaceResponse |
|
| CommandLookupTopic |
|
| CommandLookupTopicResponse |
|
| CommandLookupTopicResponse.LookupType |
|
| CommandMessage |
|
| CommandNewTxn |
|
| CommandNewTxnResponse |
|
| CommandPartitionedTopicMetadata |
|
| CommandPartitionedTopicMetadataResponse |
|
| CommandPartitionedTopicMetadataResponse.LookupType |
|
| CommandPing |
|
| CommandPong |
|
| CommandProducer |
|
| CommandProducerSuccess |
|
| CommandReachedEndOfTopic |
|
| CommandRedeliverUnacknowledgedMessages |
|
| Commands |
|
| Commands.ChecksumType |
Definition of possible checksum types.
|
| CommandSeek |
|
| CommandSend |
|
| CommandSendError |
|
| CommandSendReceipt |
|
| CommandSubscribe |
|
| CommandSubscribe.InitialPosition |
|
| CommandSubscribe.SubType |
|
| CommandSuccess |
|
| CommandTcClientConnectRequest |
|
| CommandTcClientConnectResponse |
|
| CommandUnsubscribe |
|
| CommandUtils |
Helper class to work with commands.
|
| CompactionStatsImpl |
Statistics about compaction.
|
| CompletableFutureCancellationHandler |
Implements cancellation and timeout support for CompletableFutures.
|
| CompressionCodec |
Generic compression codec interface.
|
| CompressionCodecLZ4 |
LZ4 Compression.
|
| CompressionCodecNone |
No compression.
|
| CompressionCodecProvider |
Provider of compression codecs used in Pulsar.
|
| CompressionCodecSnappy |
Snappy Compression.
|
| CompressionCodecZLib |
ZLib Compression.
|
| CompressionCodecZstd |
Zstandard Compression.
|
| CompressionType |
|
| ConcurrentBitSet |
Safe multithreaded version of BitSet.
|
| ConcurrentBitSetRecyclable |
Safe multithreaded version of BitSet and leverage netty recycler.
|
| ConcurrentLongHashMap<V> |
Map from long to an Object.
|
| ConcurrentLongHashMap.Builder<T> |
Builder of ConcurrentLongHashMap.
|
| ConcurrentLongHashMap.EntryProcessor<V> |
Processor for one key-value entry, where the key is long.
|
| ConcurrentLongLongPairHashMap |
Concurrent hash map where both keys and values are composed of pairs of longs.
|
| ConcurrentLongLongPairHashMap.BiConsumerLongPair |
A BiConsumer Long pair.
|
| ConcurrentLongLongPairHashMap.Builder |
Builder of ConcurrentLongLongPairHashMap.
|
| ConcurrentLongLongPairHashMap.LongLongPairFunction |
A Long pair function.
|
| ConcurrentLongLongPairHashMap.LongLongPairPredicate |
A Long pair predicate.
|
| ConcurrentLongLongPairHashMap.LongPair |
A pair of long values.
|
| ConcurrentLongPairSet |
Concurrent hash set where values are composed of pairs of longs.
|
| ConcurrentLongPairSet.Builder |
Builder of ConcurrentLongPairSet.
|
| ConcurrentLongPairSet.ConsumerLong |
Represents a function that accepts an object of the LongPair type.
|
| ConcurrentLongPairSet.LongPair |
Class representing two long values.
|
| ConcurrentLongPairSet.LongPairConsumer |
Represents a function that accepts two long arguments.
|
| ConcurrentOpenHashMap<K,V> |
Concurrent hash map.
|
| ConcurrentOpenHashMap.Builder<K,V> |
Builder of ConcurrentOpenHashMap.
|
| ConcurrentOpenHashSet<V> |
Concurrent hash set.
|
| ConcurrentOpenHashSet.Builder<V> |
Builder of ConcurrentOpenHashSet.
|
| ConcurrentOpenLongPairRangeSet<T extends java.lang.Comparable<T>> |
|
| ConcurrentSortedLongPairSet |
Sorted concurrent LongPairSet which is not fully accurate in sorting.
|
| ConfigFieldDefinition |
Information about a Pulsar connector config field.
|
| Constants |
Definition of constants.
|
| ConsumerStatsImpl |
Consumer statistics.
|
| DataURLStreamHandler |
Extension of the URLStreamHandler class to handle all stream protocol handlers.
|
| DateFormatter |
Date-time String formatter utility class.
|
| DefaultSslContextBuilder |
|
| DeleteSchemaResponse |
Response for schema deletion.
|
| DnsResolverUtil |
|
| DomainType |
Domain types differentiated by Mozilla Public Suffix List.
|
| EmptyVersion |
Empty schema version.
|
| EncryptionKeys |
|
| EnsemblePlacementPolicyConfig |
|
| EnsemblePlacementPolicyConfig.ParseEnsemblePlacementPolicyConfigException |
|
| EventLoopUtil |
|
| EventsTopicNames |
|
| EventType |
Pulsar system event type.
|
| FailureDomainImpl |
The data of a failure domain configuration in a cluster.
|
| FailureDomainImpl.FailureDomainImplBuilder |
|
| FeatureFlags |
|
| FieldParser |
Generic value converter.
|
| FileModifiedTimeUpdater |
Class working with file's modified time.
|
| FileUtils |
A utility class containing a few useful static methods to do typical IO
operations.
|
| FunctionDefinition |
Basic information about a Pulsar function.
|
| FunctionInstanceStatsDataBaseImpl |
Function instance statistics data base.
|
| FunctionInstanceStatsDataImpl |
Function instance statistics data.
|
| FunctionInstanceStatsImpl |
Function instance statistics.
|
| FunctionStatsImpl |
Statistics for Pulsar Function.
|
| FunctionStatusUtil |
|
| FutureUtil |
This class is aimed at simplifying work with CompletableFuture.
|
| GetAllVersionsSchemaResponse |
Response containing all schemas.
|
| GetSchemaResponse |
Response containing information about a schema.
|
| GrowableArrayBlockingQueue<T> |
This implements a BlockingQueue backed by an array with no fixed capacity.
|
| GrowablePriorityLongPairQueue |
An unbounded priority queue based on a min heap where values are composed of pairs of longs.
|
| GrowablePriorityLongPairQueue.LongPair |
Class representing two long values.
|
| GrowablePriorityLongPairQueue.LongPairConsumer |
Represents a function that accepts two long arguments.
|
| GrowablePriorityLongPairQueue.LongPairPredicate |
Predicate to checks for a key-value pair where both of them have long types.
|
| Hash |
This interface declares a hash function.
|
| HierarchyTopicPolicies |
Topic policy hierarchy value container.
|
| InetAddressUtils |
A collection of utilities relating to InetAddresses.
|
| InterceptException |
Base exception for the broker interceptor.
|
| IntRange |
|
| JAASCredentialsContainer |
JAAS Credentials Container.
|
| JsonIgnorePropertiesMixIn |
|
| JvmDefaultGCMetricsLogger |
|
| JvmG1GCMetricsLogger |
Logger for the JVM G1 GC metrics.
|
| JvmGCMetricsLogger |
JvmGCMetricsLogger can be implemented for each specific GC type which retrieves GC count and pause time and
logs it into metrics.
|
| JvmMetrics |
This class is responsible for providing JVM metrics.
|
| JvmUsage |
JvmUsage represents set of resources that are specific to JVM and are used by broker, load balancing need to
know this detail.
|
| KerberosName |
This class implements parsing and handling of Kerberos principal names.
|
| KerberosName.BadFormatString |
|
| KerberosName.NoMatchingRule |
|
| KeyLongValue |
|
| KeyManagerProxy |
This class wraps X509ExtendedKeyManager and gives opportunity to refresh key-manager with refreshed certs
without changing SslContext.
|
| KeySharedMeta |
|
| KeySharedMode |
|
| KeyStoreHolder |
Holder for the secure key store.
|
| KeyStoreSSLContext |
KeyStoreSSLContext that mainly wrap a SSLContext to provide SSL context for both webservice and netty.
|
| KeyStoreSSLContext.Mode |
Connection Mode for TLS.
|
| KeyValue |
|
| KeyValueSchemaInfo |
Util class for processing key/value schema info.
|
| LatestVersion |
Latest schema version.
|
| LoadReport |
|
| LoadReportDeserializer |
Deserializer for a load report.
|
| LocalBrokerData |
Contains all the data that is maintained locally on each broker.
|
| LocalPolicies |
Local policies.
|
| LongPairRangeSet<T extends java.lang.Comparable<T>> |
A set comprising zero or more ranges type of key-value pair.
|
| LongPairRangeSet.DefaultRangeSet<T extends java.lang.Comparable<T>> |
Generic implementation of a default range set.
|
| LongPairRangeSet.LongPair |
This class is a simple key-value data structure.
|
| LongPairRangeSet.LongPairConsumer<T> |
Represents a function that accepts two long arguments and produces a result.
|
| LongPairRangeSet.RangeProcessor<T extends java.lang.Comparable<T>> |
The interface exposing a method for processing of ranges.
|
| LongPairSet |
Hash set where values are composed of pairs of longs.
|
| LongPairSet.LongPairFunction<T> |
Represents a function that accepts two long arguments and produces a result.
|
| LongPairSet.LongPairPredicate |
Predicate to checks for a key-value pair where both of them have long types.
|
| LongSchemaVersion |
Long schema version.
|
| LongSchemaVersionResponse |
Response containing the schema version field.
|
| LookupData |
This class encapsulates lookup data.
|
| ManagedLedgerPayloadProcessor |
|
| ManagedLedgerPayloadProcessor.Processor |
|
| Markers |
|
| MarkersMessageIdData |
|
| MarkerType |
|
| MessageIdData |
|
| MessageMetadata |
|
| MessageParser |
Helper class to work with a raw Pulsar entry payload.
|
| MessageParser.MessageProcessor |
Definition of an interface to process a raw Pulsar entry payload.
|
| Metadata |
Validator for metadata configuration.
|
| MetricsMixIn |
|
| Murmur3_32Hash |
Implementation of the MurmurHash3 non-cryptographic hash function.
|
| NamedEntity |
|
| NamespaceBundleStatsComparator |
|
| NamespaceIsolationDataImpl |
The data of namespace isolation configuration.
|
| NamespaceIsolationDataImpl.NamespaceIsolationDataImplBuilder |
|
| NamespaceIsolationPolicies |
Namespace isolation policies.
|
| NamespaceIsolationPolicy |
Namespace isolation policy.
|
| NamespaceIsolationPolicyImpl |
Implementation of the namespace isolation policy.
|
| NamespaceName |
Parser of a value from the namespace field provided in configuration.
|
| NamespaceOperation |
Namespace authorization operations.
|
| NamespaceUsage |
this class represents usages of resources used by a namespace, this is an aggregate of all the topics and queues on
the namespace.
|
| NarClassLoader |
A ClassLoader for loading NARs (NiFi archives).
|
| NarClassLoaderBuilder |
NarClassLoader builder class.
|
| NarUnpacker |
Helper class to unpack NARs.
|
| NetSslContextBuilder |
Similar to `DefaultSslContextBuilder`, which build `javax.net.ssl.SSLContext` for web service.
|
| NettyClientSslContextRefresher |
SSL context builder for Netty Client side.
|
| NettyFutureUtil |
Contains utility methods for working with Netty Futures.
|
| NettyServerSslContextBuilder |
SSL context builder for Netty Server side.
|
| NettySSLContextAutoRefreshBuilder |
SSL context builder for Netty.
|
| NonPersistentPartitionedTopicStatsImpl |
Statistics for a non-persistent partitioned topic.
|
| NonPersistentPublisherStatsImpl |
Non-persistent publisher statistics.
|
| NonPersistentReplicatorStatsImpl |
Statistics for a non-persistent replicator.
|
| NonPersistentSubscriptionStatsImpl |
Statistics for subscription to non-persistent topics.
|
| NonPersistentTopicStatsImpl |
Statistics for a non-persistent topic.
|
| NoopHostnameVerifier |
|
| NumberFormat |
Custom number formatter for io.netty.buffer.ByteBuf.
|
| ObjectMapperFactory |
|
| OffloadPoliciesImpl |
Definition of the offload policies.
|
| OffloadPoliciesImpl.OffloadPoliciesImplBuilder |
|
| OptionalProxyProtocolDecoder |
Decoder that added whether a new connection is prefixed with the ProxyProtocol.
|
| PartitionedTopicStatsImpl |
Statistics for a partitioned topic.
|
| PersistentOfflineTopicStats |
This object is populated using meta data in zookeeper without actually bringing the topic online.
|
| PersistentOfflineTopicStats.CursorDetails |
Details about a cursor.
|
| PersistentOfflineTopicStats.LedgerDetails |
Details about a ledger.
|
| PersistentTopicStats |
Maintain compatibility with previous class name.
|
| PoliciesUtil |
Utils of Pulsar policies.
|
| PolicyHierarchyValue<T> |
Policy value holder for different hierarchy level.
|
| PolicyName |
PolicyName authorization operations.
|
| PolicyOperation |
PolicyOperation authorization operations.
|
| PolicyPath |
Policy path utilities.
|
| PostSchemaResponse |
Response with the version of a schema.
|
| ProducerAccessMode |
|
| ProtobufNativeSchemaData |
POJO class used for serialize to json-string for SchemaInfo.schema when SchemaType is SchemaType.PROTOBUF_NATIVE.
|
| ProtocolVersion |
|
| PublicSuffixList |
Public suffix is a set of DNS names or wildcards concatenated with dots.
|
| PublicSuffixMatcher |
Utility class that can test if DNS names match the content of the Public Suffix List.
|
| PublisherStatsImpl |
Statistics about a publisher.
|
| PulsarByteBufAllocator |
Holder of a ByteBuf allocator.
|
| PulsarDecoder |
Basic implementation of the channel handler to process inbound Pulsar data.
|
| PulsarEvent |
Pulsar base event.
|
| PulsarHandler |
Implementation of the channel handler to process inbound Pulsar data.
|
| PulsarURLStreamHandlerFactory |
This class defines a factory for URL stream
protocol handlers.
|
| PulsarVersion |
|
| Rate |
|
| RateLimiter |
A Rate Limiter that distributes permits at a configurable rate.
|
| RateLimiter.RateLimiterBuilder |
|
| RateLimitFunction |
Function use when rate limiter renew permit.
|
| RawMessage |
View of a message that exposes the internal direct-memory buffer for more efficient processing.
|
| RawMessageId |
Interface to uniquely identify an internal raw message.
|
| RawMessageIdImpl |
|
| RawMessageImpl |
|
| ReferenceCountedMessageMetadata |
Class representing a reference-counted object that requires explicit deallocation.
|
| Reflections |
Utils related to reflections.
|
| RelativeTimeUtil |
Parser for relative time.
|
| ReplicatedSubscriptionsSnapshot |
|
| ReplicatedSubscriptionsSnapshotRequest |
|
| ReplicatedSubscriptionsSnapshotResponse |
|
| ReplicatedSubscriptionsUpdate |
|
| ReplicatorStatsImpl |
Statistics about a replicator.
|
| ResourceQuotaMixIn |
|
| ResourceUnitRanking |
The class containing information about system resources, allocated quota, and loaded bundles.
|
| RestException |
Exception used to provide better error messages to clients of the REST API.
|
| Runnables |
|
| SafeCollectionUtils |
Safe collection utils.
|
| SaslConstants |
SASL Constants.
|
| Schema |
|
| Schema.Type |
|
| SchemaData |
Schema data.
|
| SchemaHash |
Schema hash wrapper with a HashCode inner type.
|
| SchemaInfoImpl |
Information about the schema.
|
| SchemaStorage |
Schema storage.
|
| SchemaUtils |
Utils for schemas.
|
| SchemaVersion |
Schema version.
|
| SecurityUtility |
Helper class for the security domain.
|
| SegmentedLongArray |
|
| ServerError |
|
| ServiceUnitId |
Basic interface for service unit's identification.
|
| ServiceURI |
ServiceURI represents service uri within pulsar cluster.
|
| SimpleTextOutputStream |
Format strings and numbers into a ByteBuf without any memory allocation.
|
| SingleMessageMetadata |
|
| SinkStatusUtil |
|
| SourceStatusUtil |
|
| SslContextAutoRefreshBuilder<T> |
Auto refresher and builder of SSLContext.
|
| SSLContextValidatorEngine |
SSLContextValidatorEngine to validate 2 SSlContext.
|
| SSLContextValidatorEngine.SSLEngineProvider |
|
| StoredSchema |
Stored schema with version.
|
| Subscription |
|
| SubscriptionStatsImpl |
Statistics about subscription.
|
| SystemResourceUsage |
This class represents a object which reflects system resource usage per resource and the upper limit on the resource.
|
| SystemResourceUsage.ResourceType |
Definition of possible resource types.
|
| TenantInfoImpl |
Information of admin roles and allowed clusters for tenant.
|
| TenantInfoImpl.TenantInfoImplBuilder |
|
| TenantOperation |
Tenant authorization operations.
|
| TGTRefreshThread |
TGT Refresh Thread.
|
| ThreadDumpUtil |
Adapted from Hadoop TimedOutTestsListener.
|
| TlsHostnameVerifier |
|
| TopicName |
Encapsulate the parsing of the completeTopicName name.
|
| TopicOperation |
Topic authorization operations.
|
| TopicPolicies |
Topic policies.
|
| TopicPoliciesEvent |
Topic policies event.
|
| TopicStatsImpl |
Statistics for a Pulsar topic.
|
| TripleLongPriorityQueue |
Provides a priority-queue implementation specialized on items composed by 3 longs.
|
| TrustManagerProxy |
This class wraps X509ExtendedTrustManager and gives opportunity to refresh Trust-manager with refreshed certs
without changing SslContext.
|
| TxnAction |
|
| UpdateOptionsImpl |
Options while updating the sink.
|
| URL |
Wrapper around java.net.URL to improve usability.
|
| Utils |
Helper class to work with configuration.
|
| ZStdRawCompressor |
Expose ZstdFrameCompressor which is a package protected class.
|
| ZStdRawDecompressor |
Exposes ZstdFrameDecompressor which is package protected.
|