You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by li...@apache.org on 2022/05/16 06:58:18 UTC

[pulsar] branch revert-15172-doc_update_Kerberos created (now 5345145a96a)

This is an automated email from the ASF dual-hosted git repository.

liuyu pushed a change to branch revert-15172-doc_update_Kerberos
in repository https://gitbox.apache.org/repos/asf/pulsar.git


      at 5345145a96a Revert "[feat][doc]Add saslJaasServerRoleTokenSignerSecret parameter in security-kerberos.md (#15172)"

This branch includes the following new commits:

     new 5345145a96a Revert "[feat][doc]Add saslJaasServerRoleTokenSignerSecret parameter in security-kerberos.md (#15172)"

The 1 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.



[pulsar] 01/01: Revert "[feat][doc]Add saslJaasServerRoleTokenSignerSecret parameter in security-kerberos.md (#15172)"

Posted by li...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

liuyu pushed a commit to branch revert-15172-doc_update_Kerberos
in repository https://gitbox.apache.org/repos/asf/pulsar.git

commit 5345145a96af2a3f90ad862a76f9821962ee8606
Author: Anonymitaet <50...@users.noreply.github.com>
AuthorDate: Mon May 16 14:58:12 2022 +0800

    Revert "[feat][doc]Add saslJaasServerRoleTokenSignerSecret parameter in security-kerberos.md (#15172)"
    
    This reverts commit 4ede97509dc90d0ef616c5ea50de7105bbf16f84.
---
 site2/docs/reference-configuration.md | 518 +++++++++++++++++-----------------
 site2/docs/security-kerberos.md       |   6 +-
 2 files changed, 258 insertions(+), 266 deletions(-)

diff --git a/site2/docs/reference-configuration.md b/site2/docs/reference-configuration.md
index 7d58db0be76..c4a42240428 100644
--- a/site2/docs/reference-configuration.md
+++ b/site2/docs/reference-configuration.md
@@ -134,261 +134,258 @@ BookKeeper is a replicated log storage system that Pulsar uses for durable stora
 
 Pulsar brokers are responsible for handling incoming messages from producers, dispatching messages to consumers, replicating data between clusters, and more.
 
