standalone.yaml 8.7 KB
Newer Older
1 2 3 4 5 6 7 8 9 10 11 12 13 14 15 16 17 18 19 20 21 22 23 24 25 26 27 28 29 30 31 32 33 34 35 36 37 38 39 40 41 42 43 44 45 46 47 48 49 50 51 52 53 54 55 56 57 58 59 60 61 62 63 64 65
#
# 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.
#

configs:
- name: zookeeperServers
  default: ''
  description: The quorum connection string for local ZooKeeper
- name: globalZookeeperServers
  default: ''
  description: The quorum connection string for global ZooKeeper
- name: brokerServicePort
  default: '6650'
  description: The port on which the standalone broker listens for connections
- name: webServicePort
  default: '8080'
  description: THe port used by the standalone broker for HTTP requests
- name: bindAddress
  default: 0.0.0.0
  description: The hostname or IP address on which the standalone service binds
- name: advertisedAddress
  default: ''
  description: The hostname or IP address that the standalone service advertises to the outside world. If not set, the value of `InetAddress.getLocalHost().getHostName()` is used.
- name: clusterName
  default: standalone
  description: The name of the cluster that this broker belongs to.
- name: zooKeeperSessionTimeoutMillis
  default: '30000'
  description: The ZooKeeper session timeout, in milliseconds.
- name: brokerShutdownTimeoutMs
  default: '3000'
  description: The time to wait for graceful broker shutdown. After this time elapses, the process will be killed.
- name: backlogQuotaCheckEnabled
  default: 'true'
  description: Enable the backlog quota check, which enforces a specified action when the quota is reached.
- name: backlogQuotaCheckIntervalInSeconds
  default: '60'
  description: How often to check for topics that have reached the backlog quota.
- name: backlogQuotaDefaultLimitGB
  default: '10'
  description: The default per-topic backlog quota limit.
- name: brokerDeleteInactiveTopicsEnabled
  default: 'true'
  description: Enable the deletion of inactive topics.
- name: brokerDeleteInactiveTopicsFrequencySeconds
  default: '60'
  description: How often to check for inactive topics, in seconds.
- name: messageExpiryCheckIntervalInMinutes
  default: '5'
  description: How often to proactively check and purged expired messages.
66 67 68
- name: activeConsumerFailoverDelayTimeMillis
  default: '1000'
  description: How long to delay rewinding cursor and dispatching messages when active consumer is changed.
69 70 71 72 73 74 75 76 77 78 79 80 81 82 83 84 85 86 87 88 89 90 91 92 93 94 95 96 97 98 99 100 101 102 103 104 105 106 107 108 109 110 111 112 113 114 115 116 117 118 119 120 121 122 123 124 125 126 127 128 129 130 131 132 133 134 135 136 137 138 139 140 141 142 143 144 145 146 147 148 149 150 151 152 153 154 155 156 157 158 159 160 161 162 163 164 165 166 167 168 169 170 171 172 173 174 175 176 177 178 179 180 181 182 183 184 185 186 187 188 189 190 191 192 193 194 195 196 197 198 199 200 201 202 203 204 205
- name: clientLibraryVersionCheckEnabled
  default: 'false'
  description: Enable checks for minimum allowed client library version.
- name: clientLibraryVersionCheckAllowUnversioned
  default: 'true'
  description: Allow client libraries with no version information
- name: statusFilePath
  default: "/usr/local/apache/htdocs"
  description: The path for the file used to determine the rotation status for the broker when responding to service discovery health checks
- name: maxUnackedMessagesPerConsumer
  default: '50000'
  description: 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.
- name: maxUnackedMessagesPerSubscription
  default: '200000'
  description: The same as above, except per subscription rather than per consumer.
- name: authenticationEnabled
  default: 'false'
  description: Enable authentication for the broker.
- name: authenticationProviders
  default: 'false'
  description: A comma-separated list of class names for authentication providers.
- name: authorizationEnabled
  default: 'false'
  description: Enforce authorization in brokers.
- name: superUserRoles
  default: ''
  description: Role names that are treated as "superusers." Superusers are authorized to perform all admin tasks.
- name: brokerClientAuthenticationPlugin
  default: ''
  description: The authentication settings of the broker itself. Used when the broker connects to other brokers either in the same cluster or from other clusters.
