From 3364a0245cd26a9bbc7583ffcd2fe5d5d99c0452 Mon Sep 17 00:00:00 2001 From: Mercurio Date: Sun, 21 Aug 2022 20:58:01 +0800 Subject: [PATCH 1/3] doc: migrate config docs to pulsar-site Signed-off-by: Mercurio --- .../broker/BaseGenerateDocumentation.java | 6 +- site2/docs/reference-configuration-broker.md | 3904 ----------------- site2/docs/reference-configuration-client.md | 229 - .../reference-configuration-pulsar-proxy.md | 940 ---- .../reference-configuration-standalone.md | 4 +- .../docs/reference-configuration-websocket.md | 501 --- site2/docs/reference-configuration.md | 12 +- site2/website/sidebars.json | 20 +- 8 files changed, 6 insertions(+), 5610 deletions(-) delete mode 100644 site2/docs/reference-configuration-broker.md delete mode 100644 site2/docs/reference-configuration-client.md delete mode 100644 site2/docs/reference-configuration-pulsar-proxy.md delete mode 100644 site2/docs/reference-configuration-websocket.md diff --git a/pulsar-broker-common/src/main/java/org/apache/pulsar/broker/BaseGenerateDocumentation.java b/pulsar-broker-common/src/main/java/org/apache/pulsar/broker/BaseGenerateDocumentation.java index 85cafd9e06094..376ba3bf517c4 100644 --- a/pulsar-broker-common/src/main/java/org/apache/pulsar/broker/BaseGenerateDocumentation.java +++ b/pulsar-broker-common/src/main/java/org/apache/pulsar/broker/BaseGenerateDocumentation.java @@ -124,14 +124,10 @@ public int compare(Field o1, Field o2) { } protected String prefix = """ - :::note - - This page is automatically generated from code files. + !> This page is automatically generated from code files. If you find something inaccurate, feel free to update `"""; protected String suffix = """ `. Do NOT edit this markdown file manually. Manual changes will be overwritten by automatic generation. - - ::: """; protected String generateDocByFieldContext(String className, String type, StringBuilder sb) throws Exception { diff --git a/site2/docs/reference-configuration-broker.md b/site2/docs/reference-configuration-broker.md deleted file mode 100644 index e4a7f5ce9ab30..0000000000000 --- a/site2/docs/reference-configuration-broker.md +++ /dev/null @@ -1,3904 +0,0 @@ -# Broker -:::note - -This page is automatically generated from code files. -If you find something inaccurate, feel free to update `org.apache.pulsar.broker.ServiceConfiguration`. Do NOT edit this markdown file manually. Manual changes will be overwritten by automatic generation. - -::: -## Required -### clusterName -Name of the cluster to which this broker belongs to - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -## Optional -### zookeeperSessionExpiredPolicy -There are two policies to apply when broker metadata session expires: session expired happens, "shutdown" or "reconnect". - - With "shutdown", the broker will be restarted. - - With "reconnect", the broker will keep serving the topics, while attempting to recreate a new session. - -**Default**: `reconnect` - -**Dynamic**: `false` - -**Category**: - -### authenticationEnabled -Enable authentication - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Authentication - -### authenticationProviders -Authentication provider name list, which is a list of class names - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: Authentication - -### authenticationRefreshCheckSeconds -Interval of time for checking for expired authentication credentials - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Authentication - -### brokerClientAuthenticationParameters -Authentication parameters of the authentication plugin the broker is using to connect to other brokers - -**Default**: `` - -**Dynamic**: `true` - -**Category**: Authentication - -### brokerClientAuthenticationPlugin -Authentication settings of the broker itself. - -Used when the broker connects to other brokers, either in same or other clusters. Default uses plugin which disables authentication - -**Default**: `org.apache.pulsar.client.impl.auth.AuthenticationDisabled` - -**Dynamic**: `true` - -**Category**: Authentication - -### brokerClientTrustCertsFilePath -Path for the trusted TLS certificate file for outgoing connection to a server (broker) - -**Default**: `` - -**Dynamic**: `false` - -**Category**: Authentication - -### anonymousUserRole -When this parameter is not empty, unauthenticated users perform as anonymousUserRole - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Authorization - -### authenticateOriginalAuthData -If this flag is set then the broker authenticates the original Auth data else it just accepts the originalPrincipal and authorizes it (if required) - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Authorization - -### authorizationAllowWildcardsMatching -Allow wildcard matching in authorization - -(wildcard matching only applicable if wildcard-char: * presents at first or last position eg: *.pulsar.service, pulsar.service.*) - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Authorization - -### authorizationEnabled -Enforce authorization - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Authorization - -### authorizationProvider -Authorization provider fully qualified class-name - -**Default**: `org.apache.pulsar.broker.authorization.PulsarAuthorizationProvider` - -**Dynamic**: `false` - -**Category**: Authorization - -### proxyRoles -Role names that are treated as `proxy roles`. - -If the broker sees a request with role as proxyRoles - it will demand to see the original client role or certificate. - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: 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 - -**Default**: `[]` - -**Dynamic**: `true` - -**Category**: Authorization - -### additionalServletDirectory -The directory to locate broker additional servlet - -**Default**: `./brokerAdditionalServlet` - -**Dynamic**: `false` - -**Category**: Broker Plugin - -### additionalServlets -List of broker additional servlet to load, which is a list of broker additional servlet names - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: Broker Plugin - -### functionsWorkerEnablePackageManagement -Flag indicates enabling or disabling function worker using unified PackageManagement service. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Functions - -### functionsWorkerEnabled -Flag indicates enabling or disabling function worker on brokers - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Functions - -### functionsWorkerServiceNarPackage -The nar package for the function worker service - -**Default**: `` - -**Dynamic**: `false` - -**Category**: Functions - -### disableHttpDebugMethods -If true, the broker will reject all HTTP requests using the TRACE and TRACK verbs. - This setting may be necessary if the broker is deployed into an environment that uses http port - scanning and flags web servers allowing the TRACE method as insecure. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: HTTP - -### httpMaxRequestSize -If \>0, it will reject all HTTP requests with bodies larged than the configured limit - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: HTTP - -### httpRequestsLimitEnabled -Enable the enforcement of limits on the incoming HTTP requests - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: HTTP - -### httpRequestsMaxPerSecond -Max HTTP requests per seconds allowed. The excess of requests will be rejected with HTTP code 429 (Too many requests) - -**Default**: `100.0` - -**Dynamic**: `false` - -**Category**: HTTP - -### brokerClientSslProvider -The TLS Provider used by internal client to authenticate with other Pulsar brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsCiphers -Specify the tls cipher the internal client will use to negotiate during TLS Handshake (a comma-separated list of ciphers). - -Examples:- [TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256]. - used by the internal client to authenticate with Pulsar brokers - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsEnabledWithKeyStore -Whether internal client use KeyStore type to authenticate with other Pulsar brokers - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsProtocols -Specify the tls protocols the broker will use to negotiate during TLS handshake (a comma-separated list of protocol names). - -Examples:- [TLSv1.3, TLSv1.2] - used by the internal client to authenticate with Pulsar brokers - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsTrustStore -TLS TrustStore path for internal client, used by the internal client to authenticate with Pulsar brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsTrustStorePassword -TLS TrustStore password for internal client, used by the internal client to authenticate with Pulsar brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsTrustStoreType -TLS TrustStore type configuration for internal client: JKS, PKCS12 used by the internal client to authenticate with Pulsar brokers - -**Default**: `JKS` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsEnabledWithKeyStore -Enable TLS with KeyStore type configuration in broker - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsKeyStore -TLS KeyStore path in broker - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsKeyStorePassword -TLS KeyStore password for broker - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsKeyStoreType -TLS KeyStore type configuration in broker: JKS, PKCS12 - -**Default**: `JKS` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsProvider -Specify the TLS provider for the broker service: -When using TLS authentication with CACert, the valid value is either OPENSSL or JDK. -When using TLS authentication with KeyStore, available values can be SunJSSE, Conscrypt and etc. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsTrustStore -TLS TrustStore path in broker - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsTrustStorePassword -TLS TrustStore password for broker, null means empty password. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsTrustStoreType -TLS TrustStore type configuration in broker: JKS, PKCS12 - -**Default**: `JKS` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### defaultNamespaceBundleSplitAlgorithm -Default algorithm name for namespace bundle split - -**Default**: `range_equally_divide` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerAutoBundleSplitEnabled -enable/disable automatic namespace bundle split - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerAutoUnloadSplitBundlesEnabled -enable/disable automatic unloading of split bundles - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerAverageResourceUsageDifferenceThresholdPercentage -Average resource usage difference threshold to determine a broker whether to be a best candidate in LeastResourceUsageWithWeight.(eg: broker1 with 10% resource usage with weight and broker2 with 30% and broker3 with 80% will have 40% average resource usage. The placement strategy can select broker1 and broker2 as best candidates.) - -**Default**: `10` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerBandwithInResourceWeight -BandwithIn Resource Usage Weight - -**Default**: `1.0` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerBandwithOutResourceWeight -BandwithOut Resource Usage Weight - -**Default**: `1.0` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerBrokerMaxTopics -Usage threshold to allocate max number of topics to broker - -**Default**: `50000` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerBrokerOverloadedThresholdPercentage -Usage threshold to determine a broker as over-loaded - -**Default**: `85` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerBrokerThresholdShedderPercentage -Usage threshold to determine a broker whether to start threshold shedder - -**Default**: `10` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerBundleUnloadMinThroughputThreshold -Bundle unload minimum throughput threshold (MB) - -**Default**: `10.0` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerCPUResourceWeight -CPU Resource Usage Weight - -**Default**: `1.0` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerDirectMemoryResourceWeight -Direct Memory Resource Usage Weight - -**Default**: `1.0` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerDistributeBundlesEvenlyEnabled -enable/disable distribute bundles evenly - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerEnabled -Enable load balancer - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Load Balancer - -### loadBalancerHistoryResourcePercentage -Resource history Usage Percentage When adding new resource usage info - -**Default**: `0.9` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerHostUsageCheckIntervalMinutes -Frequency of report to collect, in minutes - -**Default**: `1` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerLoadPlacementStrategy -load balance placement strategy - -**Default**: `org.apache.pulsar.broker.loadbalance.impl.LeastLongTermMessageRate` - -**Dynamic**: `false` - -**Category**: Load Balancer - -### loadBalancerLoadSheddingStrategy -load balance load shedding strategy (It requires broker restart if value is changed using dynamic config). Default is ThresholdShedder since 2.10.0 - -**Default**: `org.apache.pulsar.broker.loadbalance.impl.ThresholdShedder` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerMemoryResourceWeight -Memory Resource Usage Weight - -**Default**: `1.0` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerMsgRateDifferenceShedderThreshold -Message-rate percentage threshold between highest and least loaded brokers for uniform load shedding. (eg: broker1 with 50K msgRate and broker2 with 30K msgRate will have 66% msgRate difference and load balancer can unload bundles from broker-1 to broker-2) - -**Default**: `50.0` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerMsgThroughputMultiplierDifferenceShedderThreshold -Message-throughput threshold between highest and least loaded brokers for uniform load shedding. (eg: broker1 with 450MB msgRate and broker2 with 100MB msgRate will have 4.5 times msgThroughout difference and load balancer can unload bundles from broker-1 to broker-2) - -**Default**: `4.0` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerNamespaceBundleMaxBandwidthMbytes -maximum bandwidth (in + out) in a bundle, otherwise bundle split will be triggered - -**Default**: `100` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerNamespaceBundleMaxMsgRate -maximum msgRate (in + out) in a bundle, otherwise bundle split will be triggered - -**Default**: `30000` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerNamespaceBundleMaxSessions -maximum sessions (producers + consumers) in a bundle, otherwise bundle split will be triggered(disable threshold check with value -1) - -**Default**: `1000` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerNamespaceBundleMaxTopics -maximum topics in a bundle, otherwise bundle split will be triggered - -**Default**: `1000` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerNamespaceMaximumBundles -maximum number of bundles in a namespace - -**Default**: `128` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerOverrideBrokerNicSpeedGbps -Option to override the auto-detected network interfaces max speed - -**Default**: `Optional.empty` - -**Dynamic**: `false` - -**Category**: Load Balancer - -### loadBalancerReportUpdateMaxIntervalMinutes -maximum interval to update load report - -**Default**: `15` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerReportUpdateThresholdPercentage -Percentage of change to trigger load report update - -**Default**: `10` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerResourceQuotaUpdateIntervalMinutes -Interval to flush dynamic resource quota to ZooKeeper - -**Default**: `15` - -**Dynamic**: `false` - -**Category**: Load Balancer - -### loadBalancerSheddingEnabled -Enable/disable automatic bundle unloading for load-shedding - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerSheddingGracePeriodMinutes -Prevent the same topics to be shed and moved to other broker more than once within this timeframe - -**Default**: `30` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadBalancerSheddingIntervalMinutes -Load shedding interval. - -Broker periodically checks whether some traffic should be offload from some over-loaded broker to other under-loaded brokers - -**Default**: `1` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### loadManagerClassName -Name of load manager to use - -**Default**: `org.apache.pulsar.broker.loadbalance.impl.ModularLoadManagerImpl` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### namespaceBundleUnloadingTimeoutMs -Time to wait for the unloading of a namespace bundle - -**Default**: `60000` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### supportedNamespaceBundleSplitAlgorithms -Supported algorithms name for namespace bundle split - -**Default**: `[range_equally_divide, topic_count_equally_divide, specified_positions_divide]` - -**Dynamic**: `true` - -**Category**: Load Balancer - -### aggregatePublisherStatsByProducerName -If true, aggregate publisher stats of PartitionedTopicStats by producerName - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### authenticateMetricsEndpoint -Whether the '/metrics' endpoint requires authentication. Defaults to false.'authenticationEnabled' must also be set for this to take effect. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### exposeBundlesMetricsInPrometheus -Enable expose the broker bundles metrics. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### exposeConsumerLevelMetricsInPrometheus -If true, export consumer level metrics otherwise namespace level - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### exposeManagedCursorMetricsInPrometheus -If true, export managed cursor metrics - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### exposeManagedLedgerMetricsInPrometheus -If true, export managed ledger metrics (aggregated by namespace) - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Metrics - -### 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. Default is false. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### exposeProducerLevelMetricsInPrometheus -If true, export producer level metrics otherwise namespace level - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### exposePublisherStats -If true, export publisher stats when returning topics stats from the admin rest api - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Metrics - -### exposeSubscriptionBacklogSizeInPrometheus -Enable expose the backlog size for each subscription when generating stats. - Locking is used for fetching the status so default to false. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### exposeTopicLevelMetricsInPrometheus -If true, export topic level metrics otherwise namespace level - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Metrics - -### jvmGCMetricsLoggerClassName -Classname of Pluggable JVM GC metrics logger that can log GC specific metrics - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Metrics - -### metricsBufferResponse -If true, export buffered metrics - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### metricsServletTimeoutMs -Time in milliseconds that metrics endpoint would time out. Default is 30s. - Increase it if there are a lot of topics to expose topic-level metrics. - Set it to 0 to disable timeout. - -**Default**: `30000` - -**Dynamic**: `false` - -**Category**: Metrics - -### splitTopicAndPartitionLabelInPrometheus -Enable splitting topic and partition label in Prometheus. - If enabled, a topic name will split into 2 parts, one is topic name without partition index, - another one is partition index, e.g. (topic=xxx, partition=0). - If the topic is a non-partitioned topic, -1 will be used for the partition index. - If disabled, one label to represent the topic and partition, e.g. (topic=xxx-partition-0) - Default is false. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Metrics - -### statsUpdateFrequencyInSecs -Stats update frequency in seconds - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Metrics - -### statsUpdateInitialDelayInSecs -Stats update initial delay in seconds - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Metrics - -### enablePackagesManagement -Enable the packages management service or not - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Packages Management - -### packagesManagementLedgerRootPath -The bookkeeper ledger root path - -**Default**: `/ledgers` - -**Dynamic**: `false` - -**Category**: Packages Management - -### packagesManagementStorageProvider -The packages management service storage service provider - -**Default**: `org.apache.pulsar.packages.management.storage.bookkeeper.BookKeeperPackagesStorageProvider` - -**Dynamic**: `false` - -**Category**: Packages Management - -### packagesReplicas -When the packages storage provider is bookkeeper, you can use this configuration to -control the number of replicas for storing the package - -**Default**: `1` - -**Dynamic**: `false` - -**Category**: Packages Management - -### activeConsumerFailoverDelayTimeMillis -How long to delay rewinding cursor and dispatching messages when active consumer is changed - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Policies - -### backlogQuotaCheckEnabled -Enable backlog quota check. Enforces actions on topic when the quota is reached - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Policies - -### backlogQuotaCheckIntervalInSeconds -How often to check for topics that have reached the quota. It only takes effects when `backlogQuotaCheckEnabled` is true - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Policies - -### backlogQuotaDefaultLimitBytes -Default per-topic backlog quota limit by size, less than 0 means no limitation. default is -1. Increase it if you want to allow larger msg backlog - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: Policies - -### backlogQuotaDefaultLimitGB -@deprecated - Use backlogQuotaDefaultLimitByte instead." - -**Default**: `-1.0` - -**Dynamic**: `false` - -**Category**: Policies - -### backlogQuotaDefaultLimitSecond -Default per-topic backlog quota limit by time in second, less than 0 means no limitation. default is -1. Increase it if you want to allow larger msg backlog - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: Policies - -### backlogQuotaDefaultRetentionPolicy -Default backlog quota retention policy. Default is producer_request_hold - -'producer_request_hold' Policy which holds producer's send request until theresource becomes available (or holding times out) -'producer_exception' Policy which throws javax.jms.ResourceAllocationException to the producer -'consumer_backlog_eviction' Policy which evicts the oldest message from the slowest consumer's backlog - -**Default**: `producer_request_hold` - -**Dynamic**: `false` - -**Category**: Policies - -### brokerDeduplicationEnabled -Set the default behavior for message deduplication in the broker. - -This can be overridden per-namespace. If enabled, broker will reject messages that were already stored in the topic - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Policies - -### brokerDeduplicationEntriesInterval -Number of entries after which a dedup info snapshot is taken. - -A bigger interval will lead to less snapshots being taken though it would increase the topic recovery time, when the entries published after the snapshot need to be replayed - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Policies - -### brokerDeduplicationMaxNumberOfProducers -Maximum number of producer information that it's going to be persisted for deduplication purposes - -**Default**: `10000` - -**Dynamic**: `false` - -**Category**: Policies - -### brokerDeduplicationProducerInactivityTimeoutMinutes -Time of inactivity after which the broker will discard the deduplication information relative to a disconnected producer. Default is 6 hours. - -**Default**: `360` - -**Dynamic**: `false` - -**Category**: Policies - -### brokerDeduplicationSnapshotFrequencyInSeconds -How often is the thread pool scheduled to check whether a snapshot needs to be taken.(disable with value 0) - -**Default**: `120` - -**Dynamic**: `false` - -**Category**: Policies - -### brokerDeduplicationSnapshotIntervalSeconds -If this time interval is exceeded, a snapshot will be taken.It will run simultaneously with `brokerDeduplicationEntriesInterval` - -**Default**: `120` - -**Dynamic**: `false` - -**Category**: Policies - -### brokerDeleteInactivePartitionedTopicMetadataEnabled -Metadata of inactive partitioned topic will not be automatically cleaned up by default. -Note: If `allowAutoTopicCreation` and this option are enabled at the same time, -it may appear that a partitioned topic has just been deleted but is automatically created as a non-partitioned topic. - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Policies - -### brokerDeleteInactiveTopicsEnabled -Enable the deletion of inactive topics. -If only enable this option, will not clean the metadata of partitioned topic. - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Policies - -### brokerDeleteInactiveTopicsFrequencySeconds -How often to check for inactive topics - -**Default**: `60` - -**Dynamic**: `true` - -**Category**: Policies - -### brokerDeleteInactiveTopicsMaxInactiveDurationSeconds -Max duration of topic inactivity in seconds, default is not present -If not present, 'brokerDeleteInactiveTopicsFrequencySeconds' will be used -Topics that are inactive for longer than this value will be deleted - -**Default**: `null` - -**Dynamic**: `true` - -**Category**: Policies - -### brokerDeleteInactiveTopicsMode -Set the inactive topic delete mode. Default is delete_when_no_subscriptions -'delete_when_no_subscriptions' mode only delete the topic which has no subscriptions and no active producers -'delete_when_subscriptions_caught_up' mode only delete the topic that all subscriptions has no backlogs(caught up) and no active producers/consumers - -**Default**: `delete_when_no_subscriptions` - -**Dynamic**: `true` - -**Category**: Policies - -### brokerMaxConnections -The maximum number of connections in the broker. If it exceeds, new connections are rejected. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Policies - -### brokerMaxConnectionsPerIp -The maximum number of connections per IP. If it exceeds, new connections are rejected. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Policies - -### defaultNumberOfNamespaceBundles -When a namespace is created without specifying the number of bundle, this value will be used as the default - -**Default**: `4` - -**Dynamic**: `false` - -**Category**: Policies - -### defaultRetentionSizeInMB -Default retention size - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Policies - -### defaultRetentionTimeInMinutes -Default message retention time - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Policies - -### dispatchThrottlingOnBatchMessageEnabled -Apply dispatch rate limiting on batch message instead individual messages with in batch message. (Default is disabled) - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Policies - -### dispatchThrottlingOnNonBacklogConsumerEnabled -Default dispatch-throttling is disabled for consumers which already caught-up with published messages and don't have backlog. This enables dispatch-throttling for non-backlog consumers as well. - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Policies - -### dispatchThrottlingRatePerReplicatorInByte -Default number of message-bytes dispatching throttling-limit for every replicator in replication. - -Using a value of 0, is disabling replication message-byte dispatch-throttling - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Policies - -### dispatchThrottlingRatePerReplicatorInMsg -Default number of message dispatching throttling-limit for every replicator in replication. - -Using a value of 0, is disabling replication message dispatch-throttling - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Policies - -### dispatchThrottlingRatePerSubscriptionInByte -Default number of message-bytes dispatching throttling-limit for a subscription. - -Using a value of 0, is disabling default message-byte dispatch-throttling. - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Policies - -### dispatchThrottlingRatePerSubscriptionInMsg -Default number of message dispatching throttling-limit for a subscription. - -Using a value of 0, is disabling default message dispatch-throttling. - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Policies - -### dispatchThrottlingRatePerTopicInByte -Default number of message-bytes dispatching throttling-limit for every topic. - -Using a value of 0, is disabling default message-byte dispatch-throttling - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Policies - -### dispatchThrottlingRatePerTopicInMsg -Default number of message dispatching throttling-limit for every topic. - -Using a value of 0, is disabling default message dispatch-throttling - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Policies - -### dispatchThrottlingRateRelativeToPublishRate -Dispatch rate-limiting relative to publish rate. (Enabling flag will make broker to dynamically update dispatch-rate relatively to publish-rate: throttle-dispatch-rate = (publish-rate + configured dispatch-rate) - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Policies - -### enableBrokerSideSubscriptionPatternEvaluation -Enables evaluating subscription pattern on broker side. - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Policies - -### forceDeleteNamespaceAllowed -Allow forced deletion of namespaces. Default is false. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Policies - -### forceDeleteTenantAllowed -Allow forced deletion of tenants. Default is false. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Policies - -### isAllowAutoUpdateSchemaEnabled -Allow schema to be auto updated at broker level. User can override this by 'is_allow_auto_update_schema' of namespace policy. This is enabled by default. - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Policies - -### maxConsumerMetadataSize -Maximum size of Consumer metadata - -**Default**: `1024` - -**Dynamic**: `false` - -**Category**: Policies - -### maxNamespacesPerTenant -The maximum number of namespaces that each tenant can create.This configuration is not precise control, in a concurrent scenario, the threshold will be exceeded - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Policies - -### maxPendingPublishRequestsPerConnection -Max pending publish requests per connection to avoid keeping large number of pending requests in memory. Default: 1000 - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Policies - -### maxTopicsPerNamespace -Max number of topics allowed to be created in the namespace. When the topics reach the max topics of the namespace, the broker should reject the new topic request(include topic auto-created by the producer or consumer) until the number of connected consumers decrease. Using a value of 0, is disabling maxTopicsPerNamespace-limit check. - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Policies - -### maxUnackedMessagesPerBroker -Max number of unacknowledged messages allowed per broker. - - Once this limit reaches, broker will stop dispatching messages to all shared subscription which has higher number of unack messages until subscriptions start acknowledging messages back and unack count reaches to `limit/2`. Using a value of 0, is disabling unackedMessage-limit check and broker doesn't block dispatchers - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Policies - -### 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 and unack count reaches to `maxUnackedMessagesPerConsumer/2`. Using a value of 0, it is disabling unackedMessage-limit check and consumer can receive messages without any restriction - -**Default**: `50000` - -**Dynamic**: `false` - -**Category**: Policies - -### 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 - -**Default**: `200000` - -**Dynamic**: `false` - -**Category**: Policies - -### maxUnackedMessagesPerSubscriptionOnBrokerBlocked -Once broker reaches maxUnackedMessagesPerBroker limit, it blocks subscriptions which has higher unacked messages than this percentage limit and subscription will not receive any new messages until that subscription acks back `limit/2` messages - -**Default**: `0.16` - -**Dynamic**: `false` - -**Category**: Policies - -### messageExpiryCheckIntervalInMinutes -How frequently to proactively check and purge expired messages - -**Default**: `5` - -**Dynamic**: `false` - -**Category**: Policies - -### preciseTimeBasedBacklogQuotaCheck -Whether to enable precise time based backlog quota check. Enabling precise time based backlog quota check will cause broker to read first entry in backlog of the slowest cursor on a ledger which will mostly result in reading entry from BookKeeper's disk which can have negative impact on overall performance. Disabling precise time based backlog quota check will just use the timestamp indicating when a ledger was closed, which is of coarser granularity. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Policies - -### resourceUsageTransportClassName -Default policy for publishing usage reports to system topic is disabled.This enables publishing of usage reports - -**Default**: `` - -**Dynamic**: `false` - -**Category**: Policies - -### resourceUsageTransportPublishIntervalInSecs -Default interval to publish usage reports if resourceUsagePublishToTopic is enabled. - -**Default**: `60` - -**Dynamic**: `true` - -**Category**: Policies - -### subscribeRatePeriodPerConsumerInSecond -Rate period for {subscribeThrottlingRatePerConsumer}. Default is 30s. - -**Default**: `30` - -**Dynamic**: `true` - -**Category**: Policies - -### subscribeThrottlingRatePerConsumer -Too many subscribe requests from a consumer can cause broker rewinding consumer cursors and loading data from bookies, hence causing high network bandwidth usage When the positive value is set, broker will throttle the subscribe requests for one consumer. Otherwise, the throttling will be disabled. The default value of this setting is 0 - throttling is disabled. - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Policies - -### subscriptionExpirationTimeMinutes -How long to delete inactive subscriptions from last consuming. When it is 0, inactive subscriptions are not deleted automatically - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Policies - -### subscriptionExpiryCheckIntervalInMinutes -How frequently to proactively check and purge expired subscription - -**Default**: `5` - -**Dynamic**: `false` - -**Category**: Policies - -### subscriptionKeySharedConsistentHashingReplicaPoints -On KeyShared subscriptions, number of points in the consistent-hashing ring. The higher the number, the more equal the assignment of keys to consumers - -**Default**: `100` - -**Dynamic**: `false` - -**Category**: Policies - -### subscriptionKeySharedEnable -Enable Key_Shared subscription (default is enabled) - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Policies - -### subscriptionKeySharedUseConsistentHashing -On KeyShared subscriptions, with default AUTO_SPLIT mode, use splitting ranges or consistent hashing to reassign keys to new consumers (default is consistent hashing) - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Policies - -### subscriptionPatternMaxLength -Max length of subscription pattern - -**Default**: `50` - -**Dynamic**: `false` - -**Category**: Policies - -### subscriptionRedeliveryTrackerEnabled -Enable subscription message redelivery tracker to send redelivery count to consumer (default is enabled) - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Policies - -### subscriptionTypesEnabled -Enable subscription types (default is all type enabled) - -**Default**: `[Failover, Shared, Key_Shared, Exclusive]` - -**Dynamic**: `true` - -**Category**: Policies - -### topicPublisherThrottlingTickTimeMillis -Tick time to schedule task that checks topic publish rate limiting across all topics Reducing to lower value can give more accuracy while throttling publish but it uses more CPU to perform frequent check. (Disable publish throttling with value 0) - -**Default**: `10` - -**Dynamic**: `true` - -**Category**: Policies - -### ttlDurationDefaultInSeconds -Default ttl for namespaces if ttl is not already configured at namespace policies. (disable default-ttl with value 0) - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Policies - -### unblockStuckSubscriptionEnabled -Broker periodically checks if subscription is stuck and unblock if flag is enabled. (Default is disabled) - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Policies - -### messagingProtocols -List of messaging protocols to load, which is a list of protocol names - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: Protocols - -### protocolHandlerDirectory -The directory to locate messaging protocol handlers - -**Default**: `./protocols` - -**Dynamic**: `false` - -**Category**: Protocols - -### useSeparateThreadPoolForProtocolHandlers -Use a separate ThreadPool for each Protocol Handler - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Protocols - -### brokerClientTlsEnabled -Enable TLS when talking with other brokers in the same cluster (admin operation) or different clusters (replication) - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Replication - -### 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 - -**Default**: `16` - -**Dynamic**: `false` - -**Category**: Replication - -### replicationMetricsEnabled -Enable replication metrics - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Replication - -### replicationPolicyCheckDurationSeconds -Duration to check replication policy to avoid replicator inconsistency due to missing ZooKeeper watch (disable with value 0) - -**Default**: `600` - -**Dynamic**: `false` - -**Category**: Replication - -### replicationProducerQueueSize -Replicator producer queue size. When dynamically modified, it only takes effect for the newly added replicators - -**Default**: `1000` - -**Dynamic**: `true` - -**Category**: Replication - -### replicatorPrefix -replicator prefix used for replicator producer name and cursor name - -**Default**: `pulsar.repl` - -**Dynamic**: `false` - -**Category**: Replication - -### kinitCommand -kerberos kinit command. - -**Default**: `/usr/bin/kinit` - -**Dynamic**: `false` - -**Category**: SASL Authentication Provider - -### saslJaasClientAllowedIds -This is a regexp, which limits the range of possible ids which can connect to the Broker using SASL. - Default value is: ".*pulsar.*", so only clients whose id contains 'pulsar' are allowed to connect. - -**Default**: `.*pulsar.*` - -**Dynamic**: `false` - -**Category**: SASL Authentication Provider - -### saslJaasServerRoleTokenSignerSecretPath -Path to file containing the secret to be used to SaslRoleTokenSigner -The secret can be specified like: -saslJaasServerRoleTokenSignerSecretPath=file:///my/saslRoleTokenSignerSecret.key. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: SASL Authentication Provider - -### saslJaasServerSectionName -Service Principal, for login context name. Default value is "PulsarBroker". - -**Default**: `PulsarBroker` - -**Dynamic**: `false` - -**Category**: SASL Authentication Provider - -### isSchemaValidationEnforced -Enforce schema validation on following cases: - - - if a producer without a schema attempts to produce to a topic with schema, the producer will be - failed to connect. PLEASE be carefully on using this, since non-java clients don't support schema. - if you enable this setting, it will cause non-java clients failed to produce. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Schema - -### schemaCompatibilityStrategy -The schema compatibility strategy in broker level - -**Default**: `FULL` - -**Dynamic**: `false` - -**Category**: Schema - -### schemaRegistryCompatibilityCheckers -The list compatibility checkers to be used in schema registry - -**Default**: `[org.apache.pulsar.broker.service.schema.ProtobufNativeSchemaCompatibilityCheck, org.apache.pulsar.broker.service.schema.JsonSchemaCompatibilityCheck, org.apache.pulsar.broker.service.schema.AvroSchemaCompatibilityCheck]` - -**Dynamic**: `false` - -**Category**: Schema - -### schemaRegistryStorageClassName -The schema storage implementation used by this broker - -**Default**: `org.apache.pulsar.broker.service.schema.BookkeeperSchemaStorageFactory` - -**Dynamic**: `false` - -**Category**: Schema - -### systemTopicSchemaCompatibilityStrategy -The schema compatibility strategy to use for system topics - -**Default**: `ALWAYS_COMPATIBLE` - -**Dynamic**: `false` - -**Category**: Schema - -### acknowledgmentAtBatchIndexLevelEnabled -Whether to enable the acknowledge of batch local index - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### advertisedAddress -Hostname or IP address the service advertises to the outside world. If not set, the value of `InetAddress.getLocalHost().getCanonicalHostName()` is used. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### advertisedListeners -Used to specify multiple advertised listeners for the broker. The value must format as :pulsar://:,multiple listeners should separate with commas.Do not use this configuration with advertisedAddress and brokerServicePort.The Default value is absent means use advertisedAddress and brokerServicePort. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### autoShrinkForConsumerPendingAcksMap -Whether to enable the automatic shrink of pendingAcks map, the default is false, which means it is not enabled. When there are a large number of share or key share consumers in the cluster, it can be enabled to reduce the memory consumption caused by pendingAcks. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### bindAddress -Hostname or IP address the service binds on - -**Default**: `0.0.0.0` - -**Dynamic**: `false` - -**Category**: Server - -### bindAddresses -Used to specify additional bind addresses for the broker. The value must format as :://:, multiple bind addresses should be separated with commas. Associates each bind address with an advertised listener and protocol handler. Note that the brokerServicePort, brokerServicePortTls, webServicePort, and webServicePortTls properties define additional bindings. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### bootstrapNamespaces -A comma-separated list of namespaces to bootstrap - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: Server - -### brokerEntryMetadataInterceptors -List of interceptors for entry metadata. - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: Server - -### brokerEntryPayloadProcessors -List of interceptors for payload processing. - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: Server - -### brokerInterceptors -List of broker interceptor to load, which is a list of broker interceptor names - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: Server - -### brokerInterceptorsDirectory -The directory to locate broker interceptors - -**Default**: `./interceptors` - -**Dynamic**: `false` - -**Category**: Server - -### brokerPublisherThrottlingMaxByteRate -Max Rate(in 1 seconds) of Byte allowed to publish for a broker when broker publish rate limiting enabled. (Disable byte rate limit with value 0) - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Server - -### brokerPublisherThrottlingMaxMessageRate -Max Rate(in 1 seconds) of Message allowed to publish for a broker when broker publish rate limiting enabled. (Disable message rate limit with value 0) - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Server - -### brokerPublisherThrottlingTickTimeMillis -Tick time to schedule task that checks broker publish rate limiting across all topics Reducing to lower value can give more accuracy while throttling publish but it uses more CPU to perform frequent check. (Disable publish throttling with value 0) - -**Default**: `50` - -**Dynamic**: `true` - -**Category**: Server - -### brokerServiceCompactionMonitorIntervalInSeconds -Interval between checks to see if topics with compaction policies need to be compacted - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Server - -### brokerServiceCompactionPhaseOneLoopTimeInSeconds -Timeout for the compaction phase one loop, If the execution time of the compaction phase one loop exceeds this time, the compaction will not proceed. - -**Default**: `30` - -**Dynamic**: `false` - -**Category**: Server - -### brokerServiceCompactionThresholdInBytes -The estimated backlog size is greater than this threshold, compression will be triggered. -Using a value of 0, is disabling compression check. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Server - -### brokerServicePort -The port for serving binary protobuf requests. If set, defines a server binding for bindAddress:brokerServicePort. The Default value is 6650. - -**Default**: `Optional[6650]` - -**Dynamic**: `false` - -**Category**: Server - -### brokerServicePortTls -The port for serving TLS-secured binary protobuf requests. If set, defines a server binding for bindAddress:brokerServicePortTls. - -**Default**: `Optional.empty` - -**Dynamic**: `false` - -**Category**: Server - -### brokerShutdownTimeoutMs -Time to wait for broker graceful shutdown. After this time elapses, the process will be killed - -**Default**: `60000` - -**Dynamic**: `true` - -**Category**: Server - -### clientLibraryVersionCheckEnabled -Enable check for minimum allowed client library version - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Server - -### configurationMetadataStoreUrl -The metadata store URL for the configuration data. If empty, we fall back to use metadataStoreUrl - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### delayedDeliveryEnabled -Whether to enable the delayed delivery for messages. - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Server - -### delayedDeliveryTickTimeMillis -Control the tick time for when retrying on delayed delivery, affecting the accuracy of the delivery time compared to the scheduled time. Default is 1 second. Note that this time is used to configure the HashedWheelTimer's tick time for the InMemoryDelayedDeliveryTrackerFactory. - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Server - -### delayedDeliveryTrackerFactoryClassName -Class name of the factory that implements the delayed deliver tracker - -**Default**: `org.apache.pulsar.broker.delayed.InMemoryDelayedDeliveryTrackerFactory` - -**Dynamic**: `false` - -**Category**: Server - -### disableBrokerInterceptors -Enable or disable the broker interceptor, which is only used for testing for now - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Server - -### dispatchThrottlingRateInByte -Default bytes per second dispatch throttling-limit for whole broker. Using a value of 0, is disabling default message-byte dispatch-throttling - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Server - -### dispatchThrottlingRateInMsg -Default messages per second dispatch throttling-limit for whole broker. Using a value of 0, is disabling default message-byte dispatch-throttling - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Server - -### dispatcherMaxReadBatchSize -Max number of entries to read from bookkeeper. By default it is 100 entries. - -**Default**: `100` - -**Dynamic**: `true` - -**Category**: Server - -### dispatcherMaxReadSizeBytes -Max size in bytes of entries to read from bookkeeper. By default it is 5MB. - -**Default**: `5242880` - -**Dynamic**: `true` - -**Category**: Server - -### dispatcherMaxRoundRobinBatchSize -Max number of entries to dispatch for a shared subscription. By default it is 20 entries. - -**Default**: `20` - -**Dynamic**: `true` - -**Category**: Server - -### dispatcherMinReadBatchSize -Min number of entries to read from bookkeeper. By default it is 1 entries.When there is an error occurred on reading entries from bookkeeper, the broker will backoff the batch size to this minimum number. - -**Default**: `1` - -**Dynamic**: `true` - -**Category**: Server - -### dispatcherReadFailureBackoffInitialTimeInMs -The read failure backoff initial time in milliseconds. By default it is 15s. - -**Default**: `15000` - -**Dynamic**: `true` - -**Category**: Server - -### dispatcherReadFailureBackoffMandatoryStopTimeInMs -The read failure backoff mandatory stop time in milliseconds. By default it is 0s. - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Server - -### dispatcherReadFailureBackoffMaxTimeInMs -The read failure backoff max time in milliseconds. By default it is 60s. - -**Default**: `60000` - -**Dynamic**: `true` - -**Category**: Server - -### enableBusyWait -Option to enable busy-wait settings. Default is false. WARNING: This option will enable spin-waiting on executors and IO threads in order to reduce latency during context switches. The spinning will consume 100% CPU even when the broker is not doing any work. It is recommended to reduce the number of IO threads and BK client threads to only have few CPU cores busy. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### enableNamespaceIsolationUpdateOnTime -Enable namespaceIsolation policy update take effect ontime or not, if set to ture, then the related namespaces will be unloaded after reset policy to make it take effect. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### enableNonPersistentTopics -Enable broker to load non-persistent topics - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Server - -### enablePersistentTopics -Enable broker to load persistent topics - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Server - -### enableReplicatedSubscriptions -Enable tracking of replicated subscriptions state across clusters. - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Server - -### enableRunBookieAutoRecoveryTogether -Enable to run bookie autorecovery along with broker - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### enableRunBookieTogether -Enable to run bookie along with broker - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### encryptionRequireOnProducer -Enforce producer to publish encrypted messages.(default disable). - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### entryFilterNames - Class name of pluggable entry filter that decides whether the entry needs to be filtered.You can use this class to decide which entries can be sent to consumers.Multiple names need to be separated by commas. - -**Default**: `[]` - -**Dynamic**: `true` - -**Category**: Server - -### entryFiltersDirectory - The directory for all the entry filter implementations. - -**Default**: `` - -**Dynamic**: `true` - -**Category**: Server - -### exposingBrokerEntryMetadataToClientEnabled -Enable or disable exposing broker entry metadata to client. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### failureDomainsEnabled -Enable cluster's failure-domain which can distribute brokers into logical region - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Server - -### haProxyProtocolEnabled -Enable or disable the proxy protocol. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### httpServerAcceptQueueSize -Capacity for accept queue in the HTTP server Default is set to 8192. - -**Default**: `8192` - -**Dynamic**: `false` - -**Category**: Server - -### httpServerThreadPoolQueueSize -Capacity for thread pool queue in the HTTP server Default is set to 8192. - -**Default**: `8192` - -**Dynamic**: `false` - -**Category**: Server - -### internalListenerName -Used to specify the internal listener name for the broker.The listener name must contain in the advertisedListeners.The Default value is absent, the broker uses the first listener as the internal listener. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### isDelayedDeliveryDeliverAtTimeStrict -When using the InMemoryDelayedDeliveryTrackerFactory (the default DelayedDeliverTrackerFactory), whether the deliverAt time is strictly followed. When false (default), messages may be sent to consumers before the deliverAt time by as much as the tickTimeMillis. This can reduce the overhead on the broker of maintaining the delayed index for a potentially very short time period. When true, messages will not be sent to consumer until the deliverAt time has passed, and they may be as late as the deliverAt time plus the tickTimeMillis for the topic plus the delayedDeliveryTickTimeMillis. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### keepAliveIntervalSeconds -How often to check pulsar connection is still alive - -**Default**: `30` - -**Dynamic**: `false` - -**Category**: Server - -### 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 can be recovered or not. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### maxConcurrentHttpRequests -Max concurrent web requests - -**Default**: `1024` - -**Dynamic**: `false` - -**Category**: Server - -### maxConcurrentLookupRequest -Max number of concurrent lookup request broker allows to throttle heavy incoming lookup traffic - -**Default**: `50000` - -**Dynamic**: `true` - -**Category**: Server - -### maxConcurrentNonPersistentMessagePerConnection -Max concurrent non-persistent message can be processed per connection - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Server - -### maxConcurrentTopicLoadRequest -Max number of concurrent topic loading request broker allows to control number of zk-operations - -**Default**: `5000` - -**Dynamic**: `true` - -**Category**: Server - -### maxConsumersPerSubscription -Max number of consumers allowed to connect to subscription. - -Once this limit reaches, Broker will reject new consumers until the number of connected consumers decrease. Using a value of 0, is disabling maxConsumersPerSubscription-limit check. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Server - -### maxConsumersPerTopic -Max number of consumers allowed to connect to topic. - -Once this limit reaches, Broker will reject new consumers until the number of connected consumers decrease. Using a value of 0, is disabling maxConsumersPerTopic-limit check. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Server - -### maxHttpServerConnections -Maximum number of inbound http connections. (0 to disable limiting) - -**Default**: `2048` - -**Dynamic**: `false` - -**Category**: Server - -### maxMessagePublishBufferSizeInMB -Max memory size for broker handling messages sending from producers. - - If the processing message size exceed this value, broker will stop read data from the connection. The processing messages means messages are sends to broker but broker have not send response to client, usually waiting to write to bookies. - - It's shared across all the topics running in the same broker. - - Use -1 to disable the memory limitation. Default is 1/2 of direct memory. - - - -**Default**: `2048` - -**Dynamic**: `true` - -**Category**: Server - -### maxMessageSize -Max size of messages. - -**Default**: `5242880` - -**Dynamic**: `false` - -**Category**: Server - -### maxNumPartitionsPerPartitionedTopic -The number of partitions per partitioned topic. -If try to create or update partitioned topics by exceeded number of partitions, then fail. - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Server - -### maxProducersPerTopic -Max number of producers allowed to connect to topic. - -Once this limit reaches, Broker will reject new producers until the number of connected producers decrease. Using a value of 0, is disabling maxProducersPerTopic-limit check. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Server - -### maxPublishRatePerTopicInBytes -Max Rate(in 1 seconds) of Byte allowed to publish for a topic when topic publish rate limiting enabled. (Disable byte rate limit with value 0) - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Server - -### maxPublishRatePerTopicInMessages -Max Rate(in 1 seconds) of Message allowed to publish for a topic when topic publish rate limiting enabled. (Disable byte rate limit with value 0) - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Server - -### maxSameAddressConsumersPerTopic -Max number of consumers with the same IP address allowed to connect to topic. - -Once this limit reaches, Broker will reject new consumers until the number of connected consumers with the same IP address decrease. Using a value of 0, is disabling maxSameAddressConsumersPerTopic-limit check. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Server - -### maxSameAddressProducersPerTopic -Max number of producers with the same IP address allowed to connect to topic. - -Once this limit reaches, Broker will reject new producers until the number of connected producers with the same IP address decrease. Using a value of 0, is disabling maxSameAddressProducersPerTopic-limit check. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Server - -### maxSubscriptionsPerTopic -Max number of subscriptions allowed to subscribe to topic. - -Once this limit reaches, broker will reject new subscription until the number of subscribed subscriptions decrease. - Using a value of 0, is disabling maxSubscriptionsPerTopic limit check. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Server - -### maxTenants -The maximum number of tenants that each pulsar cluster can create.This configuration is not precise control, in a concurrent scenario, the threshold will be exceeded. - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Server - -### messagePublishBufferCheckIntervalInMillis -Interval between checks to see if message publish buffer size is exceed the max message publish buffer size - -**Default**: `100` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreBatchingEnabled -Whether we should enable metadata operations batching - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreBatchingMaxDelayMillis -Maximum delay to impose on batching grouping - -**Default**: `5` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreBatchingMaxOperations -Maximum number of operations to include in a singular batch - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreBatchingMaxSizeKb -Maximum size of a batch - -**Default**: `128` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreCacheExpirySeconds -Metadata store cache expiry time in seconds. - -**Default**: `300` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreConfigPath -Configuration file path for local metadata store. It's supported by RocksdbMetadataStore for now. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### metadataSyncEventTopic -Event topic to sync metadata between separate pulsar clusters on different cloud platforms. - -**Default**: `null` - -**Dynamic**: `true` - -**Category**: Server - - -### configurationMetadataSyncEventTopic -Event topic to sync configuration-metadata between separate pulsar clusters on different cloud platforms. - -**Default**: `null` - -**Dynamic**: `true` - -**Category**: Server - -### metadataStoreOperationTimeoutSeconds -Metadata store operation timeout in seconds. - -**Default**: `30` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreSessionTimeoutMillis -Metadata store session timeout in milliseconds. - -**Default**: `30000` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreUrl -The metadata store URL. - Examples: - * zk:my-zk-1:2181,my-zk-2:2181,my-zk-3:2181 - * my-zk-1:2181,my-zk-2:2181,my-zk-3:2181 (will default to ZooKeeper when the schema is not specified) - * zk:my-zk-1:2181,my-zk-2:2181,my-zk-3:2181/my-chroot-path (to add a ZK chroot path) - - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### numAcceptorThreads -Number of threads to use for Netty Acceptor. Default is set to `1` - -**Default**: `1` - -**Dynamic**: `false` - -**Category**: Server - -### numCacheExecutorThreadPoolSize -Number of thread pool size to use for pulsar zookeeper callback service.The cache executor thread pool is used for restarting global zookeeper session. Default is 10 - -**Default**: `10` - -**Dynamic**: `false` - -**Category**: Server - -### numExecutorThreadPoolSize -Number of threads to use for pulsar broker service. The executor in thread pool will do basic broker operation like load/unload bundle, update managedLedgerConfig, update topic/subscription/replicator message dispatch rate, do leader election etc. Default is set to 20 - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: Server - -### numHttpServerThreads -Number of threads to use for HTTP requests processing Default is set to `2 * Runtime.getRuntime().availableProcessors()` - -**Default**: `16` - -**Dynamic**: `false` - -**Category**: Server - -### numIOThreads -Number of threads to use for Netty IO. Default is set to `2 * Runtime.getRuntime().availableProcessors()` - -**Default**: `16` - -**Dynamic**: `false` - -**Category**: Server - -### numOrderedExecutorThreads -Number of threads to use for orderedExecutor. The ordered executor is used to operate with zookeeper, such as init zookeeper client, get namespace policies from zookeeper etc. It also used to split bundle. Default is 8 - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: Server - -### numWorkerThreadsForNonPersistentTopic -Number of worker threads to serve non-persistent topic - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: Server - -### preciseDispatcherFlowControl -Precise dispatcher flow control according to history message number of each entry - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Server - -### preciseTopicPublishRateLimiterEnable -Enable precise rate limit for topic publish - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### 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) - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Server - -### replicatedSubscriptionsSnapshotFrequencyMillis -Frequency of snapshots for replicated subscriptions tracking. - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Server - -### replicatedSubscriptionsSnapshotMaxCachedPerSubscription -Max number of snapshot to be cached per subscription. - -**Default**: `10` - -**Dynamic**: `false` - -**Category**: Server - -### replicatedSubscriptionsSnapshotTimeoutSeconds -Timeout for building a consistent snapshot for tracking replicated subscriptions state. - -**Default**: `30` - -**Dynamic**: `false` - -**Category**: Server - -### retentionCheckIntervalInSeconds -Check between intervals to see if consumed ledgers need to be trimmed - -**Default**: `120` - -**Dynamic**: `false` - -**Category**: Server - -### skipBrokerShutdownOnOOM -Flag to skip broker shutdown when broker handles Out of memory error - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Server - -### statusFilePath -Path for the file used to determine the rotation status for the broker when responding to service discovery health checks - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### streamingDispatch -Whether to use streaming read dispatcher. Currently is in preview and can be changed in subsequent release. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### strictBookieAffinityEnabled -Enable or disable strict bookie affinity. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### systemTopicEnabled -Enable or disable system topic. - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Server - -### topicFencingTimeoutSeconds -If a topic remains fenced for this number of seconds, it will be closed forcefully. - If it is set to 0 or a negative number, the fenced topic will not be closed. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Server - -### topicLevelPoliciesEnabled -Enable or disable topic level policies, topic level policies depends on the system topic, please enable the system topic first. - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Server - -### topicLoadTimeoutSeconds -Amount of seconds to timeout when loading a topic. In situations with many geo-replicated clusters, this may need raised. - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Server - -### webServicePort -The port for serving http requests - -**Default**: `Optional[8080]` - -**Dynamic**: `false` - -**Category**: Server - -### webServicePortTls -The port for serving https requests - -**Default**: `Optional.empty` - -**Dynamic**: `false` - -**Category**: Server - -### webServiceTlsProvider -Specify the TLS provider for the web service: SunJSSE, Conscrypt and etc. - -**Default**: `Conscrypt` - -**Dynamic**: `false` - -**Category**: Server - -### bookkeeperClientAuthenticationParameters -Parameters for bookkeeper auth plugin - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientAuthenticationParametersName -BookKeeper auth plugin implementation specifics parameters name and values - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientAuthenticationPlugin -Authentication plugin to use when connecting to bookies - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### 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. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientExposeStatsToPrometheus -whether expose managed ledger client stats to prometheus - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientGetBookieInfoIntervalSeconds -Set the interval to periodically check bookie info - -**Default**: `86400` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientGetBookieInfoRetryIntervalSeconds -Set the interval to retry a failed bookie info lookup - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### 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 - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientHealthCheckErrorThresholdPerInterval -Bookies health check error threshold per check interval - -**Default**: `5` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientHealthCheckIntervalSeconds -Bookies health check interval in seconds - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientHealthCheckQuarantineTimeInSeconds -Bookie health check quarantined time in seconds - -**Default**: `1800` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### 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 - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### 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. - -**Default**: `2` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientNumIoThreads -Number of BookKeeper client IO threads. Default is Runtime.getRuntime().availableProcessors() * 2 - -**Default**: `16` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientNumWorkerThreads -Number of BookKeeper client worker threads. Default is Runtime.getRuntime().availableProcessors() - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientQuarantineRatio -bookie quarantine ratio to avoid all clients quarantine the high pressure bookie servers at the same time - -**Default**: `1.0` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientRackawarePolicyEnabled -Enable rack-aware bookie selection policy. - -BK will chose bookies from different racks when forming a new bookie ensemble - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientRegionawarePolicyEnabled -Enable region-aware bookie selection policy. - -BK will chose bookies from different regions and racks when forming a new bookie ensemble - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientReorderReadSequenceEnabled -Enable/disable reordering read sequence on reading entries - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientSecondaryIsolationGroups -Enable bookie secondary-isolation group if bookkeeperClientIsolationGroups doesn't have enough bookie available. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientSeparatedIoThreadsEnabled -Use separated IO threads for BookKeeper client. Default is false, which will use Pulsar IO threads - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### 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 - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientThrottleValue -Throttle value for bookkeeper client - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperClientTimeoutInSeconds -Timeout for BK add / read operations - -**Default**: `30` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperDiskWeightBasedPlacementEnabled -Enable/disable disk weight based placement. Default is false - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### 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. - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperExplicitLacIntervalInMills -Set the interval to check the need for sending an explicit LAC - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperMetadataServiceUri -Metadata service uri that bookkeeper is used for loading corresponding metadata driver and resolving its metadata service location - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperNumberOfChannelsPerBookie -Number of channels per bookie - -**Default**: `16` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTLSCertificateFilePath -Path for the TLS certificate file - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTLSClientAuthentication -Enable tls authentication with bookie - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTLSKeyFilePath -Path for the TLS private key file - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTLSKeyFileType -Supported type: PEM, JKS, PKCS12. Default value: PEM - -**Default**: `PEM` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTLSKeyStorePasswordPath -Path to file containing keystore password, if the client keystore is password protected. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTLSProviderFactoryClass -Set the client security provider factory class name. Default: org.apache.bookkeeper.tls.TLSContextFactory - -**Default**: `org.apache.bookkeeper.tls.TLSContextFactory` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTLSTrustCertTypes -Supported type: PEM, JKS, PKCS12. Default value: PEM - -**Default**: `PEM` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTLSTrustCertsFilePath -Path for the trusted TLS certificate file - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTLSTrustStorePasswordPath -Path to file containing truststore password, if the client truststore is password protected. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperTlsCertFilesRefreshDurationSeconds -Tls cert refresh duration at bookKeeper-client in seconds (0 to disable check) - -**Default**: `300` - -**Dynamic**: `false` - -**Category**: Storage (BookKeeper) - -### bookkeeperUseV2WireProtocol -Use older Bookkeeper wire protocol with bookie - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Storage (BookKeeper) - -### managedLedgerOffloadAutoTriggerSizeThresholdBytes -The number of bytes before triggering automatic offload to long term storage - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: Storage (Ledger Offloading) - -### managedLedgerOffloadDeletionLagMs -Delay between a ledger being successfully offloaded to long term storage, and the ledger being deleted from bookkeeper - -**Default**: `14400000` - -**Dynamic**: `false` - -**Category**: Storage (Ledger Offloading) - -### managedLedgerOffloadDriver -Driver to use to offload old data to long term storage - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Storage (Ledger Offloading) - -### managedLedgerOffloadMaxThreads -Maximum number of thread pool threads for ledger offloading - -**Default**: `2` - -**Dynamic**: `false` - -**Category**: Storage (Ledger Offloading) - -### managedLedgerOffloadPrefetchRounds -Maximum prefetch rounds for ledger reading for offloading - -**Default**: `1` - -**Dynamic**: `false` - -**Category**: Storage (Ledger Offloading) - -### managedLedgerUnackedRangesOpenCacheSetEnabled -Use Open Range-Set to cache unacked messages (it is memory efficient but it can take more cpu) - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Storage (Ledger Offloading) - -### narExtractionDirectory -The directory where nar Extraction of offloaders happens - -**Default**: `/var/folders/0y/136crjnx0sb33_71mj2b33nh0000gn/T/` - -**Dynamic**: `false` - -**Category**: Storage (Ledger Offloading) - -### offloadersDirectory -The directory to locate offloaders - -**Default**: `./offloaders` - -**Dynamic**: `false` - -**Category**: Storage (Ledger Offloading) - -### allowAutoSubscriptionCreation -Allow automated creation of subscriptions if set to true (default value). - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### allowAutoTopicCreation -Allow automated creation of topics if set to true (default value). - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### allowAutoTopicCreationType -The type of topic that is allowed to be automatically created.(partitioned/non-partitioned) - -**Default**: `non-partitioned` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### 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. - -**Default**: `false` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### cacheEvictionByMarkDeletedPosition -Evicting cache data by the slowest markDeletedPosition or readPosition. The default is to evict through readPosition. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### defaultNumPartitions -The number of partitioned topics that is allowed to be automatically createdif allowAutoTopicCreationType is partitioned. - -**Default**: `1` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### managedCursorInfoCompressionType -ManagedCursorInfo compression type, option values (NONE, LZ4, ZLIB, ZSTD, SNAPPY). -If value is NONE, then save the ManagedCursorInfo bytes data directly. - -**Default**: `NONE` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerAddEntryTimeoutSeconds -Add entry timeout when broker tries to publish message to bookkeeper.(0 to disable it) - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerCacheCopyEntries -Whether we should make a copy of the entry payloads when inserting in cache - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerCacheEvictionFrequency -Configure the cache eviction frequency for the managed ledger cache. Default is 100/s - -**Default**: `100.0` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerCacheEvictionTimeThresholdMillis -All entries that have stayed in cache for more than the configured time, will be evicted - -**Default**: `1000` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### managedLedgerCacheEvictionWatermark -Threshold to which bring down the cache level when eviction is triggered - -**Default**: `0.9` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### 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 - -**Default**: `819` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### managedLedgerCursorBackloggedThreshold -Configure the threshold (in number of entries) from where a cursor should be considered 'backlogged' and thus should be set as inactive. - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerCursorMaxEntriesPerLedger -Max number of entries to append to a cursor ledger - -**Default**: `50000` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerCursorPositionFlushSeconds -How frequently to flush the cursor positions that were accumulated due to rate limiting. (seconds). Default is 60 seconds - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerCursorRolloverTimeInSeconds -Max time before triggering a rollover on a cursor ledger - -**Default**: `14400` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerDataReadPriority -Read priority when ledgers exists in both bookkeeper and the second layer storage. - -**Default**: `tiered-storage-first` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerDefaultAckQuorum -Number of guaranteed copies (acks to wait before write is complete) - -**Default**: `2` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerDefaultEnsembleSize -Number of bookies to use when creating a ledger - -**Default**: `2` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerDefaultMarkDeleteRateLimit -Rate limit the amount of writes per second generated by consumer acking the messages - -**Default**: `1.0` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerDefaultWriteQuorum -Number of copies to store for each message - -**Default**: `2` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerDigestType -Default type of checksum to use when writing to BookKeeper. - -Default is `CRC32C`. Other possible options are `CRC32`, `MAC` or `DUMMY` (no checksum). - -**Default**: `CRC32C` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerInactiveLedgerRolloverTimeSeconds -Time to rollover ledger for inactive topic (duration without any publish on that topic). Disable rollover with value 0 (Default value 0) - -**Default**: `0` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### managedLedgerInfoCompressionType -ManagedLedgerInfo compression type, option values (NONE, LZ4, ZLIB, ZSTD, SNAPPY). -If value is invalid or NONE, then save the ManagedLedgerInfo bytes data directly. - -**Default**: `NONE` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerMaxAckQuorum -Max number of guaranteed copies (acks to wait before write is complete) - -**Default**: `5` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerMaxEnsembleSize -Max number of bookies to use when creating a ledger - -**Default**: `5` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerMaxEntriesPerLedger -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: the max rollover time has been reached, the max entries have been written to the ledger, or the max ledger size has been written to the ledger - -**Default**: `50000` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerMaxLedgerRolloverTimeMinutes -Maximum time before forcing a ledger rollover for a topic - -**Default**: `240` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerMaxSizePerLedgerMbytes -Maximum ledger size before triggering a rollover for a topic (MB) - -**Default**: `2048` - -**Dynamic**: `false` - -**Category**: Storage (Managed 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 redelivered in case of crashes. - -**Default**: `10000` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerMaxUnackedRangesToPersistInMetadataStore -Max number of `acknowledgment holes` that can be stored in MetadataStore. - -If number of unack message range is higher than this limit then broker will persist unacked ranges into bookkeeper to avoid additional data overhead into MetadataStore. - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerMaxWriteQuorum -Max number of copies to store for each message - -**Default**: `5` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerMetadataOperationsTimeoutSeconds -operation timeout while updating managed-ledger metadata. - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerMinLedgerRolloverTimeMinutes -Minimum time between ledger rollover for a topic - -**Default**: `10` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerNewEntriesCheckDelayInMillis -New entries check delay for the cursor under the managed ledger. -If no new messages in the topic, the cursor will try to check again after the delay time. -For consumption latency sensitive scenario, can set to a smaller value or set to 0. -Of course, this may degrade consumption throughput. Default is 10ms. - -**Default**: `10` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerNumSchedulerThreads -Number of threads to be used for managed ledger scheduled tasks - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerPassword -Default password to use when writing to BookKeeper. - -Default is ``. - -**Default**: `` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerPrometheusStatsLatencyRolloverSeconds -Managed ledger prometheus stats latency rollover seconds - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerReadEntryTimeoutSeconds -Read entries timeout when broker tries to read messages from bookkeeper (0 to disable it) - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerStatsPeriodSeconds -How frequently to refresh the stats. (seconds). Default is 60 seconds - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerStorageClassName -The class of the managed ledger storage - -**Default**: `org.apache.pulsar.broker.ManagedLedgerClientFactory` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### managedLedgerTraceTaskExecution -Whether trace managed ledger task execution time - -**Default**: `true` - -**Dynamic**: `true` - -**Category**: Storage (Managed Ledger) - -### persistentUnackedRangesWithMultipleEntriesEnabled -If enabled, the maximum "acknowledgment holes" will not be limited and "acknowledgment holes" are stored in multiple entries. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - -### tlsAllowInsecureConnection -Accept untrusted TLS certificate from client - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsCertRefreshCheckDurationSec -Tls cert refresh duration in seconds (set 0 to check on every new connection) - -**Default**: `300` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsCertificateFilePath -Path for the TLS certificate file - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsCiphers -Specify the tls cipher the broker will use to negotiate during TLS Handshake. - -Example:- [TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsEnabled -Enable TLS - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsKeyFilePath -Path for the TLS private key file - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsProtocols -Specify the tls protocols the broker will use to negotiate during TLS Handshake. - -Example:- [TLSv1.3, TLSv1.2] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsRequireTrustedClientCertOnConnect -Specify whether Client certificates are required for TLS Reject. -the Connection if the Client Certificate is not trusted - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsTrustCertsFilePath -Path for the trusted TLS certificate file - -**Default**: `` - -**Dynamic**: `false` - -**Category**: TLS - -### webServiceTlsCiphers -Specify the tls cipher the proxy's web service will use to negotiate during TLS Handshake. - -Example:- [TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: TLS - -### webServiceTlsProtocols -Specify the tls protocols the proxy's web service will use to negotiate during TLS Handshake. - -Example:- [TLSv1.3, TLSv1.2] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: TLS - -### maxActiveTransactionsPerCoordinator -The max active transactions per transaction coordinator, default value 0 indicates no limit. - -**Default**: `0` - -**Dynamic**: `false` - -**Category**: Transaction - -### numTransactionReplayThreadPoolSize -Number of threads to use for pulsar transaction replay PendingAckStore or TransactionBuffer.Default is 5 - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: Transaction - -### transactionBufferClientMaxConcurrentRequests -The max concurrent requests for transaction buffer client. - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Transaction - -### transactionBufferClientOperationTimeoutInMills -The transaction buffer client's operation timeout in milliseconds. - -**Default**: `3000` - -**Dynamic**: `false` - -**Category**: Transaction - -### transactionBufferProviderClassName -Class name for transaction buffer provider - -**Default**: `org.apache.pulsar.broker.transaction.buffer.impl.TopicTransactionBufferProvider` - -**Dynamic**: `false` - -**Category**: Transaction - -### transactionBufferSnapshotMaxTransactionCount -Transaction buffer take snapshot transaction count - -**Default**: `1000` - -**Dynamic**: `false` - -**Category**: Transaction - -### transactionBufferSnapshotMinTimeInMillis -Transaction buffer take snapshot min interval time - -**Default**: `5000` - -**Dynamic**: `false` - -**Category**: Transaction - -### transactionCoordinatorEnabled -Enable transaction coordinator in broker - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Transaction - -### transactionMetadataStoreProviderClassName -Class name for transaction metadata store provider - -**Default**: `org.apache.pulsar.transaction.coordinator.impl.MLTransactionMetadataStoreProvider` - -**Dynamic**: `false` - -**Category**: Transaction - -### transactionPendingAckLogIndexMinLag -MLPendingAckStore maintain a ConcurrentSkipListMap pendingAckLogIndex`,it store the position in pendingAckStore as value and save a position used to determinewhether the previous data can be cleaned up as a key.transactionPendingAckLogIndexMinLag is used to configure the minimum lag between indexes - -**Default**: `500` - -**Dynamic**: `false` - -**Category**: Transaction - -### transactionPendingAckStoreProviderClassName -Class name for transaction pending ack store provider - -**Default**: `org.apache.pulsar.broker.transaction.pendingack.impl.MLPendingAckStoreProvider` - -**Dynamic**: `false` - -**Category**: Transaction - -### isRunningStandalone -Flag indicates whether to run broker in standalone mode - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: WebSocket - -### webSocketConnectionsPerBroker -Number of connections per Broker in Pulsar Client used in WebSocket proxy - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: WebSocket - -### webSocketMaxTextFrameSize -The maximum size of a text message during parsing in WebSocket proxy. - -**Default**: `1048576` - -**Dynamic**: `false` - -**Category**: WebSocket - -### webSocketNumIoThreads -Number of IO threads in Pulsar Client used in WebSocket proxy - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: WebSocket - -### webSocketNumServiceThreads -Number of threads used by Websocket service - -**Default**: `20` - -**Dynamic**: `false` - -**Category**: WebSocket - -### webSocketServiceEnabled -Enable the WebSocket API service in broker - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: WebSocket - -### webSocketSessionIdleTimeoutMillis -Time in milliseconds that idle WebSocket session times out - -**Default**: `300000` - -**Dynamic**: `false` - -**Category**: WebSocket - -## Deprecated -### loadBalancerBrokerComfortLoadLevelPercentage -Usage threshold to determine a broker is having just right level of load (only used by SimpleLoadManagerImpl) - -**Default**: `65` - -**Dynamic**: `false` - -**Category**: Load Balancer - -### loadBalancerBrokerUnderloadedThresholdPercentage -Usage threshold to determine a broker as under-loaded (only used by SimpleLoadManagerImpl) - -**Default**: `50` - -**Dynamic**: `false` - -**Category**: Load Balancer - -### loadBalancerPlacementStrategy -load placement strategy[weightedRandomSelection/leastLoadedServer] (only used by SimpleLoadManagerImpl) - -**Default**: `leastLoadedServer` - -**Dynamic**: `false` - -**Category**: Load Balancer - -### brokerServicePurgeInactiveFrequencyInSeconds -How often broker checks for inactive topics to be deleted (topics with no subscriptions and no one connected) Deprecated in favor of using `brokerDeleteInactiveTopicsFrequencySeconds` - -**Default**: `60` - -**Dynamic**: `false` - -**Category**: Policies - -### replicationTlsEnabled -@deprecated - Use brokerClientTlsEnabled instead. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Replication - -### configurationStoreServers -Configuration store connection string (as a comma-separated list). Deprecated in favor of `configurationMetadataStoreUrl` - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### globalZookeeperServers -Global Zookeeper quorum connection string (as a comma-separated list). Deprecated in favor of using `configurationStoreServers` - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### zooKeeperCacheExpirySeconds -ZooKeeper cache expiry time in seconds. @deprecated - Use metadataStoreCacheExpirySeconds instead. - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: Server - -### zooKeeperOperationTimeoutSeconds -ZooKeeper operation timeout in seconds. @deprecated - Use metadataStoreOperationTimeoutSeconds instead. - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: Server - -### zooKeeperSessionTimeoutMillis -ZooKeeper session timeout in milliseconds. @deprecated - Use metadataStoreSessionTimeoutMillis instead. - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: Server - -### zookeeperServers -The Zookeeper quorum connection string (as a comma-separated list). Deprecated in favour of metadataStoreUrl - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### managedLedgerMaxUnackedRangesToPersistInZooKeeper -Max number of `acknowledgment holes` that can be stored in Zookeeper. - -If number of unack message range is higher than this limit then broker will persist unacked ranges into bookkeeper to avoid additional data overhead into zookeeper. - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: Storage (Managed Ledger) - - diff --git a/site2/docs/reference-configuration-client.md b/site2/docs/reference-configuration-client.md deleted file mode 100644 index a18e823e18423..0000000000000 --- a/site2/docs/reference-configuration-client.md +++ /dev/null @@ -1,229 +0,0 @@ -# Client -:::note - -This page is automatically generated from code files. -If you find something inaccurate, feel free to update `org.apache.pulsar.client.impl.conf.ClientConfigurationData`. Do NOT edit this markdown file manually. Manual changes will be overwritten by automatic generation. - -::: -## Optional -### authParamMap -Authentication map of the client. - -**Default**: `null` - -### authParams -Authentication parameter of the client. - -**Default**: `null` - -### authPluginClassName -Class name of authentication plugin of the client. - -**Default**: `null` - -### authentication -Authentication settings of the client. - -**Default**: `null` - -### concurrentLookupRequest -The number of concurrent lookup requests that can be sent on each broker connection. Setting a maximum prevents overloading a broker. - -**Default**: `5000` - -### connectionTimeoutMs -Duration of waiting for a connection to a broker to be established.If the duration passes without a response from a broker, the connection attempt is dropped. - -**Default**: `10000` - -### connectionsPerBroker -Number of connections established between the client and each Broker. A value of 0 means to disable connection pooling. - -**Default**: `1` - -### dnsLookupBindAddress -The Pulsar client dns lookup bind address, default behavior is bind on 0.0.0.0 - -**Default**: `null` - -### dnsLookupBindPort -The Pulsar client dns lookup bind port, takes effect when dnsLookupBindAddress is configured, default value is 0. - -**Default**: `0` - -### enableBusyWait -Whether to enable BusyWait for EpollEventLoopGroup. - -**Default**: `false` - -### enableTransaction -Whether to enable transaction. - -**Default**: `false` - -### initialBackoffIntervalNanos -Initial backoff interval (in nanosecond). - -**Default**: `100000000` - -### keepAliveIntervalSeconds -Seconds of keeping alive interval for each client broker connection. - -**Default**: `30` - -### listenerName -Listener name for lookup. Clients can use listenerName to choose one of the listeners as the service URL to create a connection to the broker as long as the network is accessible."advertisedListeners" must enabled in broker side. - -**Default**: `null` - -### lookupTimeoutMs -Client lookup timeout (in milliseconds). - -**Default**: `-1` - -### maxBackoffIntervalNanos -Max backoff interval (in nanosecond). - -**Default**: `60000000000` - -### maxLookupRedirects -Maximum times of redirected lookup requests. - -**Default**: `20` - -### maxLookupRequest -Maximum number of lookup requests allowed on each broker connection to prevent overloading a broker. - -**Default**: `50000` - -### maxNumberOfRejectedRequestPerConnection -Maximum number of rejected requests of a broker in a certain time frame (30 seconds) after the current connection is closed and the client creating a new connection to connect to a different broker. - -**Default**: `50` - -### memoryLimitBytes -Limit of client memory usage (in byte). The 64M default can guarantee a high producer throughput. - -**Default**: `67108864` - -### numIoThreads -Number of IO threads. - -**Default**: `1` - -### numListenerThreads -Number of consumer listener threads. - -**Default**: `1` - -### operationTimeoutMs -Client operation timeout (in milliseconds). - -**Default**: `30000` - -### proxyProtocol -Protocol of proxy service. proxyServiceUrl and proxyProtocol must be mutually inclusive. - -**Default**: `null` - -### proxyServiceUrl -URL of proxy service. proxyServiceUrl and proxyProtocol must be mutually inclusive. - -**Default**: `null` - -### requestTimeoutMs -Maximum duration for completing a request. - -**Default**: `60000` - -### serviceUrl -Pulsar cluster HTTP URL to connect to a broker. - -**Default**: `null` - -### serviceUrlProvider -The implementation class of ServiceUrlProvider used to generate ServiceUrl. - -**Default**: `null` - -### socks5ProxyAddress -Address of SOCKS5 proxy. - -**Default**: `null` - -### socks5ProxyPassword -Password of SOCKS5 proxy. - -**Default**: `null` - -### socks5ProxyUsername -User name of SOCKS5 proxy. - -**Default**: `null` - -### sslProvider -The TLS provider used by an internal client to authenticate with other Pulsar brokers. - -**Default**: `null` - -### statsIntervalSeconds -Interval to print client stats (in seconds). - -**Default**: `60` - -### tlsAllowInsecureConnection -Whether the client accepts untrusted TLS certificates from the broker. - -**Default**: `false` - -### tlsCiphers -Set of TLS Ciphers. - -**Default**: `[]` - -### tlsHostnameVerificationEnable -Whether the hostname is validated when the proxy creates a TLS connection with brokers. - -**Default**: `false` - -### tlsProtocols -Protocols of TLS. - -**Default**: `[]` - -### tlsTrustCertsFilePath -Path to the trusted TLS certificate file. - -**Default**: `` - -### tlsTrustStorePassword -Password of TLS TrustStore. - -**Default**: `null` - -### tlsTrustStorePath -Path of TLS TrustStore. - -**Default**: `null` - -### tlsTrustStoreType -TLS TrustStore type configuration. You need to set this configuration when client authentication is required. - -**Default**: `JKS` - -### useKeyStoreTls -Set TLS using KeyStore way. - -**Default**: `false` - -### useTcpNoDelay -Whether to use TCP NoDelay option. - -**Default**: `true` - -### useTls -Whether to use TLS. - -**Default**: `false` - - diff --git a/site2/docs/reference-configuration-pulsar-proxy.md b/site2/docs/reference-configuration-pulsar-proxy.md deleted file mode 100644 index 4cd818963d2d3..0000000000000 --- a/site2/docs/reference-configuration-pulsar-proxy.md +++ /dev/null @@ -1,940 +0,0 @@ -# Pulsar proxy -:::note - -This page is automatically generated from code files. -If you find something inaccurate, feel free to update `org.apache.pulsar.proxy.server.ProxyConfiguration`. Do NOT edit this markdown file manually. Manual changes will be overwritten by automatic generation. - -::: -## Required -## Optional -### brokerClientAuthenticationParameters -The authentication parameters used by the Pulsar proxy to authenticate with Pulsar brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Client Authorization - -### brokerClientAuthenticationPlugin -The authentication plugin used by the Pulsar proxy to authenticate with Pulsar brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Client Authorization - -### brokerClientTrustCertsFilePath -The path to trusted certificates used by the Pulsar proxy to authenticate with Pulsar brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Client Authorization - -### tlsEnabledWithBroker -Whether TLS is enabled when communicating with Pulsar brokers - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Broker Client Authorization - -### brokerServiceURL -The service url points to the broker cluster. URL must have the pulsar:// prefix. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### brokerServiceURLTLS -The tls service url points to the broker cluster. URL must have the pulsar+ssl:// prefix. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### brokerWebServiceURL -The web service url points to the broker cluster - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### brokerWebServiceURLTLS -The tls web service url points to the broker cluster - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### configurationMetadataStoreUrl -The metadata store URL for the configuration data. If empty, we fall back to use metadataStoreUrl - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### functionWorkerWebServiceURL -The web service url points to the function worker cluster. Only configure it when you setup function workers in a separate cluster - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### functionWorkerWebServiceURLTLS -The tls web service url points to the function worker cluster. Only configure it when you setup function workers in a separate cluster - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### metadataStoreUrl -The metadata store URL. - Examples: - * zk:my-zk-1:2181,my-zk-2:2181,my-zk-3:2181 - * my-zk-1:2181,my-zk-2:2181,my-zk-3:2181 (will default to ZooKeeper when the schema is not specified) - * zk:my-zk-1:2181,my-zk-2:2181,my-zk-3:2181/my-chroot-path (to add a ZK chroot path) - - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### brokerProxyAllowedHostNames -Allowed broker target host names. Supports multiple comma separated entries and a wildcard. - -**Default**: `*` - -**Dynamic**: `false` - -**Category**: Broker Proxy - -### brokerProxyAllowedIPAddresses -Allowed broker target ip addresses or ip networks / netmasks. Supports multiple comma separated entries. - -**Default**: `*` - -**Dynamic**: `false` - -**Category**: Broker Proxy - -### brokerProxyAllowedTargetPorts -Allowed broker target ports - -**Default**: `6650,6651` - -**Dynamic**: `false` - -**Category**: Broker Proxy - -### brokerProxyConnectTimeoutMs -Broker proxy connect timeout. -The timeout value for Broker proxy connect timeout is in millisecond. Set to 0 to disable. - -**Default**: `10000` - -**Dynamic**: `false` - -**Category**: Broker Proxy - -### brokerProxyReadTimeoutMs -Broker proxy read timeout. -The timeout value for Broker proxy read timeout is in millisecond. Set to 0 to disable. - -**Default**: `75000` - -**Dynamic**: `false` - -**Category**: Broker Proxy - -### checkActiveBrokers -When enabled, checks that the target broker is active before connecting. zookeeperServers and configurationStoreServers must be configured in proxy configuration for retrieving the active brokers. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Broker Proxy - -### httpInputMaxReplayBufferSize -Http input buffer max size. - -The maximum amount of data that will be buffered for incoming http requests so that the request body can be replayed when the backend broker issues a redirect response. - -**Default**: `5242880` - -**Dynamic**: `false` - -**Category**: HTTP - -### httpNumThreads -Number of threads to use for HTTP requests processing - -**Default**: `16` - -**Dynamic**: `false` - -**Category**: HTTP - -### httpOutputBufferSize -Http output buffer size. - -The amount of data that will be buffered for http requests before it is flushed to the channel. A larger buffer size may result in higher http throughput though it may take longer for the client to see data. If using HTTP streaming via the reverse proxy, this should be set to the minimum value, 1, so that clients see the data as soon as possible. - -**Default**: `32768` - -**Dynamic**: `false` - -**Category**: HTTP - -### httpProxyTimeout -Http proxy timeout. - -The timeout value for HTTP proxy is in millisecond. - -**Default**: `300000` - -**Dynamic**: `false` - -**Category**: HTTP - -### httpRequestsLimitEnabled -Enable the enforcement of limits on the incoming HTTP requests - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: HTTP - -### httpRequestsMaxPerSecond -Max HTTP requests per seconds allowed. The excess of requests will be rejected with HTTP code 429 (Too many requests) - -**Default**: `100.0` - -**Dynamic**: `false` - -**Category**: HTTP - -### httpReverseProxyConfigs -Http directs to redirect to non-pulsar services - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: HTTP - -### brokerClientSslProvider -The TLS Provider used by the Pulsar proxy to authenticate with Pulsar brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsCiphers -Specify the tls cipher the proxy will use to negotiate during TLS Handshake (a comma-separated list of ciphers). - -Examples:- [TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256]. - used by the Pulsar proxy to authenticate with Pulsar brokers - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsEnabledWithKeyStore -Whether the Pulsar proxy use KeyStore type to authenticate with Pulsar brokers - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsProtocols -Specify the tls protocols the broker will use to negotiate during TLS handshake (a comma-separated list of protocol names). - -Examples:- [TLSv1.3, TLSv1.2] - used by the Pulsar proxy to authenticate with Pulsar brokers - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsTrustStore -TLS TrustStore path for proxy, used by the Pulsar proxy to authenticate with Pulsar brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsTrustStorePassword -TLS TrustStore password for proxy, used by the Pulsar proxy to authenticate with Pulsar brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### brokerClientTlsTrustStoreType -TLS TrustStore type configuration for proxy: JKS, PKCS12 used by the Pulsar proxy to authenticate with Pulsar brokers - -**Default**: `JKS` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsEnabledWithKeyStore -Enable TLS with KeyStore type configuration for proxy - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsKeyStore -TLS KeyStore path for proxy - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsKeyStorePassword -TLS KeyStore password for proxy - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsKeyStoreType -TLS KeyStore type configuration for proxy: JKS, PKCS12 - -**Default**: `JKS` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsProvider -Specify the TLS provider for the broker service: -When using TLS authentication with CACert, the valid value is either OPENSSL or JDK. -When using TLS authentication with KeyStore, available values can be SunJSSE, Conscrypt and etc. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsTrustStore -TLS TrustStore path for proxy - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsTrustStorePassword -TLS TrustStore password for proxy, null means empty password. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### tlsTrustStoreType -TLS TrustStore type configuration for proxy: JKS, PKCS12 - -**Default**: `JKS` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### webServiceTlsProvider -Specify the TLS provider for the web service, available values can be SunJSSE, Conscrypt and etc. - -**Default**: `Conscrypt` - -**Dynamic**: `false` - -**Category**: KeyStoreTLS - -### authenticateMetricsEndpoint -Whether the '/metrics' endpoint requires authentication. Defaults to true.'authenticationEnabled' must also be set for this to take effect. - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Proxy Authentication - -### authenticationEnabled -Whether authentication is enabled for the Pulsar proxy - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Proxy Authentication - -### authenticationProviders -Authentication provider name list (a comma-separated list of class names - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: Proxy Authentication - -### anonymousUserRole -When this parameter is not empty, unauthenticated users perform as anonymousUserRole - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Proxy Authorization - -### authorizationEnabled -Whether authorization is enforced by the Pulsar proxy - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Proxy Authorization - -### authorizationProvider -Authorization provider as a fully qualified class name - -**Default**: `org.apache.pulsar.broker.authorization.PulsarAuthorizationProvider` - -**Dynamic**: `false` - -**Category**: Proxy Authorization - -### forwardAuthorizationCredentials -Whether client authorization credentials are forwarded to the broker for re-authorization.Authentication must be enabled via configuring `authenticationEnabled` to be true for thisto take effect - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Proxy Authorization - -### superUserRoles -A list of role names (a comma-separated list of strings) that are treated as `super-user`, meaning they will be able to do all admin operations and publish & consume from all topics - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: Proxy Authorization - -### maxConcurrentInboundConnections -Max concurrent inbound connections. The proxy will reject requests beyond that - -**Default**: `10000` - -**Dynamic**: `false` - -**Category**: RateLimiting - -### maxConcurrentLookupRequests -Max concurrent lookup requests. The proxy will reject requests beyond that - -**Default**: `50000` - -**Dynamic**: `false` - -**Category**: RateLimiting - -### kinitCommand -kerberos kinit command. - -**Default**: `/usr/bin/kinit` - -**Dynamic**: `false` - -**Category**: SASL Authentication Provider - -### saslJaasClientAllowedIds -This is a regexp, which limits the range of possible ids which can connect to the Broker using SASL. - Default value is: ".*pulsar.*", so only clients whose id contains 'pulsar' are allowed to connect. - -**Default**: `.*pulsar.*` - -**Dynamic**: `false` - -**Category**: SASL Authentication Provider - -### saslJaasServerRoleTokenSignerSecretPath -Path to file containing the secret to be used to SaslRoleTokenSigner -The secret can be specified like: -saslJaasServerRoleTokenSignerSecretPath=file:///my/saslRoleTokenSignerSecret.key. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: SASL Authentication Provider - -### saslJaasServerSectionName -Service Principal, for login context name. Default value is "PulsarProxy". - -**Default**: `PulsarProxy` - -**Dynamic**: `false` - -**Category**: SASL Authentication Provider - -### advertisedAddress -Hostname or IP address the service advertises to the outside world. If not set, the value of `InetAddress.getLocalHost().getCanonicalHostName()` is used. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### bindAddress -Hostname or IP address the service binds on - -**Default**: `0.0.0.0` - -**Dynamic**: `false` - -**Category**: Server - -### haProxyProtocolEnabled -Enable or disable the proxy protocol. - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: Server - -### httpServerAcceptQueueSize -Capacity for accept queue in the HTTP server Default is set to 8192. - -**Default**: `8192` - -**Dynamic**: `false` - -**Category**: Server - -### httpServerThreadPoolQueueSize -Capacity for thread pool queue in the HTTP server Default is set to 8192. - -**Default**: `8192` - -**Dynamic**: `false` - -**Category**: Server - -### maxConcurrentHttpRequests -Max concurrent web requests - -**Default**: `1024` - -**Dynamic**: `false` - -**Category**: Server - -### maxHttpServerConnections -Maximum number of inbound http connections. (0 to disable limiting) - -**Default**: `2048` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreCacheExpirySeconds -Metadata store cache expiry time in seconds. - -**Default**: `300` - -**Dynamic**: `false` - -**Category**: Server - -### metadataStoreSessionTimeoutMillis -Metadata store session timeout in milliseconds. - -**Default**: `30000` - -**Dynamic**: `false` - -**Category**: Server - -### narExtractionDirectory -The directory where nar Extraction happens - -**Default**: `/var/folders/0y/136crjnx0sb33_71mj2b33nh0000gn/T/` - -**Dynamic**: `false` - -**Category**: Server - -### numAcceptorThreads -Number of threads used for Netty Acceptor. Default is set to `1` - -**Default**: `1` - -**Dynamic**: `false` - -**Category**: Server - -### numIOThreads -Number of threads used for Netty IO. Default is set to `2 * Runtime.getRuntime().availableProcessors()` - -**Default**: `16` - -**Dynamic**: `false` - -**Category**: Server - -### proxyLogLevel -Proxy log level, default is 0. 0: Do not log any tcp channel info 1: Parse and log any tcp channel info and command info without message body 2: Parse and log channel info, command info and message body - -**Default**: `Optional[0]` - -**Dynamic**: `false` - -**Category**: Server - -### proxyZeroCopyModeEnabled -Enables zero-copy transport of data across network interfaces using the spice. Zero copy mode cannot be used when TLS is enabled or when proxyLogLevel is \> 0. - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: Server - -### servicePort -The port for serving binary protobuf request - -**Default**: `Optional[6650]` - -**Dynamic**: `false` - -**Category**: Server - -### servicePortTls -The port for serving tls secured binary protobuf request - -**Default**: `Optional.empty` - -**Dynamic**: `false` - -**Category**: Server - -### statusFilePath -Path for the file used to determine the rotation status for the proxy instance when responding to service discovery health checks - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Server - -### webServicePort -The port for serving http requests - -**Default**: `Optional[8080]` - -**Dynamic**: `false` - -**Category**: Server - -### webServicePortTls -The port for serving https requests - -**Default**: `Optional.empty` - -**Dynamic**: `false` - -**Category**: Server - -### tlsAllowInsecureConnection -Accept untrusted TLS certificate from client. - -If 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 - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsCertRefreshCheckDurationSec -Tls cert refresh duration in seconds (set 0 to check on every new connection) - -**Default**: `300` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsCertificateFilePath -Path for the TLS certificate file - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsCiphers -Specify the tls cipher the proxy will use to negotiate during TLS Handshake (a comma-separated list of ciphers). - -Examples:- [TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsHostnameVerificationEnabled -Whether the hostname is validated when the proxy creates a TLS connection with brokers - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsKeyFilePath -Path for the TLS private key file - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsProtocols -Specify the tls protocols the broker will use to negotiate during TLS handshake (a comma-separated list of protocol names). - -Examples:- [TLSv1.3, TLSv1.2] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: TLS - -### tlsRequireTrustedClientCertOnConnect -Whether client certificates are required for TLS. - - Connections are rejected if the client certificate isn't trusted - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: TLS - -### 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 - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: TLS - -### webServiceTlsCiphers -Specify the tls cipher the proxy's web service will use to negotiate during TLS Handshake. - -Example:- [TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: TLS - -### webServiceTlsProtocols -Specify the tls protocols the proxy's web service will use to negotiate during TLS Handshake. - -Example:- [TLSv1.3, TLSv1.2] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: TLS - -### clusterName -Name of the cluster to which this broker belongs to - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: WebSocket - -### webSocketServiceEnabled -Enable or disable the WebSocket servlet - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: WebSocket - -### additionalServletDirectory -The directory to locate proxy additional servlet - -**Default**: `./proxyAdditionalServlet` - -**Dynamic**: `false` - -**Category**: proxy plugin - -### additionalServlets -List of proxy additional servlet to load, which is a list of proxy additional servlet names - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: proxy plugin - -### proxyAdditionalServletDirectory -The directory to locate proxy additional servlet - -**Default**: `./proxyAdditionalServlet` - -**Dynamic**: `false` - -**Category**: proxy plugin - -### proxyAdditionalServlets -List of proxy additional servlet to load, which is a list of proxy additional servlet names - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: proxy plugin - -### proxyExtensions -List of messaging protocols to load, which is a list of extension names - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: proxy plugin - -### proxyExtensionsDirectory -The directory to locate proxy extensions - -**Default**: `./proxyextensions` - -**Dynamic**: `false` - -**Category**: proxy plugin - -### useSeparateThreadPoolForProxyExtensions -Use a separate ThreadPool for each Proxy Extension - -**Default**: `true` - -**Dynamic**: `false` - -**Category**: proxy plugin - -## Deprecated -### configurationStoreServers -Configuration store connection string (as a comma-separated list). Deprecated in favor of `configurationMetadataStoreUrl` - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### globalZookeeperServers -Global ZooKeeper quorum connection string (as a comma-separated list) - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### zooKeeperCacheExpirySeconds -ZooKeeper cache expiry time in seconds. @deprecated - Use metadataStoreCacheExpirySeconds instead. - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### zookeeperServers -The ZooKeeper quorum connection string (as a comma-separated list) - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: Broker Discovery - -### zookeeperSessionTimeoutMs -ZooKeeper session timeout in milliseconds. @deprecated - Use metadataStoreSessionTimeoutMillis instead. - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: Broker Discovery - - diff --git a/site2/docs/reference-configuration-standalone.md b/site2/docs/reference-configuration-standalone.md index b5252d303cef3..e7796547aad3c 100644 --- a/site2/docs/reference-configuration-standalone.md +++ b/site2/docs/reference-configuration-standalone.md @@ -1404,13 +1404,13 @@ Deploy the schema compatibility checker for a specific schema type to enforce sc ### schemaCompatibilityStrategy -The schema compatibility strategy at broker level, see [here](schema-evolution-compatibility.md#schema-compatibility-check-strategy) for available values. +The schema compatibility strategy at broker level, see [here](https://pulsar.apache.org/docs/next/schema-evolution-compatibility/#schema-compatibility-check-strategy) for available values. **Default**: FULL ### systemTopicSchemaCompatibilityStrategy -The schema compatibility strategy is used for system topics, see [here](schema-evolution-compatibility.md#schema-compatibility-check-strategy) for available values. +The schema compatibility strategy is used for system topics, see [here](https://pulsar.apache.org/docs/next/schema-evolution-compatibility/#schema-compatibility-check-strategy) for available values. **Default**: ALWAYS_COMPATIBLE diff --git a/site2/docs/reference-configuration-websocket.md b/site2/docs/reference-configuration-websocket.md deleted file mode 100644 index 924f342b5b510..0000000000000 --- a/site2/docs/reference-configuration-websocket.md +++ /dev/null @@ -1,501 +0,0 @@ -# WebSocket -:::note - -This page is automatically generated from code files. -If you find something inaccurate, feel free to update `org.apache.pulsar.websocket.service.WebSocketProxyConfiguration`. Do NOT edit this markdown file manually. Manual changes will be overwritten by automatic generation. - -::: -## Required -### clusterName -Name of the cluster to which this broker belongs to - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -## Optional -### anonymousUserRole -When this parameter is not empty, unauthenticated users perform as anonymousUserRole - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### authenticationEnabled -Enable authentication - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: - -### authenticationProviders -Authentication provider name list, which is a list of class names - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: - -### authorizationAllowWildcardsMatching -Allow wildcard matching in authorization (wildcard matching only applicable if wildcard-char: presents at first or last position. For example: *.pulsar.service,pulsar.service.*) - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: - -### authorizationEnabled -Enforce authorization - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: - -### authorizationProvider -Authorization provider fully qualified class name - -**Default**: `org.apache.pulsar.broker.authorization.PulsarAuthorizationProvider` - -**Dynamic**: `false` - -**Category**: - -### bindAddress -Hostname or IP address the service binds on, default is 0.0.0.0. - -**Default**: `0.0.0.0` - -**Dynamic**: `false` - -**Category**: - -### brokerClientAuthenticationParameters -Proxy authentication parameters used to connect to brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### brokerClientAuthenticationPlugin -Proxy authentication settings used to connect to brokers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### brokerClientTlsEnabled -Enable TLS of broker client - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: - -### brokerClientTrustCertsFilePath -Path for the trusted TLS certificate file for outgoing connection to a server (broker) - -**Default**: `` - -**Dynamic**: `false` - -**Category**: - -### brokerServiceUrl -The broker binary service URL (for produce and consume operations) - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### brokerServiceUrlTls -The secured broker binary service URL (for produce and consume operations) - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### configurationMetadataStoreUrl -Connection string of configuration metadata store servers - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### httpServerAcceptQueueSize -Capacity for accept queue in the HTTP server Default is set to 8192. - -**Default**: `8192` - -**Dynamic**: `false` - -**Category**: - -### httpServerThreadPoolQueueSize -Capacity for thread pool queue in the HTTP server Default is set to 8192. - -**Default**: `8192` - -**Dynamic**: `false` - -**Category**: - -### maxConcurrentHttpRequests -Max concurrent web requests - -**Default**: `1024` - -**Dynamic**: `false` - -**Category**: - -### maxHttpServerConnections -Maximum number of inbound http connections. (0 to disable limiting) - -**Default**: `2048` - -**Dynamic**: `false` - -**Category**: - -### metadataStoreCacheExpirySeconds -Metadata store cache expiry time in seconds. - -**Default**: `300` - -**Dynamic**: `false` - -**Category**: - -### metadataStoreSessionTimeoutMillis -Metadata store session timeout in milliseconds. - -**Default**: `30000` - -**Dynamic**: `false` - -**Category**: - -### numHttpServerThreads -Number of threads to used in HTTP server - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: - -### properties -Key-value properties. Types are all String - -**Default**: `{}` - -**Dynamic**: `false` - -**Category**: - -### serviceUrl -The HTTPS REST service URL to connect to broker - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### serviceUrlTls -The HTTPS REST service TLS URL - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### statusFilePath -Path for the file used to determine the rotation status for the broker when responding to service discovery health checks - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### superUserRoles -Role names that are treated as "super-user", which means they can do all admin operations and publish to or consume from all topics - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: - -### tlsAllowInsecureConnection -Accept untrusted TLS certificate from client - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: - -### tlsCertRefreshCheckDurationSec -TLS cert refresh duration (in seconds). 0 means checking every new connection. - -**Default**: `300` - -**Dynamic**: `false` - -**Category**: - -### tlsCertificateFilePath -Path for the TLS certificate file - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### tlsEnabledWithKeyStore -Enable TLS with KeyStore type configuration for WebSocket - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: - -### tlsKeyFilePath -Path for the TLS private key file - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### tlsKeyStore -TLS KeyStore path in WebSocket - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### tlsKeyStorePassword -TLS KeyStore password for WebSocket - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### tlsKeyStoreType -TLS KeyStore type configuration in WebSocket: JKS, PKCS12 - -**Default**: `JKS` - -**Dynamic**: `false` - -**Category**: - -### tlsProvider -Specify the TLS provider for the WebSocket service: SunJSSE, Conscrypt and etc. - -**Default**: `Conscrypt` - -**Dynamic**: `false` - -**Category**: - -### tlsRequireTrustedClientCertOnConnect -Specify whether client certificates are required for TLS rejecting the connection if the client certificate is not trusted - -**Default**: `false` - -**Dynamic**: `false` - -**Category**: - -### tlsTrustCertsFilePath -Path for the trusted TLS certificate file - -**Default**: `` - -**Dynamic**: `false` - -**Category**: - -### tlsTrustStore -TLS TrustStore path in WebSocket - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### tlsTrustStorePassword -TLS TrustStore password for WebSocket, null means empty password. - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### tlsTrustStoreType -TLS TrustStore type configuration in WebSocket: JKS, PKCS12 - -**Default**: `JKS` - -**Dynamic**: `false` - -**Category**: - -### webServicePort -Port to use to server HTTP request - -**Default**: `Optional[8080]` - -**Dynamic**: `false` - -**Category**: - -### webServicePortTls -Port to use to server HTTPS request - -**Default**: `Optional.empty` - -**Dynamic**: `false` - -**Category**: - -### webServiceTlsCiphers -Specify the tls cipher the proxy's web service will use to negotiate during TLS Handshake. - -Example:- [TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: - -### webServiceTlsProtocols -Specify the tls protocols the proxy's web service will use to negotiate during TLS Handshake. - -Example:- [TLSv1.3, TLSv1.2] - -**Default**: `[]` - -**Dynamic**: `false` - -**Category**: - -### webSocketConnectionsPerBroker -Number of connections per broker in Pulsar client used in WebSocket proxy - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: - -### webSocketMaxTextFrameSize -Maximum size of a text message during parsing in WebSocket proxy - -**Default**: `1048576` - -**Dynamic**: `false` - -**Category**: - -### webSocketNumIoThreads -Number of IO threads in Pulsar client used in WebSocket proxy - -**Default**: `8` - -**Dynamic**: `false` - -**Category**: - -### webSocketNumServiceThreads -Number of threads used by Websocket service - -**Default**: `20` - -**Dynamic**: `false` - -**Category**: - -### webSocketSessionIdleTimeoutMillis -Timeout of idling WebSocket session (in milliseconds) - -**Default**: `300000` - -**Dynamic**: `false` - -**Category**: - -## Deprecated -### configurationStoreServers -Configuration store connection string (as a comma-separated list). Deprecated in favor of `configurationMetadataStoreUrl` - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### globalZookeeperServers -Configuration Store connection string - -**Default**: `null` - -**Dynamic**: `false` - -**Category**: - -### zooKeeperCacheExpirySeconds -ZooKeeper cache expiry time in seconds. @deprecated - Use metadataStoreCacheExpirySeconds instead. - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: - -### zooKeeperSessionTimeoutMillis -ZooKeeper session timeout in milliseconds. @deprecated - Use metadataStoreSessionTimeoutMillis instead. - -**Default**: `-1` - -**Dynamic**: `false` - -**Category**: - - diff --git a/site2/docs/reference-configuration.md b/site2/docs/reference-configuration.md index 7b082fcbf56da..76db94a322ffa 100644 --- a/site2/docs/reference-configuration.md +++ b/site2/docs/reference-configuration.md @@ -4,14 +4,6 @@ title: Pulsar configuration sidebar_label: "Pulsar configuration" --- -You can manage Pulsar configuration by configuration files in the [`conf`](https://github.com/apache/pulsar/tree/master/conf) directory of a Pulsar [installation](getting-started-standalone.md). +You can manage Pulsar configuration by configuration files in the [`conf`](https://github.com/apache/pulsar/tree/master/conf) directory of a Pulsar [installation](https://pulsar.apache.org/docs/next/getting-started-standalone). -- [BookKeeper](./reference-configuration-bookkeeper.md) -- [Broker](./reference-configuration-broker.md) -- [Client](./reference-configuration-client.md) -- [Log4j](./reference-configuration-log4j.md) -- [Log4j shell](./reference-configuration-log4j-shell.md) -- [Standalone](./reference-configuration-standalone.md) -- [WebSocket](./reference-configuration-websocket.md) -- [Pulsar proxy](./reference-configuration-pulsar-proxy.md) -- [ZooKeeper](./reference-configuration-zookeeper.md) \ No newline at end of file +For a full list of configuration of different components, please visit the [Pulsar Reference](https://pulsar.apache.org/reference). diff --git a/site2/website/sidebars.json b/site2/website/sidebars.json index 36734399153cd..17ad74bf9159c 100644 --- a/site2/website/sidebars.json +++ b/site2/website/sidebars.json @@ -337,25 +337,7 @@ "items": [ "reference-terminology", "reference-cli-tools", - { - "type": "category", - "label": "Pulsar Configuration", - "link": { - "type": "doc", - "id": "reference-configuration" - }, - "items": [ - "reference-configuration-bookkeeper", - "reference-configuration-broker", - "reference-configuration-client", - "reference-configuration-log4j", - "reference-configuration-log4j-shell", - "reference-configuration-standalone", - "reference-configuration-websocket", - "reference-configuration-pulsar-proxy", - "reference-configuration-zookeeper" - ] - }, + "reference-configuration", "reference-metrics", "reference-rest-api-overview" ] From 0fe9d1febc22f801d30d5a162c1d25fec6a9bd18 Mon Sep 17 00:00:00 2001 From: Mercurio <32540679+SignorMercurio@users.noreply.github.com> Date: Mon, 22 Aug 2022 16:45:19 +0800 Subject: [PATCH 2/3] Update site2/docs/reference-configuration.md Co-authored-by: Anonymitaet <50226895+Anonymitaet@users.noreply.github.com> --- site2/docs/reference-configuration.md | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/site2/docs/reference-configuration.md b/site2/docs/reference-configuration.md index 76db94a322ffa..402a446831af3 100644 --- a/site2/docs/reference-configuration.md +++ b/site2/docs/reference-configuration.md @@ -6,4 +6,4 @@ sidebar_label: "Pulsar configuration" You can manage Pulsar configuration by configuration files in the [`conf`](https://github.com/apache/pulsar/tree/master/conf) directory of a Pulsar [installation](https://pulsar.apache.org/docs/next/getting-started-standalone). -For a full list of configuration of different components, please visit the [Pulsar Reference](https://pulsar.apache.org/reference). +For a full list of the configuration of different components, see [Pulsar Reference](https://pulsar.apache.org/reference). From 44bbe20b6121db5ccf588be6339e3ecce7a0965f Mon Sep 17 00:00:00 2001 From: Mercurio Date: Wed, 24 Aug 2022 15:30:03 +0800 Subject: [PATCH 3/3] remove reference-configuration-standalone.md as it will be auto-generated Signed-off-by: Mercurio --- .../reference-configuration-standalone.md | 1465 ----------------- site2/tools/generate-config-docs.sh | 35 - 2 files changed, 1500 deletions(-) delete mode 100644 site2/docs/reference-configuration-standalone.md delete mode 100755 site2/tools/generate-config-docs.sh diff --git a/site2/docs/reference-configuration-standalone.md b/site2/docs/reference-configuration-standalone.md deleted file mode 100644 index e7796547aad3c..0000000000000 --- a/site2/docs/reference-configuration-standalone.md +++ /dev/null @@ -1,1465 +0,0 @@ -# Standalone - -## Optional - -### 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). - -**Default**: false - -### metadataStoreUrl - -The quorum connection string for local metadata store - -**Default**: - -### metadataStoreCacheExpirySeconds - -**Default**: Metadata store cache expiry time in seconds - -**Default**: 300 - -### configurationMetadataStoreUrl - -Configuration store connection string (as a comma-separated list) - -**Default**: - -### brokerServicePort - -The port on which the standalone broker listens for connections - -**Default**: 6650 - -### webServicePort - -The port used by the standalone broker for HTTP requests - -**Default**: 8080 - -### webServiceTlsProvider - -The TLS provider for the web service. Available values: `SunJSSE`, `Conscrypt`, and so on. - -**Default**: Conscrypt - -### bindAddress - -The hostname or IP address on which the standalone service binds - -**Default**: 0.0.0.0 - -### bindAddresses - -Additional Hostname or IP addresses the service binds on: `listener_name:scheme://host:port,...`. - -**Default**: - -### advertisedAddress - -The hostname or IP address that the standalone service advertises to the outside world. If not set, the value of `InetAddress.getLocalHost().getCanonicalHostName()` is used. - -**Default**: - -### numAcceptorThreads - -Number of threads to use for Netty Acceptor - -**Default**: 1 - -### numIOThreads - -Number of threads to use for Netty IO - -**Default**: 2 \* Runtime.getRuntime().availableProcessors() - -### numHttpServerThreads - -Number of threads to use for HTTP requests processing - -**Default**: 2 \* Runtime.getRuntime().availableProcessors() - -### isRunningStandalone - -This flag controls features that are meant to be used when running in standalone mode. - -**Default**: N/A - -### clusterName - -The name of the cluster that this broker belongs to. - -**Default**: standalone - -### failureDomainsEnabled - -Enable cluster's failure-domain which can distribute brokers into logical region. - -**Default**: false - -### metadataStoreSessionTimeoutMillis - -Metadata store session timeout, in milliseconds. - -**Default**: 30000 - -### metadataStoreOperationTimeoutSeconds - -Metadata store operation timeout in seconds. - -**Default**: 30 - -### brokerShutdownTimeoutMs - -The time to wait for graceful broker shutdown. After this time elapses, the process will be killed. - -**Default**: 60000 - -### skipBrokerShutdownOnOOM - -Flag to skip broker shutdown when broker handles Out of memory error. - -**Default**: false - -### backlogQuotaCheckEnabled - -Enable the backlog quota check, which enforces a specified action when the quota is reached. - -**Default**: true - -### backlogQuotaCheckIntervalInSeconds - -How often to check for topics that have reached the backlog quota. - -**Default**: 60 - -### backlogQuotaDefaultLimitBytes - -The default per-topic backlog quota limit. Being less than 0 means no limitation. By default, it is -1. - -**Default**: -1 - -### 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. - -**Default**: 0 - -### 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. - -**Default**: true - -### brokerDeleteInactiveTopicsFrequencySeconds - -How often to check for inactive topics, in seconds. - -**Default**: 60 - -### maxPendingPublishRequestsPerConnection - -Maximum pending publish requests per connection to avoid keeping large number of pending requests in memory - -**Default**: 1000 - -### messageExpiryCheckIntervalInMinutes - -How often to proactively check and purged expired messages. - -**Default**: 5 - -### activeConsumerFailoverDelayTimeMillis - -How long to delay rewinding cursor and dispatching messages when active consumer is changed. - -**Default**: 1000 - -### subscriptionExpirationTimeMinutes - -How long to delete inactive subscriptions from last consumption. When it is set to 0, inactive subscriptions are not deleted automatically - -**Default**: 0 - -### subscriptionRedeliveryTrackerEnabled - -Enable subscription message redelivery tracker to send redelivery count to consumer. - -**Default**: true - -### subscriptionKeySharedUseConsistentHashing - -In Key\*Shared subscription type, with default AUTO_SPLIT mode, use splitting ranges or consistent hashing to reassign keys to new consumers. - -**Default**: false - -### subscriptionKeySharedConsistentHashingReplicaPoints - -In Key_Shared subscription type, the number of points in the consistent-hashing ring. The greater the number, the more equal the assignment of keys to consumers. - -**Default**: 100 - -### subscriptionExpiryCheckIntervalInMinutes - -How frequently to proactively check and purge expired subscription - -**Default**: 5 - -### brokerDeduplicationEnabled - -Set the default behavior for message deduplication in the broker. This can be overridden per-namespace. If it is enabled, the broker rejects messages that are already stored in the topic. - -**Default**: false - -### brokerDeduplicationMaxNumberOfProducers - -Maximum number of producer information that it's going to be persisted for deduplication purposes - -**Default**: 10000 - -### brokerDeduplicationEntriesInterval - -Number of entries after which a deduplication information snapshot is taken. A greater interval leads to less snapshots being taken though it would increase the topic recovery time, when the entries published after the snapshot need to be replayed. - -**Default**: 1000 - -### brokerDeduplicationProducerInactivityTimeoutMinutes - -The time of inactivity (in minutes) after which the broker discards deduplication information related to a disconnected producer. - -**Default**: 360 - -### defaultNumberOfNamespaceBundles - -When a namespace is created without specifying the number of bundles, this value is used as the default setting. - -**Default**: 4 - -### clientLibraryVersionCheckEnabled - -Enable checks for minimum allowed client library version. - -**Default**: false - -### clientLibraryVersionCheckAllowUnversioned - -Allow client libraries with no version information - -**Default**: true - -### statusFilePath - -The path for the file used to determine the rotation status for the broker when responding to service discovery health checks - -**Default**: /usr/local/apache/htdocs - -### maxUnackedMessagesPerConsumer - -The maximum number of unacknowledged messages allowed to be received by consumers on a shared subscription. The broker will stop sending messages to a consumer once this limit is reached or until the consumer begins acknowledging messages. A value of 0 disables the unacked message limit check and thus allows consumers to receive messages without any restrictions. - -**Default**: 50000 - -### maxUnackedMessagesPerSubscription - -The same as above, except per subscription rather than per consumer. - -**Default**: 200000 - -### maxUnackedMessagesPerBroker - -Maximum number of unacknowledged messages allowed per broker. Once this limit reaches, the broker stops dispatching messages to all shared subscriptions which has a higher number of unacknowledged messages until subscriptions start acknowledging messages back and unacknowledged messages count reaches to limit/2. When the value is set to 0, unacknowledged message limit check is disabled and broker does not block dispatchers. - -**Default**: 0 - -### maxUnackedMessagesPerSubscriptionOnBrokerBlocked - -Once the broker reaches maxUnackedMessagesPerBroker limit, it blocks subscriptions which have higher unacknowledged messages than this percentage limit and subscription does not receive any new messages until that subscription acknowledges messages back. - -**Default**: 0.16 - -### unblockStuckSubscriptionEnabled - -Broker periodically checks if subscription is stuck and unblock if flag is enabled. - -**Default**: false - -### topicPublisherThrottlingTickTimeMillis - -Tick time to schedule task that checks topic publish rate limiting across all topics. A lower value can improve accuracy while throttling publish but it uses more CPU to perform frequent check. (Disable publish throttling with value 0) - -**Default**: 10 - -### brokerPublisherThrottlingTickTimeMillis - -Tick time to schedule task that checks broker publish rate limiting across all topics. A lower value can improve accuracy while throttling publish but it uses more CPU to perform frequent check. When the value is set to 0, publish throttling is disabled. - -**Default**: 50 - -### brokerPublisherThrottlingMaxMessageRate - -Maximum rate (in 1 second) of messages allowed to publish for a broker if the message rate limiting is enabled. When the value is set to 0, message rate limiting is disabled. - -**Default**: 0 - -### brokerPublisherThrottlingMaxByteRate - -Maximum rate (in 1 second) of bytes allowed to publish for a broker if the byte rate limiting is enabled. When the value is set to 0, the byte rate limiting is disabled. - -**Default**: 0 - -### subscribeThrottlingRatePerConsumer - -Too many subscribe requests from a consumer can cause broker rewinding consumer cursors and loading data from bookies, hence causing high network bandwidth usage. When the positive value is set, broker will throttle the subscribe requests for one consumer. Otherwise, the throttling will be disabled. By default, throttling is disabled. - -**Default**: 0 - -### subscribeRatePeriodPerConsumerInSecond - -Rate period for {subscribeThrottlingRatePerConsumer}. By default, it is 30s. - -**Default**: 30 - -### dispatchThrottlingRateInMsg - -Dispatch throttling-limit of messages for a broker (per second). 0 means the dispatch throttling-limit is disabled. - -**Default**: 0 - -### dispatchThrottlingRateInByte - -Dispatch throttling-limit of bytes for a broker (per second). 0 means the dispatch throttling-limit is disabled. - -**Default**: 0 - -### dispatchThrottlingRatePerTopicInMsg - -Default messages (per second) dispatch throttling-limit for every topic. When the value is set to 0, default message dispatch throttling-limit is disabled. - -**Default**: 0 - -### dispatchThrottlingRatePerTopicInByte - -Default byte (per second) dispatch throttling-limit for every topic. When the value is set to 0, default byte dispatch throttling-limit is disabled. - -**Default**: 0 - -### dispatchThrottlingOnBatchMessageEnabled - -Apply dispatch rate limiting on batch message instead individual messages with in batch message. (Default is disabled). - -**Default**: false - -### dispatchThrottlingRateRelativeToPublishRate - -Enable dispatch rate-limiting relative to publish rate. - -**Default**: false - -### dispatchThrottlingRatePerSubscriptionInMsg - -The defaulted number of message dispatching throttling-limit for a subscription. The value of 0 disables message dispatch-throttling. - -**Default**: 0 - -### dispatchThrottlingRatePerSubscriptionInByte - -The default number of message-bytes dispatching throttling-limit for a subscription. The value of 0 disables message-byte dispatch-throttling. - -**Default**: 0 - -### dispatchThrottlingRatePerReplicatorInMsg - -Dispatch throttling-limit of messages for every replicator in replication (per second). 0 means the dispatch throttling-limit in replication is disabled. - -**Default**: 0 - -### dispatchThrottlingRatePerReplicatorInByte - -Dispatch throttling-limit of bytes for every replicator in replication (per second). 0 means the dispatch throttling-limit is disabled. - -**Default**: 0 - -### dispatchThrottlingOnNonBacklogConsumerEnabled - -Enable dispatch-throttling for both caught up consumers as well as consumers who have backlogs. - -**Default**: true - -### dispatcherMaxReadBatchSize - -The maximum number of entries to read from BookKeeper. By default, it is 100 entries. - -**Default**: 100 - -### dispatcherMaxReadSizeBytes - -The maximum size in bytes of entries to read from BookKeeper. By default, it is 5MB. - -**Default**: 5242880 - -### dispatcherMinReadBatchSize - -The minimum number of entries to read from BookKeeper. By default, it is 1 entry. When there is an error occurred on reading entries from bookkeeper, the broker will backoff the batch size to this minimum number. - -**Default**: 1 - -### dispatcherMaxRoundRobinBatchSize - -The maximum number of entries to dispatch for a shared subscription. By default, it is 20 entries. - -**Default**: 20 - -### preciseDispatcherFlowControl - -Precise dispathcer flow control according to history message number of each entry. - -**Default**: false - -### streamingDispatch - -Whether to use streaming read dispatcher. It can be useful when there's a huge backlog to drain and instead of read with micro batch we can streamline the read from bookkeeper to make the most of consumer capacity till we hit bookkeeper read limit or consumer process limit, then we can use consumer flow control to tune the speed. This feature is currently in preview and can be changed in subsequent release. - -**Default**: false - -### maxConcurrentLookupRequest - -Maximum number of concurrent lookup request that the broker allows to throttle heavy incoming lookup traffic. - -**Default**: 50000 - -### maxConcurrentTopicLoadRequest - -Maximum number of concurrent topic loading request that the broker allows to control the number of zk-operations. - -**Default**: 5000 - -### maxConcurrentNonPersistentMessagePerConnection - -Maximum number of concurrent non-persistent message that can be processed per connection. - -**Default**: 1000 - -### numWorkerThreadsForNonPersistentTopic - -Number of worker threads to serve non-persistent topic. - -**Default**: 8 - -### enablePersistentTopics - -Enable broker to load persistent topics. - -**Default**: true - -### enableNonPersistentTopics - -Enable broker to load non-persistent topics. - -**Default**: true - -### 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. - -**Default**: 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. - -**Default**: 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. - -**Default**: 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. - -**Default**: 0 - -### maxNumPartitionsPerPartitionedTopic - -Maximum number of partitions per partitioned topic. When the value is set to a negative number or is set to 0, the check is disabled. - -**Default**: 0 - -### metadataStoreBatchingEnabled - -Enable metadata operations batching. - -**Default**: true - -### metadataStoreBatchingMaxDelayMillis - -Maximum delay to impose on batching grouping. - -**Default**: 5 - -### metadataStoreBatchingMaxOperations - -Maximum number of operations to include in a singular batch. - -**Default**: 1000 - -### metadataStoreBatchingMaxSizeKb - -Maximum size of a batch. - -**Default**: 128 - -### tlsCertRefreshCheckDurationSec - -TLS certificate refresh duration in seconds. When the value is set to 0, check the TLS certificate on every new connection. - -**Default**: 300 - -### tlsCertificateFilePath - -Path for the TLS certificate file. - -**Default**: - -### tlsKeyFilePath - -Path for the TLS private key file. - -**Default**: - -### tlsTrustCertsFilePath - -Path for the trusted TLS certificate file. - -**Default**: - -### tlsAllowInsecureConnection - -Accept untrusted TLS certificate from the client. If it is set to true, a client with a certificate which cannot be verified with the 'tlsTrustCertsFilePath' certificate is allowed to connect to the server, though the certificate is not be used for client authentication. - -**Default**: false - -### tlsProtocols - -Specify the TLS protocols the broker uses to negotiate during TLS handshake. - -**Default**: - -### tlsCiphers - -Specify the TLS cipher the broker uses to negotiate during TLS Handshake. - -**Default**: - -### tlsRequireTrustedClientCertOnConnect - -Trusted client certificates are required for to connect TLS. Reject the Connection if the client certificate is not trusted. In effect, this requires that all connecting clients perform TLS client authentication. - -**Default**: false - -### tlsEnabledWithKeyStore - -Enable TLS with KeyStore type configuration in broker. - -**Default**: false - -### tlsProvider - -The TLS provider for the broker service. - -When TLS authentication with CACert is used, the valid value is either `OPENSSL` or `JDK`. - -When TLS authentication with KeyStore is used, available options can be `SunJSSE`, `Conscrypt` and so on. - -**Default**: N/A - -### tlsKeyStoreType - -TLS KeyStore type configuration in the broker.
  • JKS
  • PKCS12
  • - -**Default**: JKS - -### tlsKeyStore - -TLS KeyStore path in the broker. - -**Default**: - -### tlsKeyStorePassword - -TLS KeyStore password for the broker. - -**Default**: - -### tlsTrustStoreType - -TLS TrustStore type configuration in the broker
  • JKS
  • PKCS12
  • - -**Default**: JKS - -### tlsTrustStore - -TLS TrustStore path in the broker. - -**Default**: - -### tlsTrustStorePassword - -TLS TrustStore password for the broker. - -**Default**: - -### brokerClientTlsEnabledWithKeyStore - -Configure whether the internal client uses the KeyStore type to authenticate with Pulsar brokers. - -**Default**: false - -### brokerClientSslProvider - -The TLS Provider used by the internal client to authenticate with other Pulsar brokers. - -**Default**: - -### brokerClientTlsTrustStoreType - -TLS TrustStore type configuration for the internal client to authenticate with Pulsar brokers.
  • JKS
  • PKCS12
  • - -**Default**: JKS - -### brokerClientTlsTrustStore - -TLS TrustStore path for the internal client to authenticate with Pulsar brokers. - -**Default**: - -### brokerClientTlsTrustStorePassword - -TLS TrustStore password for the internal client to authenticate with Pulsar brokers. - -**Default**: - -### brokerClientTlsCiphers - -Specify the TLS cipher that the internal client uses to negotiate during TLS Handshake. - -**Default**: - -### brokerClientTlsProtocols - -Specify the TLS protocols that the broker uses to negotiate during TLS handshake. - -**Default**: - -### systemTopicEnabled - -Enable/Disable system topics. - -**Default**: false - -### topicLevelPoliciesEnabled - -Enable or disable topic level policies. Topic level policies depends on the system topic. Please enable the system topic first. - -**Default**: false - -### 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. - -**Default**: 0 - -### proxyRoles - -Role names that are treated as "proxy roles". If the broker receives a request from a proxy role, it demands to authenticate its client role. Note that client role and proxy role cannot use the same name. - -**Default**: - -### authenticationEnabled - -Enable authentication for the broker. - -**Default**: false - -### authenticationProviders - -A comma-separated list of class names for authentication providers. - -**Default**: false - -### authorizationEnabled - -Enforce authorization in brokers. - -**Default**: false - -### authorizationProvider - -Authorization provider fully qualified class-name. - -**Default**: org.apache.pulsar.broker.authorization.PulsarAuthorizationProvider - -### authorizationAllowWildcardsMatching - -Allow wildcard matching in authorization. Wildcard matching is applicable only when the wildcard-character (\*) presents at the **first** or **last** position. - -**Default**: false - -### superUserRoles - -Role names that are treated as “superusers.” Superusers are authorized to perform all admin tasks. - -**Default**: - -### brokerClientAuthenticationPlugin - -The authentication settings of the broker itself. Used when the broker connects to other brokers either in the same cluster or from other clusters. - -**Default**: - -### brokerClientAuthenticationParameters - -The parameters that go along with the plugin specified using brokerClientAuthenticationPlugin. - -**Default**: - -### athenzDomainNames - -Supported Athenz authentication provider domain names as a comma-separated list. - -**Default**: - -### anonymousUserRole - -When this parameter is not empty, unauthenticated users perform as anonymousUserRole. - -**Default**: - -### tokenSettingPrefix - -Configure the prefix of the token related setting like `tokenSecretKey`, `tokenPublicKey`, `tokenAuthClaim`, `tokenPublicAlg`, `tokenAudienceClaim`, and `tokenAudience`. - -**Default**: - -### 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. - -**Default**: - -### 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. - -**Default**: - -### 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 - -**Default**: - -### 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. - -**Default**: - -### tokenAudience - -The token audience stands for this broker. The field `tokenAudienceClaim` of a valid token need contains this parameter. - -**Default**: - -### 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. - -**Default**: N/A - -### saslJaasServerSectionName - -Service Principal, for login context name. By default, it is set to `SaslConstants.JAAS_DEFAULT_BROKER_SECTION_NAME`, which is "Broker". - -**Default**: N/A - -### httpMaxRequestSize - -If the value is larger than 0, it rejects all HTTP requests with bodies larged than the configured limit. - -**Default**: -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. - -**Default**: 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`. - -**Default**: N/A - -### bookkeeperClientAuthenticationPlugin - -Authentication plugin to be used when connecting to bookies (BookKeeper servers). - -**Default**: - -### bookkeeperClientAuthenticationParametersName - -BookKeeper authentication plugin implementation parameters and values. - -**Default**: - -### bookkeeperClientAuthenticationParameters - -Parameters associated with the bookkeeperClientAuthenticationParametersName - -**Default**: - -### bookkeeperClientNumWorkerThreads - -Number of BookKeeper client worker threads. Default is Runtime.getRuntime().availableProcessors() - -**Default**: - -### bookkeeperClientTimeoutInSeconds - -Timeout for BookKeeper add and read operations. - -**Default**: 30 - -### bookkeeperClientSpeculativeReadTimeoutInMillis - -Speculative reads are initiated if a read request doesn’t complete within a certain time. A value of 0 disables speculative reads. - -**Default**: 0 - -### bookkeeperUseV2WireProtocol - -Use older Bookkeeper wire protocol with bookie. - -**Default**: true - -### bookkeeperClientHealthCheckEnabled - -Enable bookie health checks. - -**Default**: true - -### bookkeeperClientHealthCheckIntervalSeconds - -The time interval, in seconds, at which health checks are performed. New ledgers are not created during health checks. - -**Default**: 60 - -### bookkeeperClientHealthCheckErrorThresholdPerInterval - -Error threshold for health checks. - -**Default**: 5 - -### bookkeeperClientHealthCheckQuarantineTimeInSeconds - -If bookies have more than the allowed number of failures within the time interval specified by bookkeeperClientHealthCheckIntervalSeconds - -**Default**: 1800 - -### bookkeeperClientGetBookieInfoIntervalSeconds - -Specify options for the GetBookieInfo check. This setting helps ensure the list of bookies that are up to date on the brokers. - -**Default**: 86400 - -### bookkeeperClientGetBookieInfoRetryIntervalSeconds - -Specify options for the GetBookieInfo check. This setting helps ensure the list of bookies that are up to date on the brokers. - -**Default**: 60 - -### bookkeeperClientRackawarePolicyEnabled - -**Default**: true - -### bookkeeperClientRegionawarePolicyEnabled - -**Default**: false - -### bookkeeperClientMinNumRacksPerWriteQuorum - -**Default**: 2 - -### bookkeeperClientMinNumRacksPerWriteQuorum - -**Default**: false - -### bookkeeperClientReorderReadSequenceEnabled - -**Default**: false - -### bookkeeperClientIsolationGroups - -**Default**: - -### bookkeeperClientSecondaryIsolationGroups - -Enable bookie secondary-isolation group if bookkeeperClientIsolationGroups doesn't have enough bookie available. - -**Default**: - -### bookkeeperClientMinAvailableBookiesInIsolationGroups - -Minimum bookies that should be available as part of bookkeeperClientIsolationGroups else broker will include bookkeeperClientSecondaryIsolationGroups bookies in isolated list. - -**Default**: - -### bookkeeperTLSProviderFactoryClass - -Set the client security provider factory class name. - -**Default**: org.apache.bookkeeper.tls.TLSContextFactory - -### bookkeeperTLSClientAuthentication - -Enable TLS authentication with bookie. - -**Default**: false - -### bookkeeperTLSKeyFileType - -Supported type: PEM, JKS, PKCS12. - -**Default**: PEM - -### bookkeeperTLSTrustCertTypes - -Supported type: PEM, JKS, PKCS12. - -**Default**: PEM - -### bookkeeperTLSKeyStorePasswordPath - -Path to file containing keystore password, if the client keystore is password protected. - -**Default**: - -### bookkeeperTLSTrustStorePasswordPath - -Path to file containing truststore password, if the client truststore is password protected. - -**Default**: - -### bookkeeperTLSKeyFilePath - -Path for the TLS private key file. - -**Default**: - -### bookkeeperTLSCertificateFilePath - -Path for the TLS certificate file. - -**Default**: - -### bookkeeperTLSTrustCertsFilePath - -Path for the trusted TLS certificate file. - -**Default**: - -### bookkeeperTlsCertFilesRefreshDurationSeconds - -Tls cert refresh duration at bookKeeper-client in seconds (0 to disable check). - -**Default**: - -### bookkeeperDiskWeightBasedPlacementEnabled - -Enable/Disable disk weight based placement. - -**Default**: false - -### bookkeeperExplicitLacIntervalInMills - -Set the interval to check the need for sending an explicit LAC. When the value is set to 0, no explicit LAC is sent. - -**Default**: 0 - -### bookkeeperClientExposeStatsToPrometheus - -Expose BookKeeper client managed ledger stats to Prometheus. - -**Default**: false - -### managedLedgerDefaultEnsembleSize - -**Default**: 1 - -### managedLedgerDefaultWriteQuorum - -**Default**: 1 - -### managedLedgerDefaultAckQuorum - -**Default**: 1 - -### managedLedgerDigestType - -Default type of checksum to use when writing to BookKeeper. - -**Default**: CRC32C - -### managedLedgerNumSchedulerThreads - -Number of threads to be used for managed ledger scheduled tasks. - -**Default**: Runtime.getRuntime().availableProcessors() - -### managedLedgerCacheSizeMB - -**Default**: N/A - -### managedLedgerCacheCopyEntries - -Whether to copy the entry payloads when inserting in cache. - -**Default**: false - -### managedLedgerCacheEvictionWatermark - -**Default**: 0.9 - -### managedLedgerCacheEvictionFrequency - -Configure the cache eviction frequency for the managed ledger cache (evictions/sec) - -**Default**: 100.0 - -### managedLedgerCacheEvictionTimeThresholdMillis - -All entries that have stayed in cache for more than the configured time, will be evicted - -**Default**: 1000 - -### managedLedgerCursorBackloggedThreshold - -Configure the threshold (in number of entries) from where a cursor should be considered 'backlogged' and thus should be set as inactive. - -**Default**: 1000 - -### managedLedgerUnackedRangesOpenCacheSetEnabled - -Use Open Range-Set to cache unacknowledged messages - -**Default**: true - -### managedLedgerDefaultMarkDeleteRateLimit - -**Default**: 0.1 - -### managedLedgerMaxEntriesPerLedger - -**Default**: 50000 - -### managedLedgerMinLedgerRolloverTimeMinutes - -**Default**: 10 - -### managedLedgerMaxLedgerRolloverTimeMinutes - -**Default**: 240 - -### managedLedgerCursorMaxEntriesPerLedger - -**Default**: 50000 - -### managedLedgerCursorRolloverTimeInSeconds - -**Default**: 14400 - -### managedLedgerMaxSizePerLedgerMbytes - -Maximum ledger size before triggering a rollover for a topic. - -**Default**: 2048 - -### managedLedgerMaxUnackedRangesToPersist - -Maximum number of "acknowledgment holes" that are going to be persistently stored. When acknowledging out of order, a consumer leaves holes that are supposed to be quickly filled by acknowledging 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 is only tracked in memory and messages are redelivered in case of crashes. - -**Default**: 10000 - -### 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. - -**Default**: 1000 - -### autoSkipNonRecoverableData - -**Default**: false - -### managedLedgerMetadataOperationsTimeoutSeconds - -Operation timeout while updating managed-ledger metadata. - -**Default**: 60 - -### managedLedgerReadEntryTimeoutSeconds - -Read entries timeout when the broker tries to read messages from BookKeeper. - -**Default**: 0 - -### managedLedgerAddEntryTimeoutSeconds - -Add entry timeout when the broker tries to publish messages to BookKeeper. - -**Default**: 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. Of course, a smaller value may degrade consumption throughput. - -**Default**: 10 - -### managedLedgerPrometheusStatsLatencyRolloverSeconds - -Managed ledger prometheus stats latency rollover seconds. - -**Default**: 60 - -### managedLedgerTraceTaskExecution - -Whether to trace managed ledger task execution time. - -**Default**: true - -### loadBalancerEnabled - -**Default**: false - -### loadBalancerPlacementStrategy - -**Default**: weightedRandomSelection - -### loadBalancerReportUpdateThresholdPercentage - -**Default**: 10 - -### loadBalancerReportUpdateMaxIntervalMinutes - -**Default**: 15 - -### loadBalancerHostUsageCheckIntervalMinutes - -**Default**: 1 - -### loadBalancerSheddingIntervalMinutes - -**Default**: 30 - -### loadBalancerSheddingGracePeriodMinutes - -**Default**: 30 - -### loadBalancerBrokerMaxTopics - -**Default**: 50000 - -### loadBalancerBrokerUnderloadedThresholdPercentage - -**Default**: 1 - -### loadBalancerBrokerOverloadedThresholdPercentage - -**Default**: 85 - -### loadBalancerResourceQuotaUpdateIntervalMinutes - -**Default**: 15 - -### loadBalancerBrokerComfortLoadLevelPercentage - -**Default**: 65 - -### loadBalancerAutoBundleSplitEnabled - -**Default**: false - -### loadBalancerAutoUnloadSplitBundlesEnabled - -Enable/Disable automatic unloading of split bundles. - -**Default**: true - -### loadBalancerNamespaceBundleMaxTopics - -**Default**: 1000 - -### loadBalancerNamespaceBundleMaxSessions - -Maximum sessions (producers + consumers) in a bundle, otherwise bundle split will be triggered. - -To disable the threshold check, set the value to -1. - -**Default**: 1000 - -### loadBalancerNamespaceBundleMaxMsgRate - -**Default**: 1000 - -### loadBalancerNamespaceBundleMaxBandwidthMbytes - -**Default**: 100 - -### loadBalancerNamespaceMaximumBundles - -**Default**: 128 - -### loadBalancerBrokerThresholdShedderPercentage - -The broker resource usage threshold. When the broker resource usage is greater than the pulsar cluster average resource usage, the threshold shedder is triggered to offload bundles from the broker. It only takes effect in the ThresholdShedder strategy. - -**Default**: 10 - -### loadBalancerMsgRateDifferenceShedderThreshold - -Message-rate percentage threshold between highest and least loaded brokers for uniform load shedding. - -**Default**: 50 - -### loadBalancerMsgThroughputMultiplierDifferenceShedderThreshold - -Message-throughput threshold between highest and least loaded brokers for uniform load shedding. - -**Default**: 4 - -### loadBalancerHistoryResourcePercentage - -The history usage when calculating new resource usage. It only takes effect in the ThresholdShedder strategy. - -**Default**: 0.9 - -### loadBalancerBandwithInResourceWeight - -The BandWithIn usage weight when calculating new resource usage. It only takes effect in the ThresholdShedder strategy. - -**Default**: 1.0 - -### loadBalancerBandwithOutResourceWeight - -The BandWithOut usage weight when calculating new resource usage. It only takes effect in the ThresholdShedder strategy. - -**Default**: 1.0 - -### loadBalancerCPUResourceWeight - -The CPU usage weight when calculating new resource usage. It only takes effect in the ThresholdShedder strategy. - -**Default**: 1.0 - -### loadBalancerMemoryResourceWeight - -The heap memory usage weight when calculating new resource usage. It only takes effect in the ThresholdShedder strategy. - -**Default**: 1.0 - -### loadBalancerDirectMemoryResourceWeight - -The direct memory usage weight when calculating new resource usage. It only takes effect in the ThresholdShedder strategy. - -**Default**: 1.0 - -### loadBalancerBundleUnloadMinThroughputThreshold - -Bundle unload minimum throughput threshold. Avoid bundle unload frequently. It only takes effect in the ThresholdShedder strategy. - -**Default**: 10 - -### namespaceBundleUnloadingTimeoutMs - -Time to wait for the unloading of a namespace bundle in milliseconds. - -**Default**: 60000 - -### replicationMetricsEnabled - -**Default**: true - -### replicationConnectionsPerBroker - -**Default**: 16 - -### replicationProducerQueueSize - -**Default**: 1000 - -### replicationPolicyCheckDurationSeconds - -Duration to check replication policy to avoid replicator inconsistency due to missing ZooKeeper watch. When the value is set to 0, disable checking replication policy. - -**Default**: 600 - -### transactionCoordinatorEnabled - -Whether to enable transaction coordinator in broker. - -**Default**: false - -### transactionMetadataStoreProviderClassName - -The class name of transactionMetadataStoreProvider. - -**Default**: org.apache.pulsar.transaction.coordinator.impl.MLTransactionMetadataStoreProvider - -### transactionBufferClientOperationTimeoutInMills - -The transaction buffer client's operation timeout in milliseconds. - -**Default**: 3000 - -### transactionBufferSnapshotMaxTransactionCount - -Transaction buffer takes a snapshot after the number of transaction operations reaches this value. - -**Default**: 1000 - -### transactionBufferSnapshotMinTimeInMillis - -The interval between two snapshots that the transaction buffer takes (in milliseconds). - -**Default**: 5000 - -### defaultRetentionTimeInMinutes - -**Default**: 0 - -### defaultRetentionSizeInMB - -**Default**: 0 - -### keepAliveIntervalSeconds - -**Default**: 30 - -### haProxyProtocolEnabled - -Enable or disable the [HAProxy](http://www.haproxy.org/) protocol. - -**Default**: false - -### bookieId - -If you want to custom a bookie ID or use a dynamic network address for a bookie, you can set the `bookieId`. - -Bookie advertises itself using the `bookieId` rather than the `BookieSocketAddress` (`hostname:port` or `IP:port`). - -The `bookieId` is a non-empty string that can contain ASCII digits and letters ([a-zA-Z9-0]), colons, dashes, and dots. - -For more information about `bookieId`, see [here](http://bookkeeper.apache.org/bps/BP-41-bookieid/). - -**Default**: / - -### 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. - -**Default**: 0 - -### metadataStoreConfigPath - -The configuration file path of the local metadata store. Standalone Pulsar uses [RocksDB](http://rocksdb.org/) as the local metadata store. The format is `/xxx/xx/rocksdb.ini`. - -**Default**: N/A - -### schemaRegistryStorageClassName - -The schema storage implementation used by this broker. - -**Default**: 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. - -**Default**: false - -### isAllowAutoUpdateSchemaEnabled - -Allow schema to be auto updated at broker level. - -**Default**: true - -### schemaRegistryCompatibilityCheckers - -Deploy the schema compatibility checker for a specific schema type to enforce schema compatibility check. - -**Default**: org.apache.pulsar.broker.service.schema.JsonSchemaCompatibilityCheck,org.apache.pulsar.broker.service.schema.AvroSchemaCompatibilityCheck,org.apache.pulsar.broker.service.schema.ProtobufNativeSchemaCompatibilityCheck - -### schemaCompatibilityStrategy - -The schema compatibility strategy at broker level, see [here](https://pulsar.apache.org/docs/next/schema-evolution-compatibility/#schema-compatibility-check-strategy) for available values. - -**Default**: FULL - -### systemTopicSchemaCompatibilityStrategy - -The schema compatibility strategy is used for system topics, see [here](https://pulsar.apache.org/docs/next/schema-evolution-compatibility/#schema-compatibility-check-strategy) for available values. - -**Default**: ALWAYS_COMPATIBLE - -### managedCursorInfoCompressionType - -The compression type of managed cursor information. - -Available options are `NONE`, `LZ4`, `ZLIB`, `ZSTD`, and `SNAPPY`). - -If this value is `NONE`, managed cursor information is not compressed. - -**Default**: NONE - -## Deprecated - -The following parameters have been deprecated in the `conf/standalone.conf` file. - -### zookeeperServers - -The quorum connection string for local metadata store. Use `metadataStoreUrl` instead. - -**Default**: N/A - -### configurationStoreServers - -Configuration store connection string (as a comma-separated list). Use `configurationMetadataStoreUrl` instead. - -**Default**: N/A - -### zooKeeperOperationTimeoutSeconds - -ZooKeeper operation timeout in seconds. Use `metadataStoreOperationTimeoutSeconds` instead. - -**Default**: 30 - -### zooKeeperCacheExpirySeconds - -ZooKeeper cache expiry time in seconds. Use `metadataStoreCacheExpirySeconds` instead. - -**Default**: 300 - -### zooKeeperSessionTimeoutMillis - -The ZooKeeper session timeout, in milliseconds. Use `metadataStoreSessionTimeoutMillis` instead. - -**Default**: 30000 - -### managedLedgerMaxUnackedRangesToPersistInZooKeeper - -Maximum number of "acknowledgment holes" that can be stored in ZooKeeper. Use `managedLedgerMaxUnackedRangesToPersistInMetadataStore` instead. - -**Default**: 1000 diff --git a/site2/tools/generate-config-docs.sh b/site2/tools/generate-config-docs.sh deleted file mode 100755 index 94c08cf61661d..0000000000000 --- a/site2/tools/generate-config-docs.sh +++ /dev/null @@ -1,35 +0,0 @@ -#!/usr/bin/env bash -# -# Licensed to the Apache Software Foundation (ASF) under one -# or more contributor license agreements. See the NOTICE file -# distributed with this work for additional information -# regarding copyright ownership. The ASF licenses this file -# to you under the Apache License, Version 2.0 (the -# "License"); you may not use this file except in compliance -# with the License. You may obtain a copy of the License at -# -# http://www.apache.org/licenses/LICENSE-2.0 -# -# Unless required by applicable law or agreed to in writing, -# software distributed under the License is distributed on an -# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY -# KIND, either express or implied. See the License for the -# specific language governing permissions and limitations -# under the License. -# - -set -x -e - -ROOT_DIR=$(git rev-parse --show-toplevel) -JAVA=java -f=$ROOT_DIR/distribution/server/target/classpath.txt -GEN_DOCS_BROKER=org.apache.pulsar.utils.CmdGenerateDocumentation -GEN_DOCS_PROXY=org.apache.pulsar.proxy.util.CmdGenerateDocumentation -DOCS_DIR=site2/docs - -cd ${ROOT_DIR} - -$JAVA -cp `cat "${f}"` $GEN_DOCS_BROKER -c org.apache.pulsar.broker.ServiceConfiguration > $DOCS_DIR/reference-configuration-broker.md -$JAVA -cp `cat "${f}"` $GEN_DOCS_BROKER -c org.apache.pulsar.client.impl.conf.ClientConfigurationData > $DOCS_DIR/reference-configuration-client.md -$JAVA -cp `cat "${f}"` $GEN_DOCS_BROKER -c org.apache.pulsar.websocket.service.WebSocketProxyConfiguration > $DOCS_DIR/reference-configuration-websocket.md -$JAVA -cp `cat "${f}"` $GEN_DOCS_PROXY -c org.apache.pulsar.proxy.server.ProxyConfiguration > $DOCS_DIR/reference-configuration-pulsar-proxy.md \ No newline at end of file