-|Name| Description                                                                                                                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|---|------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------- [...]
-|advertisedListeners| Specify multiple advertised listeners for the broker.<br /><br />The format is `<listener_name>:pulsar://<host>:<port>`.<br /><br />If there are multiple listeners, separate them with commas.<br /><br />**Note**: do not use this configuration with `advertisedAddress` and `brokerServicePort`. If the value of this configuration is empty, the broker uses `advertisedAddress` and `brokerServicePort`                                                                          [...]
-|internalListenerName| Specify the internal listener name for the broker.<br /><br />**Note**: the listener name must be contained in `advertisedListeners`.<br /><br /> If the value of this configuration is empty, the broker uses the first listener as the internal listener.                                                                                                                                                                                                                           [...]
-|authenticateOriginalAuthData| If this flag is set to `true`, the broker authenticates the original Auth data; else it just accepts the originalPrincipal and authorizes it (if required).                                                                                                                                                                                                                                                                                                                   [...]
-|enablePersistentTopics| Whether persistent topics are enabled on the broker                                                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|enableNonPersistentTopics| Whether non-persistent topics are enabled on the broker                                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|functionsWorkerEnabled| Whether the Pulsar Functions worker service is enabled in the broker                                                                                                                                                                                                                                                                                                                                                                                                                [...]
-|exposePublisherStats| Whether to enable topic level metrics.                                                                                                                                                                                                                                                                                                                                                                                                                                                [...]
-|statsUpdateFrequencyInSecs|| 60                                                                                                                                                                                                                                                                                                                                                                                                                                                                             [...]
-|statsUpdateInitialDelayInSecs|| 60                                                                                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|metadataStoreUrl| Metadata store quorum connection string                                                                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|metadataStoreCacheExpirySeconds| Metadata store cache expiry time in seconds                                                                                                                                                                                                                                                                                                                                                                                                                                [...]
-|configurationMetadataStoreUrl| Configuration store connection string (as a comma-separated list)                                                                                                                                                                                                                                                                                                                                                                                                            [...]
-|brokerServicePort| Broker data port                                                                                                                                                                                                                                                                                                                                                                                                                                                                         [...]
-|brokerServicePortTls| Broker data port for TLS                                                                                                                                                                                                                                                                                                                                                                                                                                                              [...]
-|webServicePort| Port to use to server HTTP request                                                                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|webServicePortTls| Port to use to server HTTPS request                                                                                                                                                                                                                                                                                                                                                                                                                                                      [...]
-|webSocketServiceEnabled| Enable the WebSocket API service in broker                                                                                                                                                                                                                                                                                                                                                                                                                                         [...]
-|webSocketNumIoThreads| The number of IO threads in Pulsar Client used in WebSocket proxy.                                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|webSocketConnectionsPerBroker| The number of connections per Broker in Pulsar Client used in WebSocket proxy.                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|webSocketSessionIdleTimeoutMillis| Time in milliseconds that idle WebSocket session times out.                                                                                                                                                                                                                                                                                                                                                                                                              [...]
-|webSocketMaxTextFrameSize| The maximum size of a text message during parsing in WebSocket proxy.                                                                                                                                                                                                                                                                                                                                                                                                            [...]
-|exposeTopicLevelMetricsInPrometheus| Whether to enable topic level metrics.                                                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|exposeConsumerLevelMetricsInPrometheus| Whether to enable consumer level metrics.                                                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|jvmGCMetricsLoggerClassName| Classname of Pluggable JVM GC metrics logger that can log GC specific metrics.                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|bindAddress| Hostname or IP address the service binds on, default is 0.0.0.0.                                                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|bindAddresses| Additional Hostname or IP addresses the service binds on: `listener_name:scheme://host:port,...`.                                                                                                                                                                                                                                                                                                                                                                                            [...]
-|advertisedAddress| Hostname or IP address the service advertises to the outside world. If not set, the value of `InetAddress.getLocalHost().getHostName()` is used.                                                                                                                                                                                                                                                                                                                                         [...]
-|clusterName| Name of the cluster to which this broker belongs to                                                                                                                                                                                                                                                                                                                                                                                                                                            [...]
-|maxTenants| The maximum number of tenants that can be created in each Pulsar cluster. When the number of tenants reaches the threshold, the broker rejects the request of creating a new tenant. The default value 0 disables the check.                                                                                                                                                                                                                                                                    [...]
-|brokerDeduplicationEnabled| Sets the default behavior for message deduplication in the broker. If enabled, the broker will reject messages that were already stored in the topic. This setting can be overridden on a per-namespace basis.                                                                                                                                                                                                                                                                  [...]
-|brokerDeduplicationMaxNumberOfProducers| The maximum number of producers for which information will be stored for deduplication purposes.                                                                                                                                                                                                                                                                                                                                                                   [...]
-|brokerDeduplicationEntriesInterval| The number of entries after which a deduplication informational snapshot is taken. A larger interval will lead to fewer snapshots being taken, though this would also lengthen the topic recovery time (the time required for entries published after the snapshot to be replayed).                                                                                                                                                                                     [...]
-|brokerDeduplicationSnapshotIntervalSeconds| The time period after which a deduplication informational snapshot is taken. It runs simultaneously with `brokerDeduplicationEntriesInterval`.                                                                                                                                                                                                                                                                                                                  [...]
-|brokerDeduplicationProducerInactivityTimeoutMinutes| The time of inactivity (in minutes) after which the broker will discard deduplication information related to a disconnected producer.                                                                                                                                                                                                                                                                                                                  [...]
-|brokerDeduplicationSnapshotFrequencyInSeconds| How often is the thread pool scheduled to check whether a snapshot needs to be taken. The value of `0` means it is disabled.                                                                                                                                                                                                                                                                                                                                 [...]
-|dispatchThrottlingRateInMsg| Dispatch throttling-limit of messages for a broker (per second). 0 means the dispatch throttling-limit is disabled.                                                                                                                                                                                                                                                                                                                                                            [...]
-|dispatchThrottlingRateInByte| Dispatch throttling-limit of bytes for a broker (per second). 0 means the dispatch throttling-limit is disabled.                                                                                                                                                                                                                                                                                                                                                              [...]
-|dispatchThrottlingRatePerTopicInMsg| Dispatch throttling-limit of messages for every topic (per second). 0 means the dispatch throttling-limit is disabled.                                                                                                                                                                                                                                                                                                                                                 [...]
-|dispatchThrottlingRatePerTopicInByte| Dispatch throttling-limit of bytes for every topic (per second). 0 means the dispatch throttling-limit is disabled.                                                                                                                                                                                                                                                                                                                                                   [...]
-|dispatchThrottlingOnBatchMessageEnabled| Apply dispatch rate limiting on batch message instead individual messages with in batch message. (Default is disabled).                                                                                                                                                                                                                                                                                                                                            [...]
-|dispatchThrottlingRateRelativeToPublishRate| Enable dispatch rate-limiting relative to publish rate.                                                                                                                                                                                                                                                                                                                                                                                                        [...]
-|dispatchThrottlingRatePerSubscriptionInMsg| Dispatch throttling-limit of messages for a subscription. 0 means the dispatch throttling-limit is disabled.                                                                                                                                                                                                                                                                                                                                                    [...]
-|dispatchThrottlingRatePerSubscriptionInByte| Dispatch throttling-limit of bytes for a subscription. 0 means the dispatch throttling-limit is disabled.                                                                                                                                                                                                                                                                                                                                                      [...]
-|dispatchThrottlingRatePerReplicatorInMsg| The default messages per second dispatch throttling-limit for every replicator in replication. The value of `0` means disabling replication message dispatch-throttling                                                                                                                                                                                                                                                                                           [...]
-|dispatchThrottlingRatePerReplicatorInByte| The default bytes per second dispatch throttling-limit for every replicator in replication. The value of `0` means disabling replication message-byte dispatch-throttling                                                                                                                                                                                                                                                                                        [...]
-|metadataStoreSessionTimeoutMillis| Metadata store session timeout in milliseconds                                                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|brokerShutdownTimeoutMs| Time to wait for broker graceful shutdown. After this time elapses, the process will be killed                                                                                                                                                                                                                                                                                                                                                                                     [...]
-|skipBrokerShutdownOnOOM| Flag to skip broker shutdown when broker handles Out of memory error.                                                                                                                                                                                                                                                                                                                                                                                                              [...]
-|backlogQuotaCheckEnabled| Enable backlog quota check. Enforces action on topic when the quota is reached                                                                                                                                                                                                                                                                                                                                                                                                    [...]
-|backlogQuotaCheckIntervalInSeconds| How often to check for topics that have reached the quota                                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|backlogQuotaDefaultLimitBytes| The default per-topic backlog quota limit. Being less than 0 means no limitation. By default, it is -1.                                                                                                                                                                                                                                                                                                                                                                      [...]
-|backlogQuotaDefaultRetentionPolicy| The defaulted backlog quota retention policy. By Default, it is `producer_request_hold`. <li>'producer_request_hold' Policy which holds producer's send request until the resource becomes available (or holding times out)</li> <li>'producer_exception' Policy which throws `javax.jms.ResourceAllocationException` to the producer </li><li>'consumer_backlog_eviction' Policy which evicts the oldest message from the slowest consumer's backlog</li>              [...]
-|allowAutoTopicCreation| Enable topic auto creation if a new producer or consumer connected                                                                                                                                                                                                                                                                                                                                                                                                                  [...]
-|allowAutoTopicCreationType| The type of topic that is allowed to be automatically created.(partitioned/non-partitioned)                                                                                                                                                                                                                                                                                                                                                                                     [...]
-|allowAutoSubscriptionCreation| Enable subscription auto creation if a new consumer connected                                                                                                                                                                                                                                                                                                                                                                                                                [...]
-|defaultNumPartitions| The number of partitioned topics that is allowed to be automatically created if `allowAutoTopicCreationType` is partitioned                                                                                                                                                                                                                                                                                                                                                           [...]
-|brokerDeleteInactiveTopicsEnabled| Enable the deletion of inactive topics. If topics are not consumed for some while, these inactive topics might be cleaned up. Deleting inactive topics is enabled by default. The default period is 1 minute.                                                                                                                                                                                                                                                            [...]
-|brokerDeleteInactiveTopicsFrequencySeconds| How often to check for inactive topics                                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-| brokerDeleteInactiveTopicsMode | Set the mode to delete inactive topics. <li> `delete_when_no_subscriptions`: delete the topic which has no subscriptions or active producers. <li> `delete_when_subscriptions_caught_up`: delete the topic whose subscriptions have no backlogs and which has no active producers or consumers.                                                                                                                                                                           [...]
-| brokerDeleteInactiveTopicsMaxInactiveDurationSeconds | Set the maximum duration for inactive topics. If it is not specified, the `brokerDeleteInactiveTopicsFrequencySeconds` parameter is adopted.                                                                                                                                                                                                                                                                                                        [...]
-|forceDeleteTenantAllowed| Enable you to delete a tenant forcefully.                                                                                                                                                                                                                                                                                                                                                                                                                                         [...]
-|forceDeleteNamespaceAllowed| Enable you to delete a namespace forcefully.                                                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|messageExpiryCheckIntervalInMinutes| The frequency of proactively checking and purging expired messages.                                                                                                                                                                                                                                                                                                                                                                                                    [...]
-|brokerServiceCompactionMonitorIntervalInSeconds| Interval between checks to determine whether topics with compaction policies need compaction.                                                                                                                                                                                                                                                                                                                                                              [...]
-brokerServiceCompactionThresholdInBytes| If the estimated backlog size is greater than this threshold, compression is triggered.<br /><br />Set this threshold to 0 means disabling the compression check.                                                                                                                                                                                                                                                                                                   [...]
-|delayedDeliveryEnabled| Whether to enable the delayed delivery for messages. If disabled, messages will be immediately delivered and there will be no tracking overhead.                                                                                                                                                                                                                                                                                                                                    [...]
-|delayedDeliveryTickTimeMillis| Control the tick time for retrying on delayed delivery, which affects the accuracy of the delivery time compared to the scheduled time. By default, it is 1 second.                                                                                                                                                                                                                                                                                                          [...]
-|activeConsumerFailoverDelayTimeMillis| How long to delay rewinding cursor and dispatching messages when active consumer is changed.                                                                                                                                                                                                                                                                                                                                                                         [...]
-|clientLibraryVersionCheckEnabled| Enable check for minimum allowed client library version                                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|clientLibraryVersionCheckAllowUnversioned| Allow client libraries with no version information                                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|statusFilePath| Path for the file used to determine the rotation status for the broker when responding to service discovery health checks                                                                                                                                                                                                                                                                                                                                                                   [...]
-|preferLaterVersions| If true, (and ModularLoadManagerImpl is being used), the load manager will attempt to use only brokers running the latest software version (to minimize impact to bundles)                                                                                                                                                                                                                                                                                                             [...]
-|maxNumPartitionsPerPartitionedTopic| Max number of partitions per partitioned topic. Use 0 or negative number to disable the check                                                                                                                                                                                                                                                                                                                                                                          [...]
-| maxSubscriptionsPerTopic | Maximum number of subscriptions allowed to subscribe to a topic. Once this limit reaches, the broker rejects new subscriptions until the number of subscriptions decreases. When the value is set to 0, the limit check is disabled.                                                                                                                                                                                                                                            [...]
-| maxProducersPerTopic | Maximum number of producers allowed to connect to a topic. Once this limit reaches, the broker rejects new producers until the number of connected producers decreases. When the value is set to 0, the limit check is disabled.                                                                                                                                                                                                                                                    [...]
-| maxConsumersPerTopic | Maximum number of consumers allowed to connect to a topic. Once this limit reaches, the broker rejects new consumers until the number of connected consumers decreases. When the value is set to 0, the limit check is disabled.                                                                                                                                                                                                                                                    [...]
-| maxConsumersPerSubscription | Maximum number of consumers allowed to connect to a subscription. Once this limit reaches, the broker rejects new consumers until the number of connected consumers decreases. When the value is set to 0, the limit check is disabled.                                                                                                                                                                                                                                      [...]
-|tlsCertificateFilePath| Path for the TLS certificate file                                                                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|tlsKeyFilePath| Path for the TLS private key file                                                                                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|tlsTrustCertsFilePath| Path for the trusted TLS certificate file. This cert is used to verify that any certs presented by connecting clients are signed by a certificate authority. If this verification fails, then the certs are untrusted and the connections are dropped.                                                                                                                                                                                                                               [...]
-|tlsAllowInsecureConnection| Accept untrusted TLS certificate from client. If it is set to `true`, a client with a cert which cannot be verified with the 'tlsTrustCertsFilePath' cert will be allowed to connect to the server, though the cert will not be used for client authentication.                                                                                                                                                                                                                 [...]
-|tlsProtocols| Specify the tls protocols the broker will use to negotiate during TLS Handshake. Multiple values can be specified, separated by commas. Example:- ```TLSv1.3```, ```TLSv1.2```                                                                                                                                                                                                                                                                                                                [...]
-|tlsCiphers| Specify the tls cipher the broker will use to negotiate during TLS Handshake. Multiple values can be specified, separated by commas. Example:- ```TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256```                                                                                                                                                                                                                                                                                                      [...]
-|tlsEnabledWithKeyStore| Enable TLS with KeyStore type configuration in broker                                                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|tlsProvider| TLS Provider for KeyStore type                                                                                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|tlsKeyStoreType| LS KeyStore type configuration in broker: JKS, PKCS12                                                                                                                                                                                                                                                                                                                                                                                                                                      [...]
-|tlsKeyStore| TLS KeyStore path in broker                                                                                                                                                                                                                                                                                                                                                                                                                                                                    [...]
-|tlsKeyStorePassword| TLS KeyStore password for broker                                                                                                                                                                                                                                                                                                                                                                                                                                                       [...]
-|brokerClientTlsEnabledWithKeyStore| Whether internal client use KeyStore type to authenticate with Pulsar brokers                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|brokerClientSslProvider| The TLS Provider used by internal client to authenticate with other Pulsar brokers                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|brokerClientTlsTrustStoreType| TLS TrustStore type configuration for internal client: JKS, PKCS12, used by the internal client to authenticate with Pulsar brokers                                                                                                                                                                                                                                                                                                                                          [...]
-|brokerClientTlsTrustStore| TLS TrustStore path for internal client, used by the internal client to authenticate with Pulsar brokers                                                                                                                                                                                                                                                                                                                                                                         [...]
-|brokerClientTlsTrustStorePassword| TLS TrustStore password for internal client, used by the internal client to authenticate with Pulsar brokers                                                                                                                                                                                                                                                                                                                                                             [...]
-|brokerClientTlsCiphers| Specify the tls cipher the internal client will use to negotiate during TLS Handshake. (a comma-separated list of ciphers) e.g.  [TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256]                                                                                                                                                                                                                                                                                                            [...]
-|brokerClientTlsProtocols| Specify the tls protocols the broker will use to negotiate during TLS handshake. (a comma-separated list of protocol names). e.g.  `TLSv1.3`, `TLSv1.2`                                                                                                                                                                                                                                                                                                                           [...]
-| metadataStoreBatchingEnabled | Enable metadata operations batching.                                                                                                                                                                                                                                                                                                                                                                                                                                        [...]
-| metadataStoreBatchingMaxDelayMillis | Maximum delay to impose on batching grouping.                                                                                                                                                                                                                                                                                                                                                                                                                        [...]
-| metadataStoreBatchingMaxOperations | Maximum number of operations to include in a singular batch.                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-| metadataStoreBatchingMaxSizeKb | Maximum size of a batch.                                                                                                                                                                                                                                                                                                                                                                                                                                                  [...]
-|ttlDurationDefaultInSeconds| The default Time to Live (TTL) for namespaces if the TTL is not configured at namespace policies. When the value is set to `0`, TTL is disabled. By default, TTL is disabled.                                                                                                                                                                                                                                                                                                  [...]
-|tokenSettingPrefix| Configure the prefix of the token-related settings, such as `tokenSecretKey`, `tokenPublicKey`, `tokenAuthClaim`, `tokenPublicAlg`, `tokenAudienceClaim`, and `tokenAudience`.                                                                                                                                                                                                                                                                                                          [...]
-|tokenSecretKey| Configure the secret key to be used to validate auth tokens. The key can be specified like: `tokenSecretKey=data:;base64,xxxxxxxxx` or `tokenSecretKey=file:///my/secret.key`.  Note: key file must be DER-encoded.                                                                                                                                                                                                                                                                         [...]
-|tokenPublicKey| Configure the public key to be used to validate auth tokens. The key can be specified like: `tokenPublicKey=data:;base64,xxxxxxxxx` or `tokenPublicKey=file:///my/secret.key`.  Note: key file must be DER-encoded.                                                                                                                                                                                                                                                                         [...]
-|tokenPublicAlg| Configure the algorithm to be used to validate auth tokens. This can be any of the asymettric algorithms supported by Java JWT (https://github.com/jwtk/jjwt#signature-algorithms-keys)                                                                                                                                                                                                                                                                                                     [...]
-|tokenAuthClaim| Specify which of the token's claims will be used as the authentication "principal" or "role". The default "sub" claim will be used if this is left blank                                                                                                                                                                                                                                                                                                                                    [...]
-|tokenAudienceClaim| The token audience "claim" name, e.g. "aud", that will be used to get the audience from token. If not set, audience will not be verified.                                                                                                                                                                                                                                                                                                                                               [...]
-|tokenAudience| The token audience stands for this broker. The field `tokenAudienceClaim` of a valid token, need contains this.                                                                                                                                                                                                                                                                                                                                                                              [...]
-|saslJaasClientAllowedIds| This is a regexp, which limits the range of possible IDs. These IDs can connect to the broker using SASL. By default, it is set to `SaslConstants.JAAS_CLIENT_ALLOWED_IDS_DEFAULT`, which is ".*pulsar.*", so only clients whose ID contains 'pulsar' are allowed to connect.                                                                                                                                                                                                     [...]
-|saslJaasServerSectionName| Service Principal, for login context name. By default, it is set to `SaslConstants.JAAS_DEFAULT_BROKER_SECTION_NAME`, which is "PulsarBroker".                                                                                                                                                                                                                                                                                                                                   [...]
-|saslJaasServerRoleTokenSignerSecretPath| Secret path for SaslRoleTokenSigner,the Path can be specified like file:///my/saslRoleTokenSignerSecret.key.                                                                                                                                                                                                                                                                                                                                                       [...]
-|maxUnackedMessagesPerConsumer| Max number of unacknowledged messages allowed to receive messages by a consumer on a shared subscription. Broker will stop sending messages to consumer once, this limit reaches until consumer starts acknowledging messages back. Using a value of 0, is disabling unackeMessage limit check and consumer can receive messages without any restriction                                                                                                                     [...]
-|maxUnackedMessagesPerSubscription| Max number of unacknowledged messages allowed per shared subscription. Broker will stop dispatching messages to all consumers of the subscription once this limit reaches until consumer starts acknowledging messages back and unack count reaches to limit/2. Using a value of 0, is disabling unackedMessage-limit check and dispatcher can dispatch messages without any restriction                                                                                 [...]
-|subscriptionRedeliveryTrackerEnabled| Enable subscription message redelivery tracker                                                                                                                                                                                                                                                                                                                                                                                                                        [...]
+|Name|Description|Default|
+|---|---|---|
+|advertisedListeners|Specify multiple advertised listeners for the broker.<br /><br />The format is `<listener_name>:pulsar://<host>:<port>`.<br /><br />If there are multiple listeners, separate them with commas.<br /><br />**Note**: do not use this configuration with `advertisedAddress` and `brokerServicePort`. If the value of this configuration is empty, the broker uses `advertisedAddress` and `brokerServicePort`|/|
+|internalListenerName|Specify the internal listener name for the broker.<br /><br />**Note**: the listener name must be contained in `advertisedListeners`.<br /><br /> If the value of this configuration is empty, the broker uses the first listener as the internal listener.|/|
+|authenticateOriginalAuthData|  If this flag is set to `true`, the broker authenticates the original Auth data; else it just accepts the originalPrincipal and authorizes it (if required). |false|
+|enablePersistentTopics|  Whether persistent topics are enabled on the broker |true|
+|enableNonPersistentTopics| Whether non-persistent topics are enabled on the broker |true|
+|functionsWorkerEnabled|  Whether the Pulsar Functions worker service is enabled in the broker  |false|
+|exposePublisherStats|Whether to enable topic level metrics.|true|
+|statsUpdateFrequencyInSecs||60|
+|statsUpdateInitialDelayInSecs||60|
+|metadataStoreUrl| Metadata store quorum connection string  ||
+|metadataStoreCacheExpirySeconds|Metadata store cache expiry time in seconds|300|
+|configurationMetadataStoreUrl| Configuration store connection string (as a comma-separated list) ||
+|brokerServicePort| Broker data port  |6650|
+|brokerServicePortTls|  Broker data port for TLS  |6651|
+|webServicePort|  Port to use to server HTTP request  |8080|
+|webServicePortTls| Port to use to server HTTPS request |8443|
+|webSocketServiceEnabled| Enable the WebSocket API service in broker  |false|
+|webSocketNumIoThreads|The number of IO threads in Pulsar Client used in WebSocket proxy.|Runtime.getRuntime().availableProcessors()|
+|webSocketConnectionsPerBroker|The number of connections per Broker in Pulsar Client used in WebSocket proxy.|Runtime.getRuntime().availableProcessors()|
+|webSocketSessionIdleTimeoutMillis|Time in milliseconds that idle WebSocket session times out.|300000|
+|webSocketMaxTextFrameSize|The maximum size of a text message during parsing in WebSocket proxy.|1048576|
+|exposeTopicLevelMetricsInPrometheus|Whether to enable topic level metrics.|true|
+|exposeConsumerLevelMetricsInPrometheus|Whether to enable consumer level metrics.|false|
+|jvmGCMetricsLoggerClassName|Classname of Pluggable JVM GC metrics logger that can log GC specific metrics.|N/A|
+|bindAddress| Hostname or IP address the service binds on, default is 0.0.0.0.  |0.0.0.0|
+|bindAddresses| Additional Hostname or IP addresses the service binds on: `listener_name:scheme://host:port,...`.  ||
+|advertisedAddress| Hostname or IP address the service advertises to the outside world. If not set, the value of `InetAddress.getLocalHost().getHostName()` is used.  ||
+|clusterName| Name of the cluster to which this broker belongs to ||
+|maxTenants|The maximum number of tenants that can be created in each Pulsar cluster. When the number of tenants reaches the threshold, the broker rejects the request of creating a new tenant. The default value 0 disables the check. |0|
+|brokerDeduplicationEnabled|  Sets the default behavior for message deduplication in the broker. If enabled, the broker will reject messages that were already stored in the topic. This setting can be overridden on a per-namespace basis.  |false|
+|brokerDeduplicationMaxNumberOfProducers| The maximum number of producers for which information will be stored for deduplication purposes.  |10000|
+|brokerDeduplicationEntriesInterval|  The number of entries after which a deduplication informational snapshot is taken. A larger interval will lead to fewer snapshots being taken, though this would also lengthen the topic recovery time (the time required for entries published after the snapshot to be replayed). |1000|
+|brokerDeduplicationSnapshotIntervalSeconds| The time period after which a deduplication informational snapshot is taken. It runs simultaneously with `brokerDeduplicationEntriesInterval`. |120|
+|brokerDeduplicationProducerInactivityTimeoutMinutes| The time of inactivity (in minutes) after which the broker will discard deduplication information related to a disconnected producer. |360|
+|brokerDeduplicationSnapshotFrequencyInSeconds| How often is the thread pool scheduled to check whether a snapshot needs to be taken. The value of `0` means it is disabled. |120| 
+|dispatchThrottlingRateInMsg| Dispatch throttling-limit of messages for a broker (per second). 0 means the dispatch throttling-limit is disabled. |0|
+|dispatchThrottlingRateInByte| Dispatch throttling-limit of bytes for a broker (per second). 0 means the dispatch throttling-limit is disabled. |0|
+|dispatchThrottlingRatePerTopicInMsg| Dispatch throttling-limit of messages for every topic (per second). 0 means the dispatch throttling-limit is disabled. |0|
+|dispatchThrottlingRatePerTopicInByte| Dispatch throttling-limit of bytes for every topic (per second). 0 means the dispatch throttling-limit is disabled. |0|
+|dispatchThrottlingOnBatchMessageEnabled|Apply dispatch rate limiting on batch message instead individual messages with in batch message. (Default is disabled). | false|
+|dispatchThrottlingRateRelativeToPublishRate| Enable dispatch rate-limiting relative to publish rate. | false |
+|dispatchThrottlingRatePerSubscriptionInMsg| Dispatch throttling-limit of messages for a subscription. 0 means the dispatch throttling-limit is disabled. |0|
+|dispatchThrottlingRatePerSubscriptionInByte|Dispatch throttling-limit of bytes for a subscription. 0 means the dispatch throttling-limit is disabled.|0|
+|dispatchThrottlingRatePerReplicatorInMsg| The default messages per second dispatch throttling-limit for every replicator in replication. The value of `0` means disabling replication message dispatch-throttling| 0 |
+|dispatchThrottlingRatePerReplicatorInByte| The default bytes per second dispatch throttling-limit for every replicator in replication. The value of `0` means disabling replication message-byte dispatch-throttling| 0 | 
+|metadataStoreSessionTimeoutMillis| Metadata store session timeout in milliseconds |30000|
+|brokerShutdownTimeoutMs| Time to wait for broker graceful shutdown. After this time elapses, the process will be killed  |60000|
+|skipBrokerShutdownOnOOM| Flag to skip broker shutdown when broker handles Out of memory error. |false|
+|backlogQuotaCheckEnabled|  Enable backlog quota check. Enforces action on topic when the quota is reached  |true|
+|backlogQuotaCheckIntervalInSeconds|  How often to check for topics that have reached the quota |60|
+|backlogQuotaDefaultLimitBytes| The default per-topic backlog quota limit. Being less than 0 means no limitation. By default, it is -1. | -1 |
+|backlogQuotaDefaultRetentionPolicy|The defaulted backlog quota retention policy. By Default, it is `producer_request_hold`. <li>'producer_request_hold' Policy which holds producer's send request until the resource becomes available (or holding times out)</li> <li>'producer_exception' Policy which throws `javax.jms.ResourceAllocationException` to the producer </li><li>'consumer_backlog_eviction' Policy which evicts the oldest message from the slowest consumer's backlog</li>|producer_requ [...]
+|allowAutoTopicCreation| Enable topic auto creation if a new producer or consumer connected |true|
+|allowAutoTopicCreationType| The type of topic that is allowed to be automatically created.(partitioned/non-partitioned) |non-partitioned|
+|allowAutoSubscriptionCreation| Enable subscription auto creation if a new consumer connected |true|
+|defaultNumPartitions| The number of partitioned topics that is allowed to be automatically created if `allowAutoTopicCreationType` is partitioned |1|
+|brokerDeleteInactiveTopicsEnabled| Enable the deletion of inactive topics. If topics are not consumed for some while, these inactive topics might be cleaned up. Deleting inactive topics is enabled by default. The default period is 1 minute.  |true|
+|brokerDeleteInactiveTopicsFrequencySeconds|  How often to check for inactive topics  |60|
+| brokerDeleteInactiveTopicsMode | Set the mode to delete inactive topics. <li> `delete_when_no_subscriptions`: delete the topic which has no subscriptions or active producers. <li> `delete_when_subscriptions_caught_up`: delete the topic whose subscriptions have no backlogs and which has no active producers or consumers. | `delete_when_no_subscriptions` |
+| brokerDeleteInactiveTopicsMaxInactiveDurationSeconds | Set the maximum duration for inactive topics. If it is not specified, the `brokerDeleteInactiveTopicsFrequencySeconds` parameter is adopted. | N/A |
+|forceDeleteTenantAllowed| Enable you to delete a tenant forcefully. |false|
+|forceDeleteNamespaceAllowed| Enable you to delete a namespace forcefully. |false|
+|messageExpiryCheckIntervalInMinutes| The frequency of proactively checking and purging expired messages. |5|
+|brokerServiceCompactionMonitorIntervalInSeconds| Interval between checks to determine whether topics with compaction policies need compaction. |60|
+brokerServiceCompactionThresholdInBytes|If the estimated backlog size is greater than this threshold, compression is triggered.<br /><br />Set this threshold to 0 means disabling the compression check.|N/A
+|delayedDeliveryEnabled| Whether to enable the delayed delivery for messages. If disabled, messages will be immediately delivered and there will be no tracking overhead.|true|
+|delayedDeliveryTickTimeMillis|Control the tick time for retrying on delayed delivery, which affects the accuracy of the delivery time compared to the scheduled time. By default, it is 1 second.|1000|
+|activeConsumerFailoverDelayTimeMillis| How long to delay rewinding cursor and dispatching messages when active consumer is changed.  |1000|
+|clientLibraryVersionCheckEnabled|  Enable check for minimum allowed client library version |false|
+|clientLibraryVersionCheckAllowUnversioned| Allow client libraries with no version information  |true|
+|statusFilePath|  Path for the file used to determine the rotation status for the broker when responding to service discovery health checks ||
+|preferLaterVersions| If true, (and ModularLoadManagerImpl is being used), the load manager will attempt to use only brokers running the latest software version (to minimize impact to bundles)  |false|
+|maxNumPartitionsPerPartitionedTopic|Max number of partitions per partitioned topic. Use 0 or negative number to disable the check|0|
+| maxSubscriptionsPerTopic | Maximum number of subscriptions allowed to subscribe to a topic. Once this limit reaches, the broker rejects new subscriptions until the number of subscriptions decreases. When the value is set to 0, the limit check is disabled. | 0 |
+| maxProducersPerTopic | Maximum number of producers allowed to connect to a topic. Once this limit reaches, the broker rejects new producers until the number of connected producers decreases. When the value is set to 0, the limit check is disabled. | 0 |
+| maxConsumersPerTopic | Maximum number of consumers allowed to connect to a topic. Once this limit reaches, the broker rejects new consumers until the number of connected consumers decreases. When the value is set to 0, the limit check is disabled. | 0 |
+| maxConsumersPerSubscription | Maximum number of consumers allowed to connect to a subscription. Once this limit reaches, the broker rejects new consumers until the number of connected consumers decreases. When the value is set to 0, the limit check is disabled. | 0 |
+|tlsCertificateFilePath|  Path for the TLS certificate file ||
+|tlsKeyFilePath|  Path for the TLS private key file ||
+|tlsTrustCertsFilePath| Path for the trusted TLS certificate file. This cert is used to verify that any certs presented by connecting clients are signed by a certificate authority. If this verification fails, then the certs are untrusted and the connections are dropped. ||
+|tlsAllowInsecureConnection| Accept untrusted TLS certificate from client. If it is set to `true`, a client with a cert which cannot be verified with the 'tlsTrustCertsFilePath' cert will be allowed to connect to the server, though the cert will not be used for client authentication. |false|
+|tlsProtocols|Specify the tls protocols the broker will use to negotiate during TLS Handshake. Multiple values can be specified, separated by commas. Example:- ```TLSv1.3```, ```TLSv1.2``` ||
+|tlsCiphers|Specify the tls cipher the broker will use to negotiate during TLS Handshake. Multiple values can be specified, separated by commas. Example:- ```TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256```||
+|tlsEnabledWithKeyStore| Enable TLS with KeyStore type configuration in broker |false|
+|tlsProvider| TLS Provider for KeyStore type ||
+|tlsKeyStoreType| LS KeyStore type configuration in broker: JKS, PKCS12 |JKS|
+|tlsKeyStore| TLS KeyStore path in broker ||
+|tlsKeyStorePassword| TLS KeyStore password for broker ||
+|brokerClientTlsEnabledWithKeyStore| Whether internal client use KeyStore type to authenticate with Pulsar brokers |false|
+|brokerClientSslProvider| The TLS Provider used by internal client to authenticate with other Pulsar brokers ||
+|brokerClientTlsTrustStoreType| TLS TrustStore type configuration for internal client: JKS, PKCS12, used by the internal client to authenticate with Pulsar brokers |JKS|
+|brokerClientTlsTrustStore| TLS TrustStore path for internal client, used by the internal client to authenticate with Pulsar brokers ||
+|brokerClientTlsTrustStorePassword| TLS TrustStore password for internal client, used by the internal client to authenticate with Pulsar brokers ||
+|brokerClientTlsCiphers| Specify the tls cipher the internal client will use to negotiate during TLS Handshake. (a comma-separated list of ciphers) e.g.  [TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256]||
+|brokerClientTlsProtocols|Specify the tls protocols the broker will use to negotiate during TLS handshake. (a comma-separated list of protocol names). e.g.  `TLSv1.3`, `TLSv1.2` ||
+| metadataStoreBatchingEnabled | Enable metadata operations batching. | true |
+| metadataStoreBatchingMaxDelayMillis | Maximum delay to impose on batching grouping. | 5 |
+| metadataStoreBatchingMaxOperations | Maximum number of operations to include in a singular batch. | 1000 |
+| metadataStoreBatchingMaxSizeKb | Maximum size of a batch. | 128 |
+|ttlDurationDefaultInSeconds|The default Time to Live (TTL) for namespaces if the TTL is not configured at namespace policies. When the value is set to `0`, TTL is disabled. By default, TTL is disabled. |0|
+|tokenSettingPrefix| Configure the prefix of the token-related settings, such as `tokenSecretKey`, `tokenPublicKey`, `tokenAuthClaim`, `tokenPublicAlg`, `tokenAudienceClaim`, and `tokenAudience`. ||
+|tokenSecretKey| Configure the secret key to be used to validate auth tokens. The key can be specified like: `tokenSecretKey=data:;base64,xxxxxxxxx` or `tokenSecretKey=file:///my/secret.key`.  Note: key file must be DER-encoded.||
+|tokenPublicKey| Configure the public key to be used to validate auth tokens. The key can be specified like: `tokenPublicKey=data:;base64,xxxxxxxxx` or `tokenPublicKey=file:///my/secret.key`.  Note: key file must be DER-encoded.||
+|tokenPublicAlg| Configure the algorithm to be used to validate auth tokens. This can be any of the asymettric algorithms supported by Java JWT (https://github.com/jwtk/jjwt#signature-algorithms-keys) |RS256|
+|tokenAuthClaim| Specify which of the token's claims will be used as the authentication "principal" or "role". The default "sub" claim will be used if this is left blank ||
+|tokenAudienceClaim| The token audience "claim" name, e.g. "aud", that will be used to get the audience from token. If not set, audience will not be verified. ||
+|tokenAudience| The token audience stands for this broker. The field `tokenAudienceClaim` of a valid token, need contains this. ||
+|maxUnackedMessagesPerConsumer| Max number of unacknowledged messages allowed to receive messages by a consumer on a shared subscription. Broker will stop sending messages to consumer once, this limit reaches until consumer starts acknowledging messages back. Using a value of 0, is disabling unackeMessage limit check and consumer can receive messages without any restriction  |50000|
+|maxUnackedMessagesPerSubscription| Max number of unacknowledged messages allowed per shared subscription. Broker will stop dispatching messages to all consumers of the subscription once this limit reaches until consumer starts acknowledging messages back and unack count reaches to limit/2. Using a value of 0, is disabling unackedMessage-limit check and dispatcher can dispatch messages without any restriction  |200000|
+|subscriptionRedeliveryTrackerEnabled| Enable subscription message redelivery tracker |true|
 |subscriptionExpirationTimeMinutes | How long to delete inactive subscriptions from last consuming. <br/><br/>Setting this configuration to a value **greater than 0** deletes inactive subscriptions automatically.<br/>Setting this configuration to **0** does not delete inactive subscriptions automatically. <br/><br/> Since this configuration takes effect on all topics, if there is even one topic whose subscriptions should not be deleted automatically, you need to set it to 0. <br/>Instead [...]
-|maxConcurrentLookupRequest| Max number of concurrent lookup request broker allows to throttle heavy incoming lookup traffic                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|maxConcurrentTopicLoadRequest| Max number of concurrent topic loading request broker allows to control number of zk-operations                                                                                                                                                                                                                                                                                                                                                                              [...]
-|authenticationEnabled| Enable authentication                                                                                                                                                                                                                                                                                                                                                                                                                                                                [...]
-|authenticationProviders| Authentication provider name list, which is comma separated list of class names                                                                                                                                                                                                                                                                                                                                                                                                    [...]
-| authenticationRefreshCheckSeconds | Interval of time for checking for expired authentication credentials                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|authorizationEnabled| Enforce authorization                                                                                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|superUserRoles| Role names that are treated as “super-user”, meaning they will be able to do all admin operations and publish/consume from all topics                                                                                                                                                                                                                                                                                                                                                       [...]
-|brokerClientAuthenticationPlugin| Authentication settings of the broker itself. Used when the broker connects to other brokers, either in same or other clusters                                                                                                                                                                                                                                                                                                                                            [...]
+|maxConcurrentLookupRequest|  Max number of concurrent lookup request broker allows to throttle heavy incoming lookup traffic |50000|
+|maxConcurrentTopicLoadRequest| Max number of concurrent topic loading request broker allows to control number of zk-operations |5000|
+|authenticationEnabled| Enable authentication |false|
+|authenticationProviders| Authentication provider name list, which is comma separated list of class names  ||
+| authenticationRefreshCheckSeconds | Interval of time for checking for expired authentication credentials | 60 |
+|authorizationEnabled|  Enforce authorization |false|
+|superUserRoles|  Role names that are treated as “super-user”, meaning they will be able to do all admin operations and publish/consume from all topics ||
+|brokerClientAuthenticationPlugin|  Authentication settings of the broker itself. Used when the broker connects to other brokers, either in same or other clusters  ||
 |brokerClientAuthenticationParameters|||
-|athenzDomainNames| Supported Athenz provider domain names(comma separated) for authentication                                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|exposePreciseBacklogInPrometheus| Enable expose the precise backlog stats, set false to use published counter and consumed counter to calculate, this would be more efficient but may be inaccurate.                                                                                                                                                                                                                                                                                                        [...]
-|schemaRegistryStorageClassName| The schema storage implementation used by this broker.                                                                                                                                                                                                                                                                                                                                                                                                                      [...]
-|isSchemaValidationEnforced| Whether to enable schema validation, when schema validation is enabled, if a producer without a schema attempts to produce the message to a topic with schema, the producer is rejected and disconnected.                                                                                                                                                                                                                                                                       [...]
-|isAllowAutoUpdateSchemaEnabled| Allow schema to be auto updated at broker level.                                                                                                                                                                                                                                                                                                                                                                                                                            [...]
-|schemaCompatibilityStrategy| The schema compatibility strategy at broker level, see [here](schema-evolution-compatibility.md#schema-compatibility-check-strategy) for available values.                                                                                                                                                                                                                                                                                                                     [...]
-|systemTopicSchemaCompatibilityStrategy| The schema compatibility strategy is used for system topics, see [here](schema-evolution-compatibility.md#schema-compatibility-check-strategy) for available values.                                                                                                                                                                                                                                                                                                [...]
-| topicFencingTimeoutSeconds | If a topic remains fenced for a certain time period (in seconds), it is closed forcefully. If set to 0 or a negative number, the fenced topic is not closed.                                                                                                                                                                                                                                                                                                                  [...]
-|offloadersDirectory| The directory for all the offloader implementations.                                                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|bookkeeperMetadataServiceUri| Metadata service uri that bookkeeper is used for loading corresponding metadata driver and resolving its metadata service location. This value can be fetched using `bookkeeper shell whatisinstanceid` command in BookKeeper cluster. For example: zk+hierarchical://localhost:2181/ledgers. The metadata service uri list can also be semicolon separated values like below: zk+hierarchical://zk1:2181;zk2:2181;zk3:2181/ledgers                                           [...]
-|bookkeeperClientAuthenticationPlugin| Authentication plugin to use when connecting to bookies                                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|bookkeeperClientAuthenticationParametersName| BookKeeper auth plugin implementation specifics parameters name and values                                                                                                                                                                                                                                                                                                                                                                                    [...]
+|athenzDomainNames| Supported Athenz provider domain names(comma separated) for authentication  ||
+|exposePreciseBacklogInPrometheus| Enable expose the precise backlog stats, set false to use published counter and consumed counter to calculate, this would be more efficient but may be inaccurate. |false|
+|schemaRegistryStorageClassName|The schema storage implementation used by this broker.|org.apache.pulsar.broker.service.schema.BookkeeperSchemaStorageFactory|
+|isSchemaValidationEnforced| Whether to enable schema validation, when schema validation is enabled, if a producer without a schema attempts to produce the message to a topic with schema, the producer is rejected and disconnected.|false|
+|isAllowAutoUpdateSchemaEnabled|Allow schema to be auto updated at broker level.|true|
+|schemaCompatibilityStrategy| The schema compatibility strategy at broker level, see [here](schema-evolution-compatibility.md#schema-compatibility-check-strategy) for available values.|FULL|
+|systemTopicSchemaCompatibilityStrategy| The schema compatibility strategy is used for system topics, see [here](schema-evolution-compatibility.md#schema-compatibility-check-strategy) for available values.|ALWAYS_COMPATIBLE|
+| topicFencingTimeoutSeconds | If a topic remains fenced for a certain time period (in seconds), it is closed forcefully. If set to 0 or a negative number, the fenced topic is not closed. | 0 |
+|offloadersDirectory|The directory for all the offloader implementations.|./offloaders|
+|bookkeeperMetadataServiceUri| Metadata service uri that bookkeeper is used for loading corresponding metadata driver and resolving its metadata service location. This value can be fetched using `bookkeeper shell whatisinstanceid` command in BookKeeper cluster. For example: zk+hierarchical://localhost:2181/ledgers. The metadata service uri list can also be semicolon separated values like below: zk+hierarchical://zk1:2181;zk2:2181;zk3:2181/ledgers ||
+|bookkeeperClientAuthenticationPlugin|  Authentication plugin to use when connecting to bookies ||
+|bookkeeperClientAuthenticationParametersName|  BookKeeper auth plugin implementation specifics parameters name and values  ||
 |bookkeeperClientAuthenticationParameters|||
-|bookkeeperClientNumWorkerThreads| Number of BookKeeper client worker threads. Default is Runtime.getRuntime().availableProcessors()                                                                                                                                                                                                                                                                                                                                                                         [...]
-|bookkeeperClientTimeoutInSeconds| Timeout for BK add / read operations                                                                                                                                                                                                                                                                                                                                                                                                                                      [...]
-|bookkeeperClientSpeculativeReadTimeoutInMillis| Speculative reads are initiated if a read request doesn’t complete within a certain time Using a value of 0, is disabling the speculative reads                                                                                                                                                                                                                                                                                                             [...]
-|bookkeeperNumberOfChannelsPerBookie| Number of channels per bookie                                                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|bookkeeperClientHealthCheckEnabled| Enable bookies health check. Bookies that have more than the configured number of failure within the interval will be quarantined for some time. During this period, new ledgers won’t be created on these bookies                                                                                                                                                                                                                                                      [...]
-|bookkeeperClientHealthCheckIntervalSeconds|| 60                                                                                                                                                                                                                                                                                                                                                                                                                                                             [...]
-|bookkeeperClientHealthCheckErrorThresholdPerInterval|| 5                                                                                                                                                                                                                                                                                                                                                                                                                                                    [...]
-|bookkeeperClientHealthCheckQuarantineTimeInSeconds || 1800                                                                                                                                                                                                                                                                                                                                                                                                                                                  [...]
-|bookkeeperClientRackawarePolicyEnabled| Enable rack-aware bookie selection policy. BK will chose bookies from different racks when forming a new bookie ensemble                                                                                                                                                                                                                                                                                                                                            [...]
-|bookkeeperClientRegionawarePolicyEnabled| Enable region-aware bookie selection policy. BK will chose bookies from different regions and racks when forming a new bookie ensemble. If enabled, the value of bookkeeperClientRackawarePolicyEnabled is ignored                                                                                                                                                                                                                                                [...]
-|bookkeeperClientMinNumRacksPerWriteQuorum| Minimum number of racks per write quorum. BK rack-aware bookie selection policy will try to get bookies from at least 'bookkeeperClientMinNumRacksPerWriteQuorum' racks for a write quorum.                                                                                                                                                                                                                                                                      [...]
-|bookkeeperClientEnforceMinNumRacksPerWriteQuorum| Enforces rack-aware bookie selection policy to pick bookies from 'bookkeeperClientMinNumRacksPerWriteQuorum' racks for a writeQuorum. If BK can't find bookie then it would throw BKNotEnoughBookiesException instead of picking random one.                                                                                                                                                                                                              [...]
-|bookkeeperClientReorderReadSequenceEnabled| Enable/disable reordering read sequence on reading entries.                                                                                                                                                                                                                                                                                                                                                                                                     [...]
-|bookkeeperClientIsolationGroups| Enable bookie isolation by specifying a list of bookie groups to choose from. Any bookie outside the specified groups will not be used by the broker                                                                                                                                                                                                                                                                                                                       [...]
-|bookkeeperClientSecondaryIsolationGroups| Enable bookie secondary-isolation group if bookkeeperClientIsolationGroups doesn't have enough bookie available.                                                                                                                                                                                                                                                                                                                                                  [...]
-|bookkeeperClientMinAvailableBookiesInIsolationGroups| Minimum bookies that should be available as part of bookkeeperClientIsolationGroups else broker will include bookkeeperClientSecondaryIsolationGroups bookies in isolated list.                                                                                                                                                                                                                                                                       [...]
-|bookkeeperClientGetBookieInfoIntervalSeconds| Set the interval to periodically check bookie info                                                                                                                                                                                                                                                                                                                                                                                                            [...]
-|bookkeeperClientGetBookieInfoRetryIntervalSeconds| Set the interval to retry a failed bookie info lookup                                                                                                                                                                                                                                                                                                                                                                                                    [...]
-|bookkeeperEnableStickyReads | Enable/disable having read operations for a ledger to be sticky to a single bookie. If this flag is enabled, the client will use one single bookie (by preference) to read  all entries for a ledger.                                                                                                                                                                                                                                                                         [...]
-|managedLedgerDefaultEnsembleSize| Number of bookies to use when creating a ledger                                                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|managedLedgerDefaultWriteQuorum| Number of copies to store for each message                                                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|managedLedgerDefaultAckQuorum| Number of guaranteed copies (acks to wait before write is complete)                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|managedLedgerCacheSizeMB| Amount of memory to use for caching data payload in managed ledger. This memory is allocated from JVM direct memory and it’s shared across all the topics running in the same broker. By default, uses 1/5th of available direct memory                                                                                                                                                                                                                                           [...]
-|managedLedgerCacheCopyEntries| Whether we should make a copy of the entry payloads when inserting in cache                                                                                                                                                                                                                                                                                                                                                                                                  [...]
-|managedLedgerCacheEvictionWatermark| Threshold to which bring down the cache level when eviction is triggered                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|managedLedgerCacheEvictionFrequency| Configure the cache eviction frequency for the managed ledger cache (evictions/sec)                                                                                                                                                                                                                                                                                                                                                                                    [...]
-|managedLedgerCacheEvictionTimeThresholdMillis| All entries that have stayed in cache for more than the configured time, will be evicted                                                                                                                                                                                                                                                                                                                                                                     [...]
-|managedLedgerCursorBackloggedThreshold| Configure the threshold (in number of entries) from where a cursor should be considered 'backlogged' and thus should be set as inactive.                                                                                                                                                                                                                                                                                                                            [...]
-|managedLedgerDefaultMarkDeleteRateLimit| Rate limit the amount of writes per second generated by consumer acking the messages                                                                                                                                                                                                                                                                                                                                                                               [...]
-|managedLedgerMaxEntriesPerLedger| The max number of entries to append to a ledger before triggering a rollover. A ledger rollover is triggered after the min rollover time has passed and one of the following conditions is true: <ul><li>The max rollover time has been reached</li><li>The max entries have been written to the ledger</li><li>The max ledger size has been written to the ledger</li></ul>                                                                                              [...]
-|managedLedgerMinLedgerRolloverTimeMinutes| Minimum time between ledger rollover for a topic                                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|managedLedgerMaxLedgerRolloverTimeMinutes| Maximum time before forcing a ledger rollover for a topic                                                                                                                                                                                                                                                                                                                                                                                                        [...]
-|managedLedgerInactiveLedgerRolloverTimeSeconds| Time to rollover ledger for inactive topic                                                                                                                                                                                                                                                                                                                                                                                                                  [...]
-|managedLedgerCursorMaxEntriesPerLedger| Max number of entries to append to a cursor ledger                                                                                                                                                                                                                                                                                                                                                                                                                  [...]
-|managedLedgerCursorRolloverTimeInSeconds| Max time before triggering a rollover on a cursor ledger                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|managedLedgerMaxUnackedRangesToPersist| Max number of “acknowledgment holes” that are going to be persistently stored. When acknowledging out of order, a consumer will leave holes that are supposed to be quickly filled by acking all the messages. The information of which messages are acknowledged is persisted by compressing in “ranges” of messages that were acknowledged. After the max number of ranges is reached, the information will only be tracked in memory and messages will be redeli [...]
-| managedLedgerMaxUnackedRangesToPersistInMetadataStore | Maximum number of "acknowledgment holes" that can be stored in metadata store. If the number of unacknowledged message range is higher than this limit, the broker persists unacknowledged ranges into BookKeeper to avoid additional data overhead into metadata store.                                                                                                                                                                           [...]
-| managedLedgerMetadataOperationsTimeoutSeconds | Operation timeout while updating managed-ledger metadata.                                                                                                                                                                                                                                                                                                                                                                                                  [...]
-| managedLedgerReadEntryTimeoutSeconds | Read entries timeout when the broker tries to read messages from BookKeeper.                                                                                                                                                                                                                                                                                                                                                                                        [...]
-| managedLedgerAddEntryTimeoutSeconds | Add entry timeout when the broker tries to publish messages to BookKeeper.                                                                                                                                                                                                                                                                                                                                                                                           [...]
-| managedLedgerNewEntriesCheckDelayInMillis | New entries check delay for the cursor under the managed ledger. If no new messages in the topic, the cursor tries to check again after the delay time. For consumption latency sensitive scenarios, you can set the value to a smaller value or 0. A smaller value may degrade consumption throughput.                                                                                                                                                        [...]
-|autoSkipNonRecoverableData| Skip reading non-recoverable/unreadable data-ledger under managed-ledger’s list.It helps when data-ledgers gets corrupted at bookkeeper and managed-cursor is stuck at that ledger.                                                                                                                                                                                                                                                                                             [...]
-|loadBalancerEnabled| Enable load balancer                                                                                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|loadBalancerPlacementStrategy| Strategy to assign a new bundle weightedRandomSelection                                                                                                                                                                                                                                                                                                                                                                                                                      [...]
-|loadBalancerReportUpdateThresholdPercentage| Percentage of change to trigger load report update                                                                                                                                                                                                                                                                                                                                                                                                             [...]
-|loadBalancerReportUpdateMaxIntervalMinutes| Maximum interval to update load report                                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|loadBalancerHostUsageCheckIntervalMinutes| Frequency of report to collect                                                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|loadBalancerSheddingIntervalMinutes| Load shedding interval. Broker periodically checks whether some traffic should be offload from some over-loaded broker to other under-loaded brokers                                                                                                                                                                                                                                                                                                                   [...]
-|loadBalancerSheddingGracePeriodMinutes| Prevent the same topics to be shed and moved to other broker more than once within this timeframe                                                                                                                                                                                                                                                                                                                                                                   [...]
-|loadBalancerBrokerMaxTopics| Usage threshold to allocate max number of topics to broker                                                                                                                                                                                                                                                                                                                                                                                                                     [...]
-|loadBalancerBrokerUnderloadedThresholdPercentage| Usage threshold to determine a broker as under-loaded                                                                                                                                                                                                                                                                                                                                                                                                     [...]
-|loadBalancerBrokerOverloadedThresholdPercentage| Usage threshold to determine a broker as over-loaded                                                                                                                                                                                                                                                                                                                                                                                                       [...]
-|loadBalancerResourceQuotaUpdateIntervalMinutes| Interval to update namespace bundle resource quota                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|loadBalancerBrokerComfortLoadLevelPercentage| Usage threshold to determine a broker is having just right level of load                                                                                                                                                                                                                                                                                                                                                                                      [...]
-|loadBalancerAutoBundleSplitEnabled| enable/disable namespace bundle auto split                                                                                                                                                                                                                                                                                                                                                                                                                              [...]
-|loadBalancerNamespaceBundleMaxTopics| maximum topics in a bundle, otherwise bundle split will be triggered                                                                                                                                                                                                                                                                                                                                                                                                  [...]
-|loadBalancerNamespaceBundleMaxSessions| maximum sessions (producers + consumers) in a bundle, otherwise bundle split will be triggered                                                                                                                                                                                                                                                                                                                                                                      [...]
-|loadBalancerNamespaceBundleMaxMsgRate| maximum msgRate (in + out) in a bundle, otherwise bundle split will be triggered                                                                                                                                                                                                                                                                                                                                                                                     [...]
-|loadBalancerNamespaceBundleMaxBandwidthMbytes| maximum bandwidth (in + out) in a bundle, otherwise bundle split will be triggered                                                                                                                                                                                                                                                                                                                                                                           [...]
-|loadBalancerNamespaceMaximumBundles| maximum number of bundles in a namespace                                                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|loadBalancerLoadSheddingStrategy | The shedding strategy of load balance. <br /><br />Available values: <li>`org.apache.pulsar.broker.loadbalance.impl.ThresholdShedder`</li><li>`org.apache.pulsar.broker.loadbalance.impl.OverloadShedder`</li><li>`org.apache.pulsar.broker.loadbalance.impl.UniformLoadShedder`</li><br />For the comparisons of the shedding strategies, see [here](administration-load-balance/#shed-load-automatically).<br />**Note**: You need to restart brokers if this configur [...]
-|replicationMetricsEnabled| Enable replication metrics                                                                                                                                                                                                                                                                                                                                                                                                                                                       [...]
-|replicationConnectionsPerBroker| Max number of connections to open for each broker in a remote cluster More connections host-to-host lead to better throughput over high-latency links.                                                                                                                                                                                                                                                                                                                     [...]
-|replicationProducerQueueSize| Replicator producer queue size                                                                                                                                                                                                                                                                                                                                                                                                                                                [...]
-|replicatorPrefix| Replicator prefix used for replicator producer name and cursor name pulsar.repl                                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|transactionBufferClientOperationTimeoutInMills| The transaction buffer client's operation timeout in milliseconds.                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|transactionCoordinatorEnabled| Whether to enable transaction coordinator in broker.                                                                                                                                                                                                                                                                                                                                                                                                                         [...]
-|transactionMetadataStoreProviderClassName|                                                                                                                                                                                                                                                                                                                                                                                                                                                                  [...]
-|defaultRetentionTimeInMinutes| Default message retention time                                                                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|defaultRetentionSizeInMB| Default retention size                                                                                                                                                                                                                                                                                                                                                                                                                                                            [...]
-|keepAliveIntervalSeconds| How often to check whether the connections are still alive                                                                                                                                                                                                                                                                                                                                                                                                                        [...]
-|bootstrapNamespaces| The bootstrap name.                                                                                                                                                                                                                                                                                                                                                                                                                                                                    [...]
-|loadManagerClassName| Name of load manager to use                                                                                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|supportedNamespaceBundleSplitAlgorithms| Supported algorithms name for namespace bundle split                                                                                                                                                                                                                                                                                                                                                                                                               [...]
-|defaultNamespaceBundleSplitAlgorithm| Default algorithm name for namespace bundle split                                                                                                                                                                                                                                                                                                                                                                                                                     [...]
-|managedLedgerOffloadDriver| The directory for all the offloader implementations `offloadersDirectory=./offloaders`. Driver to use to offload old data to long term storage (Possible values: S3, aws-s3, google-cloud-storage). When using google-cloud-storage, Make sure both Google Cloud Storage and Google Cloud Storage JSON API are enabled for the project (check from Developers Console -> Api&auth -> APIs).                                                                                     [...]
-|managedLedgerOffloadMaxThreads| Maximum number of thread pool threads for ledger offloading                                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-|managedLedgerOffloadPrefetchRounds| The maximum prefetch rounds for ledger reading for offloading.                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|managedLedgerUnackedRangesOpenCacheSetEnabled| Use Open Range-Set to cache unacknowledged messages                                                                                                                                                                                                                                                                                                                                                                                                          [...]
-|managedLedgerOffloadDeletionLagMs| Delay between a ledger being successfully offloaded to long term storage and the ledger being deleted from bookkeeper                                                                                                                                                                                                                                                                                                                                                    [...]
-|managedLedgerOffloadAutoTriggerSizeThresholdBytes| The number of bytes before triggering automatic offload to long term storage                                                                                                                                                                                                                                                                                                                                                                             [...]
-|s3ManagedLedgerOffloadRegion| For Amazon S3 ledger offload, AWS region                                                                                                                                                                                                                                                                                                                                                                                                                                      [...]
-|s3ManagedLedgerOffloadBucket| For Amazon S3 ledger offload, Bucket to place offloaded ledger into                                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|s3ManagedLedgerOffloadServiceEndpoint| For Amazon S3 ledger offload, Alternative endpoint to connect to (useful for testing)                                                                                                                                                                                                                                                                                                                                                                                [...]
-|s3ManagedLedgerOffloadMaxBlockSizeInBytes| For Amazon S3 ledger offload, Max block size in bytes. (64MB by default, 5MB minimum)                                                                                                                                                                                                                                                                                                                                                                            [...]
-|s3ManagedLedgerOffloadReadBufferSizeInBytes| For Amazon S3 ledger offload, Read buffer size in bytes (1MB by default)                                                                                                                                                                                                                                                                                                                                                                                       [...]
-|gcsManagedLedgerOffloadRegion| For Google Cloud Storage ledger offload, region where offload bucket is located. Go to this page for more details: https://cloud.google.com/storage/docs/bucket-locations .                                                                                                                                                                                                                                                                                                  [...]
-|gcsManagedLedgerOffloadBucket| For Google Cloud Storage ledger offload, Bucket to place offloaded ledger into.                                                                                                                                                                                                                                                                                                                                                                                              [...]
-|gcsManagedLedgerOffloadMaxBlockSizeInBytes| For Google Cloud Storage ledger offload, the maximum block size in bytes. (64MB by default, 5MB minimum)                                                                                                                                                                                                                                                                                                                                                        [...]
-|gcsManagedLedgerOffloadReadBufferSizeInBytes| For Google Cloud Storage ledger offload, Read buffer size in bytes. (1MB by default)                                                                                                                                                                                                                                                                                                                                                                          [...]
-|gcsManagedLedgerOffloadServiceAccountKeyFile| For Google Cloud Storage, path to json file containing service account credentials. For more details, see the "Service Accounts" section of https://support.google.com/googleapi/answer/6158849 .                                                                                                                                                                                                                                                             [...]
-|fileSystemProfilePath| For File System Storage, file system profile path.                                                                                                                                                                                                                                                                                                                                                                                                                                   [...]
-|fileSystemURI| For File System Storage, file system uri.                                                                                                                                                                                                                                                                                                                                                                                                                                                    [...]
-|s3ManagedLedgerOffloadRole| For Amazon S3 ledger offload, provide a role to assume before writing to s3                                                                                                                                                                                                                                                                                                                                                                                                     [...]
-|s3ManagedLedgerOffloadRoleSessionName| For Amazon S3 ledger offload, provide a role session name when using a role                                                                                                                                                                                                                                                                                                                                                                                          [...]
-| acknowledgmentAtBatchIndexLevelEnabled | Enable or disable the batch index acknowledgement.                                                                                                                                                                                                                                                                                                                                                                                                                [...]
-|enableReplicatedSubscriptions| Whether to enable tracking of replicated subscriptions state across clusters.                                                                                                                                                                                                                                                                                                                                                                                                [...]
-|replicatedSubscriptionsSnapshotFrequencyMillis| The frequency of snapshots for replicated subscriptions tracking.                                                                                                                                                                                                                                                                                                                                                                                           [...]
-|replicatedSubscriptionsSnapshotTimeoutSeconds| The timeout for building a consistent snapshot for tracking replicated subscriptions state.                                                                                                                                                                                                                                                                                                                                                                  [...]
-|replicatedSubscriptionsSnapshotMaxCachedPerSubscription| The maximum number of snapshot to be cached per subscription.                                                                                                                                                                                                                                                                                                                                                                                      [...]
-|maxMessagePublishBufferSizeInMB| The maximum memory size for a broker to handle messages that are sent by producers. If the processing message size exceeds this value, the broker stops reading data from the connection. The processing messages refer to the messages that are sent to the broker but the broker has not sent response to the client. Usually the messages are waiting to be written to bookies. It is shared across all the topics running in the same broker. The value `-1` disables  [...]
-|messagePublishBufferCheckIntervalInMillis| Interval between checks to see if message publish buffer size exceeds the maximum. Use `0` or negative number to disable the max publish buffer limiting.                                                                                                                                                                                                                                                                                                        [...]
-|retentionCheckIntervalInSeconds| Check between intervals to see if consumed ledgers need to be trimmed. Use 0 or negative number to disable the check.                                                                                                                                                                                                                                                                                                                                                      [...]
-| maxMessageSize | Set the maximum size of a message.                                                                                                                                                                                                                                                                                                                                                                                                                                                        [...]
-| preciseTopicPublishRateLimiterEnable | Enable precise topic publish rate limiting.                                                                                                                                                                                                                                                                                                                                                                                                                         [...]
-| lazyCursorRecovery | Whether to recover cursors lazily when trying to recover a managed ledger backing a persistent topic. It can improve write availability of topics. The caveat is now when recovered ledger is ready to write we're not sure if all old consumers' last mark delete position(ack position) can be recovered or not. So user can make the trade off or have custom logic in application to checkpoint consumer state.                                                                   [...]
-|haProxyProtocolEnabled | Enable or disable the [HAProxy](http://www.haproxy.org/) protocol.                                                                                                                                                                                                                                                                                                                                                                                                                 [...]
-| maxNamespacesPerTenant | The maximum number of namespaces that can be created in each tenant. When the number of namespaces reaches this threshold, the broker rejects the request of creating a new tenant. The default value 0 disables the check.                                                                                                                                                                                                                                                       [...]
-| maxTopicsPerNamespace | The maximum number of persistent topics that can be created in the namespace. When the number of topics reaches this threshold, the broker rejects the request of creating a new topic, including the auto-created topics by the producer or consumer, until the number of connected consumers decreases. The default value 0 disables the check.                                                                                                                                  [...]
-|subscriptionTypesEnabled| Enable all subscription types, which are exclusive, shared, failover, and key_shared.                                                                                                                                                                                                                                                                                                                                                                                             [...]
-| managedLedgerInfoCompressionType | Compression type of managed ledger information. <br /><br />Available options are `NONE`, `LZ4`, `ZLIB`, `ZSTD`, and `SNAPPY`). <br /><br />If this value is `NONE` or invalid, the `managedLedgerInfo` is not compressed. <br /><br />**Note** that after enabling this configuration, if you want to degrade a broker, you need to change the value to `NONE` and make sure all ledger metadata is saved without compression.                                         [...]
-| additionalServlets | Additional servlet name. <br /><br />If you have multiple additional servlets, separate them by commas. <br /><br />For example, additionalServlet_1, additionalServlet_2                                                                                                                                                                                                                                                                                                             [...]
-| additionalServletDirectory | Location of broker additional servlet NAR directory                                                                                                                                                                                                                                                                                                                                                                                                                           [...]
-| brokerEntryMetadataInterceptors | Set broker entry metadata interceptors.<br /><br />Multiple interceptors should be separated by commas. <br /><br />Available values:<li>org.apache.pulsar.common.intercept.AppendBrokerTimestampMetadataInterceptor</li><li>org.apache.pulsar.common.intercept.AppendIndexMetadataInterceptor</li> <br /><br />Example<br />brokerEntryMetadataInterceptors=org.apache.pulsar.common.intercept.AppendBrokerTimestampMetadataInterceptor, org.apache.pulsar.common.inter [...]
-| enableExposingBrokerEntryMetadataToClient| Whether to expose broker entry metadata to client or not.<br /><br />Available values:<li>true</li><li>false</li><br />Example<br />enableExposingBrokerEntryMetadataToClient=true                                                                                                                                                                                                                                                                              [...]
-| metricsBufferResponse | The configuration is for those broker which there are more than one metrics system access the `/metrics` endpoint. For the purpose of reduce `CPU` and `Memory` usage, metrics data will be generated once in the interval(`managedLedgerStatsPeriodSeconds`) and it will be cached, all `/metrics` requests in the `interval` will return same metrics                                                                                                                            [...]
-| strictBookieAffinityEnabled | Enable or disable the strict bookie isolation strategy. If enabled, <br /> - `bookie-ensemble` first tries to choose bookies that belong to a namespace's affinity group. If the number of bookies is not enough, then the rest bookies are chosen. <br /> - If namespace has no affinity group, `bookie-ensemble` only chooses bookies that belong to no region. If the number of bookies is not enough, `BKNotEnoughBookiesException` is thrown.                           [...]
+|bookkeeperClientNumWorkerThreads|  Number of BookKeeper client worker threads. Default is Runtime.getRuntime().availableProcessors()  ||
+|bookkeeperClientTimeoutInSeconds|  Timeout for BK add / read operations  |30|
+|bookkeeperClientSpeculativeReadTimeoutInMillis|  Speculative reads are initiated if a read request doesn’t complete within a certain time Using a value of 0, is disabling the speculative reads |0|
+|bookkeeperNumberOfChannelsPerBookie|  Number of channels per bookie  |16|
+|bookkeeperClientHealthCheckEnabled|  Enable bookies health check. Bookies that have more than the configured number of failure within the interval will be quarantined for some time. During this period, new ledgers won’t be created on these bookies  |true|
+|bookkeeperClientHealthCheckIntervalSeconds||60|
+|bookkeeperClientHealthCheckErrorThresholdPerInterval||5|
+|bookkeeperClientHealthCheckQuarantineTimeInSeconds ||1800|
+|bookkeeperClientRackawarePolicyEnabled|  Enable rack-aware bookie selection policy. BK will chose bookies from different racks when forming a new bookie ensemble  |true|
+|bookkeeperClientRegionawarePolicyEnabled|  Enable region-aware bookie selection policy. BK will chose bookies from different regions and racks when forming a new bookie ensemble. If enabled, the value of bookkeeperClientRackawarePolicyEnabled is ignored  |false|
+|bookkeeperClientMinNumRacksPerWriteQuorum|  Minimum number of racks per write quorum. BK rack-aware bookie selection policy will try to get bookies from at least 'bookkeeperClientMinNumRacksPerWriteQuorum' racks for a write quorum.  |2|
+|bookkeeperClientEnforceMinNumRacksPerWriteQuorum|  Enforces rack-aware bookie selection policy to pick bookies from 'bookkeeperClientMinNumRacksPerWriteQuorum' racks for a writeQuorum. If BK can't find bookie then it would throw BKNotEnoughBookiesException instead of picking random one.  |false|
+|bookkeeperClientReorderReadSequenceEnabled|  Enable/disable reordering read sequence on reading entries.  |false|
+|bookkeeperClientIsolationGroups| Enable bookie isolation by specifying a list of bookie groups to choose from. Any bookie outside the specified groups will not be used by the broker  ||
+|bookkeeperClientSecondaryIsolationGroups| Enable bookie secondary-isolation group if bookkeeperClientIsolationGroups doesn't have enough bookie available.  ||
+|bookkeeperClientMinAvailableBookiesInIsolationGroups| Minimum bookies that should be available as part of bookkeeperClientIsolationGroups else broker will include bookkeeperClientSecondaryIsolationGroups bookies in isolated list.  ||
+|bookkeeperClientGetBookieInfoIntervalSeconds| Set the interval to periodically check bookie info |86400|
+|bookkeeperClientGetBookieInfoRetryIntervalSeconds|  Set the interval to retry a failed bookie info lookup |60|
+|bookkeeperEnableStickyReads | Enable/disable having read operations for a ledger to be sticky to a single bookie. If this flag is enabled, the client will use one single bookie (by preference) to read  all entries for a ledger. | true |
+|managedLedgerDefaultEnsembleSize|  Number of bookies to use when creating a ledger |2|
+|managedLedgerDefaultWriteQuorum| Number of copies to store for each message  |2|
+|managedLedgerDefaultAckQuorum| Number of guaranteed copies (acks to wait before write is complete) |2|
+|managedLedgerCacheSizeMB|  Amount of memory to use for caching data payload in managed ledger. This memory is allocated from JVM direct memory and it’s shared across all the topics running in the same broker. By default, uses 1/5th of available direct memory ||
+|managedLedgerCacheCopyEntries| Whether we should make a copy of the entry payloads when inserting in cache| false|
+|managedLedgerCacheEvictionWatermark| Threshold to which bring down the cache level when eviction is triggered  |0.9|
+|managedLedgerCacheEvictionFrequency| Configure the cache eviction frequency for the managed ledger cache (evictions/sec) | 100.0 |
+|managedLedgerCacheEvictionTimeThresholdMillis| All entries that have stayed in cache for more than the configured time, will be evicted | 1000 |
+|managedLedgerCursorBackloggedThreshold| Configure the threshold (in number of entries) from where a cursor should be considered 'backlogged' and thus should be set as inactive. | 1000|
+|managedLedgerDefaultMarkDeleteRateLimit| Rate limit the amount of writes per second generated by consumer acking the messages  |1.0|
+|managedLedgerMaxEntriesPerLedger| The max number of entries to append to a ledger before triggering a rollover. A ledger rollover is triggered after the min rollover time has passed and one of the following conditions is true: <ul><li>The max rollover time has been reached</li><li>The max entries have been written to the ledger</li><li>The max ledger size has been written to the ledger</li></ul>|50000|
+|managedLedgerMinLedgerRolloverTimeMinutes| Minimum time between ledger rollover for a topic  |10|
+|managedLedgerMaxLedgerRolloverTimeMinutes| Maximum time before forcing a ledger rollover for a topic |240|
+|managedLedgerInactiveLedgerRolloverTimeSeconds| Time to rollover ledger for inactive topic |0|
+|managedLedgerCursorMaxEntriesPerLedger|  Max number of entries to append to a cursor ledger  |50000|
+|managedLedgerCursorRolloverTimeInSeconds|  Max time before triggering a rollover on a cursor ledger  |14400|
+|managedLedgerMaxUnackedRangesToPersist|  Max number of “acknowledgment holes” that are going to be persistently stored. When acknowledging out of order, a consumer will leave holes that are supposed to be quickly filled by acking all the messages. The information of which messages are acknowledged is persisted by compressing in “ranges” of messages that were acknowledged. After the max number of ranges is reached, the information will only be tracked in memory and messages will be redel [...]
+| managedLedgerMaxUnackedRangesToPersistInMetadataStore | Maximum number of "acknowledgment holes" that can be stored in metadata store. If the number of unacknowledged message range is higher than this limit, the broker persists unacknowledged ranges into BookKeeper to avoid additional data overhead into metadata store. | 1000 |
+| managedLedgerMetadataOperationsTimeoutSeconds | Operation timeout while updating managed-ledger metadata. | 60 |
+| managedLedgerReadEntryTimeoutSeconds | Read entries timeout when the broker tries to read messages from BookKeeper. | 0 |
+| managedLedgerAddEntryTimeoutSeconds | Add entry timeout when the broker tries to publish messages to BookKeeper. | 0 |
+| managedLedgerNewEntriesCheckDelayInMillis | New entries check delay for the cursor under the managed ledger. If no new messages in the topic, the cursor tries to check again after the delay time. For consumption latency sensitive scenarios, you can set the value to a smaller value or 0. A smaller value may degrade consumption throughput.|10|
+|autoSkipNonRecoverableData|  Skip reading non-recoverable/unreadable data-ledger under managed-ledger’s list.It helps when data-ledgers gets corrupted at bookkeeper and managed-cursor is stuck at that ledger. |false|
+|loadBalancerEnabled| Enable load balancer  |true|
+|loadBalancerPlacementStrategy| Strategy to assign a new bundle weightedRandomSelection ||
+|loadBalancerReportUpdateThresholdPercentage| Percentage of change to trigger load report update  |10|
+|loadBalancerReportUpdateMaxIntervalMinutes|  Maximum interval to update load report  |15|
+|loadBalancerHostUsageCheckIntervalMinutes| Frequency of report to collect  |1|
+|loadBalancerSheddingIntervalMinutes| Load shedding interval. Broker periodically checks whether some traffic should be offload from some over-loaded broker to other under-loaded brokers  |30|
+|loadBalancerSheddingGracePeriodMinutes|  Prevent the same topics to be shed and moved to other broker more than once within this timeframe |30|
+|loadBalancerBrokerMaxTopics| Usage threshold to allocate max number of topics to broker  |50000|
+|loadBalancerBrokerUnderloadedThresholdPercentage|  Usage threshold to determine a broker as under-loaded |1|
+|loadBalancerBrokerOverloadedThresholdPercentage| Usage threshold to determine a broker as over-loaded  |85|
+|loadBalancerResourceQuotaUpdateIntervalMinutes|  Interval to update namespace bundle resource quota |15|
+|loadBalancerBrokerComfortLoadLevelPercentage|  Usage threshold to determine a broker is having just right level of load  |65|
+|loadBalancerAutoBundleSplitEnabled|  enable/disable namespace bundle auto split  |false|
+|loadBalancerNamespaceBundleMaxTopics|  maximum topics in a bundle, otherwise bundle split will be triggered  |1000|
+|loadBalancerNamespaceBundleMaxSessions|  maximum sessions (producers + consumers) in a bundle, otherwise bundle split will be triggered  |1000|
+|loadBalancerNamespaceBundleMaxMsgRate| maximum msgRate (in + out) in a bundle, otherwise bundle split will be triggered  |1000|
+|loadBalancerNamespaceBundleMaxBandwidthMbytes| maximum bandwidth (in + out) in a bundle, otherwise bundle split will be triggered  |100|
+|loadBalancerNamespaceMaximumBundles| maximum number of bundles in a namespace  |128|
+|loadBalancerLoadSheddingStrategy | The shedding strategy of load balance. <br /><br />Available values: <li>`org.apache.pulsar.broker.loadbalance.impl.ThresholdShedder`</li><li>`org.apache.pulsar.broker.loadbalance.impl.OverloadShedder`</li><li>`org.apache.pulsar.broker.loadbalance.impl.UniformLoadShedder`</li><br />For the comparisons of the shedding strategies, see [here](administration-load-balance/#shed-load-automatically).<br />**Note**: You need to restart brokers if this configur [...]
+|replicationMetricsEnabled| Enable replication metrics  |true|
+|replicationConnectionsPerBroker| Max number of connections to open for each broker in a remote cluster More connections host-to-host lead to better throughput over high-latency links.  |16|
+|replicationProducerQueueSize|  Replicator producer queue size  |1000|
+|replicatorPrefix|  Replicator prefix used for replicator producer name and cursor name pulsar.repl||
+|transactionBufferClientOperationTimeoutInMills|The transaction buffer client's operation timeout in milliseconds.|3000|
+|transactionCoordinatorEnabled|Whether to enable transaction coordinator in broker.|true|
+|transactionMetadataStoreProviderClassName| |org.apache.pulsar.transaction.coordinator.impl.InMemTransactionMetadataStoreProvider|
+|defaultRetentionTimeInMinutes| Default message retention time  |0|
+|defaultRetentionSizeInMB|  Default retention size  |0|
+|keepAliveIntervalSeconds|  How often to check whether the connections are still alive  |30|
+|bootstrapNamespaces| The bootstrap name. | N/A |
+|loadManagerClassName|  Name of load manager to use |org.apache.pulsar.broker.loadbalance.impl.SimpleLoadManagerImpl|
+|supportedNamespaceBundleSplitAlgorithms| Supported algorithms name for namespace bundle split |[range_equally_divide,topic_count_equally_divide]|
+|defaultNamespaceBundleSplitAlgorithm| Default algorithm name for namespace bundle split |range_equally_divide|
+|managedLedgerOffloadDriver| The directory for all the offloader implementations `offloadersDirectory=./offloaders`. Driver to use to offload old data to long term storage (Possible values: S3, aws-s3, google-cloud-storage). When using google-cloud-storage, Make sure both Google Cloud Storage and Google Cloud Storage JSON API are enabled for the project (check from Developers Console -> Api&auth -> APIs). ||
+|managedLedgerOffloadMaxThreads|  Maximum number of thread pool threads for ledger offloading |2|
+|managedLedgerOffloadPrefetchRounds|The maximum prefetch rounds for ledger reading for offloading.|1|
+|managedLedgerUnackedRangesOpenCacheSetEnabled|  Use Open Range-Set to cache unacknowledged messages |true|
+|managedLedgerOffloadDeletionLagMs|Delay between a ledger being successfully offloaded to long term storage and the ledger being deleted from bookkeeper | 14400000|
+|managedLedgerOffloadAutoTriggerSizeThresholdBytes|The number of bytes before triggering automatic offload to long term storage |-1 (disabled)|
+|s3ManagedLedgerOffloadRegion|  For Amazon S3 ledger offload, AWS region  ||
+|s3ManagedLedgerOffloadBucket|  For Amazon S3 ledger offload, Bucket to place offloaded ledger into ||
+|s3ManagedLedgerOffloadServiceEndpoint| For Amazon S3 ledger offload, Alternative endpoint to connect to (useful for testing) ||
+|s3ManagedLedgerOffloadMaxBlockSizeInBytes| For Amazon S3 ledger offload, Max block size in bytes. (64MB by default, 5MB minimum) |67108864|
+|s3ManagedLedgerOffloadReadBufferSizeInBytes| For Amazon S3 ledger offload, Read buffer size in bytes (1MB by default)  |1048576|
+|gcsManagedLedgerOffloadRegion|For Google Cloud Storage ledger offload, region where offload bucket is located. Go to this page for more details: https://cloud.google.com/storage/docs/bucket-locations .|N/A|
+|gcsManagedLedgerOffloadBucket|For Google Cloud Storage ledger offload, Bucket to place offloaded ledger into.|N/A|
+|gcsManagedLedgerOffloadMaxBlockSizeInBytes|For Google Cloud Storage ledger offload, the maximum block size in bytes. (64MB by default, 5MB minimum)|67108864|
+|gcsManagedLedgerOffloadReadBufferSizeInBytes|For Google Cloud Storage ledger offload, Read buffer size in bytes. (1MB by default)|1048576|
+|gcsManagedLedgerOffloadServiceAccountKeyFile|For Google Cloud Storage, path to json file containing service account credentials. For more details, see the "Service Accounts" section of https://support.google.com/googleapi/answer/6158849 .|N/A|
+|fileSystemProfilePath|For File System Storage, file system profile path.|../conf/filesystem_offload_core_site.xml|
+|fileSystemURI|For File System Storage, file system uri.|N/A|
+|s3ManagedLedgerOffloadRole| For Amazon S3 ledger offload, provide a role to assume before writing to s3 ||
+|s3ManagedLedgerOffloadRoleSessionName| For Amazon S3 ledger offload, provide a role session name when using a role |pulsar-s3-offload|
+| acknowledgmentAtBatchIndexLevelEnabled | Enable or disable the batch index acknowledgement. | false |
+|enableReplicatedSubscriptions|Whether to enable tracking of replicated subscriptions state across clusters.|true|
+|replicatedSubscriptionsSnapshotFrequencyMillis|The frequency of snapshots for replicated subscriptions tracking.|1000|
+|replicatedSubscriptionsSnapshotTimeoutSeconds|The timeout for building a consistent snapshot for tracking replicated subscriptions state.|30|
+|replicatedSubscriptionsSnapshotMaxCachedPerSubscription|The maximum number of snapshot to be cached per subscription.|10|
+|maxMessagePublishBufferSizeInMB|The maximum memory size for a broker to handle messages that are sent by producers. If the processing message size exceeds this value, the broker stops reading data from the connection. The processing messages refer to the messages that are sent to the broker but the broker has not sent response to the client. Usually the messages are waiting to be written to bookies. It is shared across all the topics running in the same broker. The value `-1` disables t [...]
+|messagePublishBufferCheckIntervalInMillis|Interval between checks to see if message publish buffer size exceeds the maximum. Use `0` or negative number to disable the max publish buffer limiting.|100|
+|retentionCheckIntervalInSeconds|Check between intervals to see if consumed ledgers need to be trimmed. Use 0 or negative number to disable the check.|120|
+| maxMessageSize | Set the maximum size of a message. | 5242880 |
+| preciseTopicPublishRateLimiterEnable | Enable precise topic publish rate limiting. | false |
+| lazyCursorRecovery | Whether to recover cursors lazily when trying to recover a managed ledger backing a persistent topic. It can improve write availability of topics. The caveat is now when recovered ledger is ready to write we're not sure if all old consumers' last mark delete position(ack position) can be recovered or not. So user can make the trade off or have custom logic in application to checkpoint consumer state.| false |  
+|haProxyProtocolEnabled | Enable or disable the [HAProxy](http://www.haproxy.org/) protocol. |false|
+| maxNamespacesPerTenant | The maximum number of namespaces that can be created in each tenant. When the number of namespaces reaches this threshold, the broker rejects the request of creating a new tenant. The default value 0 disables the check. |0|
+| maxTopicsPerNamespace | The maximum number of persistent topics that can be created in the namespace. When the number of topics reaches this threshold, the broker rejects the request of creating a new topic, including the auto-created topics by the producer or consumer, until the number of connected consumers decreases. The default value 0 disables the check. | 0 |
+|subscriptionTypesEnabled| Enable all subscription types, which are exclusive, shared, failover, and key_shared. | Exclusive, Shared, Failover, Key_Shared |
+| managedLedgerInfoCompressionType | Compression type of managed ledger information. <br /><br />Available options are `NONE`, `LZ4`, `ZLIB`, `ZSTD`, and `SNAPPY`). <br /><br />If this value is `NONE` or invalid, the `managedLedgerInfo` is not compressed. <br /><br />**Note** that after enabling this configuration, if you want to degrade a broker, you need to change the value to `NONE` and make sure all ledger metadata is saved without compression. | None |
+| additionalServlets | Additional servlet name. <br /><br />If you have multiple additional servlets, separate them by commas. <br /><br />For example, additionalServlet_1, additionalServlet_2 | N/A |
+| additionalServletDirectory | Location of broker additional servlet NAR directory | ./brokerAdditionalServlet |
+| brokerEntryMetadataInterceptors | Set broker entry metadata interceptors.<br /><br />Multiple interceptors should be separated by commas. <br /><br />Available values:<li>org.apache.pulsar.common.intercept.AppendBrokerTimestampMetadataInterceptor</li><li>org.apache.pulsar.common.intercept.AppendIndexMetadataInterceptor</li> <br /><br />Example<br />brokerEntryMetadataInterceptors=org.apache.pulsar.common.intercept.AppendBrokerTimestampMetadataInterceptor, org.apache.pulsar.common.inter [...]
+| enableExposingBrokerEntryMetadataToClient|Whether to expose broker entry metadata to client or not.<br /><br />Available values:<li>true</li><li>false</li><br />Example<br />enableExposingBrokerEntryMetadataToClient=true  | false |
+| metricsBufferResponse | The configuration is for those broker which there are more than one metrics system access the `/metrics` endpoint. For the purpose of reduce `CPU` and `Memory` usage, metrics data will be generated once in the interval(`managedLedgerStatsPeriodSeconds`) and it will be cached, all `/metrics` requests in the `interval` will return same metrics | false |
+| strictBookieAffinityEnabled | Enable or disable the strict bookie isolation strategy. If enabled, <br /> - `bookie-ensemble` first tries to choose bookies that belong to a namespace's affinity group. If the number of bookies is not enough, then the rest bookies are chosen. <br /> - If namespace has no affinity group, `bookie-ensemble` only chooses bookies that belong to no region. If the number of bookies is not enough, `BKNotEnoughBookiesException` is thrown.| false |
 
 
 #### Deprecated parameters of Broker
@@ -487,7 +484,7 @@ You can set the log level and configuration in the  [log4j2.yaml](https://github
 |webServicePort|  The port used by the standalone broker for HTTP requests  |8080|
 |bindAddress| The hostname or IP address on which the standalone service binds  |0.0.0.0|
 |bindAddresses| Additional Hostname or IP addresses the service binds on: `listener_name:scheme://host:port,...`.  ||
-|advertisedAddress| The hostname or IP address that the standalone service advertises to the outside world. If not set, the value of `InetAddress.getLocalHost().getHostName()` is used. ||
+|advertisedAddress| The hostname or IP address that the standalone service advertises to the outside world. If not set, the value of `InetAddress.getLocalHost().getHostName()` is used.  ||
 | numAcceptorThreads | Number of threads to use for Netty Acceptor | 1 |
 | numIOThreads | Number of threads to use for Netty IO | 2 * Runtime.getRuntime().availableProcessors() |
 | numHttpServerThreads | Number of threads to use for HTTP requests processing | 2 * Runtime.getRuntime().availableProcessors()|
@@ -606,9 +603,8 @@ You can set the log level and configuration in the  [log4j2.yaml](https://github
 |tokenAuthClaim| Specify the token claim that will be used as the authentication "principal" or "role". The "subject" field will be used if this is left blank ||
 |tokenAudienceClaim| The token audience "claim" name, e.g. "aud". It is used to get the audience from token. If it is not set, the audience is not verified. ||
 | tokenAudience | The token audience stands for this broker. The field `tokenAudienceClaim` of a valid token need contains this parameter.| |
-|saslJaasClientAllowedIds|This is a regexp, which limits the range of possible ids which can connect to the Broker using SASL. By default, it is set to `SaslConstants.JAAS_CLIENT_ALLOWED_IDS_DEFAULT`, which is ".*pulsar.*", so only clients whose id contains 'pulsar' are allowed to connect.|.*pulsar.*|
-|saslJaasServerSectionName|Service Principal, for login context name. By default, it is set to `SaslConstants.JAAS_DEFAULT_BROKER_SECTION_NAME`, which is "PulsarBroker".|PulsarBroker|
-|saslJaasServerRoleTokenSignerSecretPath|Secret path for SaslRoleTokenSigner,the Path can be specified like file:///my/saslRoleTokenSignerSecret.key.|N/A|
+|saslJaasClientAllowedIds|This is a regexp, which limits the range of possible ids which can connect to the Broker using SASL. By default, it is set to `SaslConstants.JAAS_CLIENT_ALLOWED_IDS_DEFAULT`, which is ".*pulsar.*", so only clients whose id contains 'pulsar' are allowed to connect.|N/A|
+|saslJaasServerSectionName|Service Principal, for login context name. By default, it is set to `SaslConstants.JAAS_DEFAULT_BROKER_SECTION_NAME`, which is "Broker".|N/A|
 |httpMaxRequestSize|If the value is larger than 0, it rejects all HTTP requests with bodies larged than the configured limit.|-1|
 |exposePreciseBacklogInPrometheus| Enable expose the precise backlog stats, set false to use published counter and consumed counter to calculate, this would be more efficient but may be inaccurate. |false|
 |bookkeeperMetadataServiceUri|Metadata service uri is what BookKeeper used for loading corresponding metadata driver and resolving its metadata service location. This value can be fetched using `bookkeeper shell whatisinstanceid` command in BookKeeper cluster. For example: `zk+hierarchical://localhost:2181/ledgers`. The metadata service uri list can also be semicolon separated values like: `zk+hierarchical://zk1:2181;zk2:2181;zk3:2181/ledgers`.|N/A|
@@ -617,10 +613,10 @@ You can set the log level and configuration in the  [log4j2.yaml](https://github
 |bookkeeperClientAuthenticationParameters|  Parameters associated with the bookkeeperClientAuthenticationParametersName ||
 |bookkeeperClientNumWorkerThreads|  Number of BookKeeper client worker threads. Default is Runtime.getRuntime().availableProcessors()  ||
 |bookkeeperClientTimeoutInSeconds|  Timeout for BookKeeper add and read operations. |30|
-|bookkeeperClientSpeculativeReadTimeoutInMillis|  Speculative reads are initiated if a read request doesn’t complete within a certain time. A value of 0 disables speculative reads. |0|
+|bookkeeperClientSpeculativeReadTimeoutInMillis|  Speculative reads are initiated if a read request doesn’t complete within a certain time. A value of 0 disables speculative reads.  |0|
 |bookkeeperUseV2WireProtocol|Use older Bookkeeper wire protocol with bookie.|true|
 |bookkeeperClientHealthCheckEnabled|  Enable bookie health checks.  |true|
-|bookkeeperClientHealthCheckIntervalSeconds|  The time interval, in seconds, at which health checks are performed. New ledgers are not created during health checks. |60|
+|bookkeeperClientHealthCheckIntervalSeconds|  The time interval, in seconds, at which health checks are performed. New ledgers are not created during health checks.  |60|
 |bookkeeperClientHealthCheckErrorThresholdPerInterval|  Error threshold for health checks.  |5|
 |bookkeeperClientHealthCheckQuarantineTimeInSeconds|  If bookies have more than the allowed number of failures within the time interval specified by bookkeeperClientHealthCheckIntervalSeconds |1800|
 |bookkeeperClientGetBookieInfoIntervalSeconds|Specify options for the GetBookieInfo check. This setting helps ensure the list of bookies that are up to date on the brokers.|86400|
@@ -631,8 +627,8 @@ You can set the log level and configuration in the  [log4j2.yaml](https://github
 |bookkeeperClientMinNumRacksPerWriteQuorum|    |false|
 |bookkeeperClientReorderReadSequenceEnabled|    |false|
 |bookkeeperClientIsolationGroups|||
-|bookkeeperClientSecondaryIsolationGroups| Enable bookie secondary-isolation group if bookkeeperClientIsolationGroups doesn't have enough bookie available. ||
-|bookkeeperClientMinAvailableBookiesInIsolationGroups| Minimum bookies that should be available as part of bookkeeperClientIsolationGroups else broker will include bookkeeperClientSecondaryIsolationGroups bookies in isolated list. ||
+|bookkeeperClientSecondaryIsolationGroups| Enable bookie secondary-isolation group if bookkeeperClientIsolationGroups doesn't have enough bookie available.  ||
+|bookkeeperClientMinAvailableBookiesInIsolationGroups| Minimum bookies that should be available as part of bookkeeperClientIsolationGroups else broker will include bookkeeperClientSecondaryIsolationGroups bookies in isolated list.  ||
 | bookkeeperTLSProviderFactoryClass | Set the client security provider factory class name. | org.apache.bookkeeper.tls.TLSContextFactory |
 | bookkeeperTLSClientAuthentication | Enable TLS authentication with bookie. | false |
 | bookkeeperTLSKeyFileType | Supported type: PEM, JKS, PKCS12.  | PEM |
@@ -689,7 +685,7 @@ You can set the log level and configuration in the  [log4j2.yaml](https://github
 |loadBalancerAutoBundleSplitEnabled|    |false|
 | loadBalancerAutoUnloadSplitBundlesEnabled | Enable/Disable automatic unloading of split bundles. | true |
 |loadBalancerNamespaceBundleMaxTopics|    |1000|
-|loadBalancerNamespaceBundleMaxSessions|  Maximum sessions (producers + consumers) in a bundle, otherwise bundle split will be triggered. <br />To disable the threshold check, set the value to -1. |1000|
+|loadBalancerNamespaceBundleMaxSessions|  Maximum sessions (producers + consumers) in a bundle, otherwise bundle split will be triggered. <br />To disable the threshold check, set the value to -1.  |1000|
 |loadBalancerNamespaceBundleMaxMsgRate|   |1000|
 |loadBalancerNamespaceBundleMaxBandwidthMbytes|   |100|
 |loadBalancerNamespaceMaximumBundles|   |128|
diff --git a/site2/docs/security-kerberos.md b/site2/docs/security-kerberos.md
index 40ff09afa20..dcc15f9009c 100644
--- a/site2/docs/security-kerberos.md
+++ b/site2/docs/security-kerberos.md
@@ -114,8 +114,7 @@ You can have 2 separate JAAS configuration files:
  - Set `authenticationProviders` to choose `AuthenticationProviderSasl`;
  - Set `saslJaasClientAllowedIds` regex for principal that is allowed to connect to broker;
  - Set `saslJaasServerSectionName` that corresponds to the section in JAAS configuration file for broker;
- - Set `saslJaasServerRoleTokenSignerSecretPath` that corresponds to the secret path of role token signer in JAAS configuration file for broker, a short secret would lead to an easily brute forced discovery of the broker's secret;
-
+ 
  To make Pulsar internal admin client work properly, you need to set the configuration in the `broker.conf` file as below: 
  - Set `brokerClientAuthenticationPlugin` to client plugin `AuthenticationSasl`;
  - Set `brokerClientAuthenticationParameters` to value in JSON string `{"saslJaasClientSectionName":"PulsarClient", "serverType":"broker"}`, in which `PulsarClient` is the section name in the `pulsar_jaas.conf` file, and `"serverType":"broker"` indicates that the internal admin client connects to a Pulsar Broker;
@@ -127,7 +126,6 @@ authenticationEnabled=true
 authenticationProviders=org.apache.pulsar.broker.authentication.AuthenticationProviderSasl
 saslJaasClientAllowedIds=.*client.*
 saslJaasServerSectionName=PulsarBroker
-saslJaasServerRoleTokenSignerSecretPath=file:///my/saslRoleTokenSignerSecret.key
 
 ## Authentication settings of the broker itself. Used when the broker connects to other brokers
 brokerClientAuthenticationPlugin=org.apache.pulsar.client.impl.auth.AuthenticationSasl
@@ -309,7 +307,6 @@ authenticationEnabled=true
 authenticationProviders=org.apache.pulsar.broker.authentication.AuthenticationProviderSasl
 saslJaasClientAllowedIds=.*client.*
 saslJaasServerSectionName=PulsarProxy
-saslJaasServerRoleTokenSignerSecretPath=file:///my/saslRoleTokenSignerSecret.key
 
 ## related to be authenticated by broker
 brokerClientAuthenticationPlugin=org.apache.pulsar.client.impl.auth.AuthenticationSasl
@@ -330,7 +327,6 @@ authenticationEnabled=true
 authenticationProviders=org.apache.pulsar.broker.authentication.AuthenticationProviderSasl
 saslJaasClientAllowedIds=.*client.*
 saslJaasServerSectionName=PulsarBroker
-saslJaasServerRoleTokenSignerSecretPath=file:///my/saslRoleTokenSignerSecret.key
 ```
 
 ## Regarding authorization and role token