- name: brokerClientAuthenticationParameters
  default: ''
  description: The parameters that go along with the plugin specified using [`brokerClientAuthenticationPlugin`](#standalone-brokerClientAuthenticationPlugin).
- name: athenzDomainNames
  default: ''
  description: Supported Athenz authentication provider domain names as a comma-separated list.
- name: bookkeeperClientAuthenticationPlugin
  default: ''
  description: Authentication plugin to be used when connecting to bookies (BookKeeper servers).
- name: bookkeeperClientAuthenticationParametersName
  default: ''
  description: BookKeeper authentication plugin implementation parameters and values.
- name: bookkeeperClientAuthenticationParameters
  default: ''
  description: Parameters associated with the [`bookkeeperClientAuthenticationParametersName`](#standalone-bookkeeperClientAuthenticationParametersName)
- name: bookkeeperClientTimeoutInSeconds
  default: '30'
  description: Timeout for BookKeeper add and read operations.
- name: bookkeeperClientSpeculativeReadTimeoutInMillis
  default: '0'
  description: Speculative reads are initiated if a read request doesn't complete within a certain time. A value of 0 disables speculative reads.
- name: bookkeeperClientHealthCheckEnabled
  default: 'true'
  description: Enable bookie health checks.
- name: bookkeeperClientHealthCheckIntervalSeconds
  default: '60'
  description: The time interval, in seconds, at which health checks are performed. New ledgers are not created during health checks.
- name: bookkeeperClientHealthCheckErrorThresholdPerInterval
  default: '5'
  description: Error threshold for health checks.
- name: bookkeeperClientHealthCheckQuarantineTimeInSeconds
  default: '1800'
  description: If bookies have more than the allowed number of failures within the time interval specified by [`bookkeeperClientHealthCheckIntervalSeconds`](#)
- name: bookkeeperClientRackawarePolicyEnabled
  default: 'true'
- name: bookkeeperClientIsolationGroups
  default: ''
- name: managedLedgerDefaultEnsembleSize
  default: '1'
- name: managedLedgerDefaultWriteQuorum
  default: '1'
- name: managedLedgerDefaultAckQuorum
  default: '1'
- name: managedLedgerCacheSizeMB
  default: '1024'
- name: managedLedgerCacheEvictionWatermark
  default: '0.9'
- name: managedLedgerDefaultMarkDeleteRateLimit
  default: '0.1'
- name: managedLedgerMaxEntriesPerLedger
  default: '50000'
- name: managedLedgerMinLedgerRolloverTimeMinutes
  default: '10'
- name: managedLedgerMaxLedgerRolloverTimeMinutes
  default: '240'
- name: managedLedgerCursorMaxEntriesPerLedger
  default: '50000'
- name: managedLedgerCursorRolloverTimeInSeconds
  default: '14400'
- name: loadBalancerEnabled
  default: 'false'
- name: loadBalancerPlacementStrategy
  default: weightedRandomSelection
- name: loadBalancerReportUpdateThresholdPercentage
  default: '10'
- name: loadBalancerReportUpdateMaxIntervalMinutes
  default: '15'
- name: loadBalancerHostUsageCheckIntervalMinutes
  default: '1'
- name: loadBalancerSheddingIntervalMinutes
  default: '30'
- name: loadBalancerSheddingGracePeriodMinutes
  default: '30'
- name: loadBalancerBrokerUnderloadedThresholdPercentage
  default: '1'
- name: loadBalancerBrokerOverloadedThresholdPercentage
  default: '85'
- name: loadBalancerResourceQuotaUpdateIntervalMinutes
  default: '15'
- name: loadBalancerBrokerComfortLoadLevelPercentage
  default: '65'
- name: loadBalancerAutoBundleSplitEnabled
  default: 'false'
- name: loadBalancerNamespaceBundleMaxTopics
  default: '1000'
- name: loadBalancerNamespaceBundleMaxSessions
  default: '1000'
- name: loadBalancerNamespaceBundleMaxMsgRate
  default: '1000'
- name: loadBalancerNamespaceBundleMaxBandwidthMbytes
  default: '100'
- name: loadBalancerNamespaceMaximumBundles
  default: '128'
- name: replicationMetricsEnabled
  default: 'true'
- name: replicationConnectionsPerBroker
  default: '16'
- name: replicationProducerQueueSize
  default: '1000'
- name: defaultRetentionTimeInMinutes
  default: '0'
- name: defaultRetentionSizeInMB
  default: '0'
- name: keepAliveIntervalSeconds
  default: '30'
- name: brokerServicePurgeInactiveFrequencyInSeconds
  default: '60'