pulsar配置文件常用配置项

#bookeeper.conf配置
zkTimeout=30000
zkServers=localhost:2181/pulsar
zkLedgersRootPath=/ledgers
zkEnableSecurity=false
writeBufferSizeBytes=65536
useHostNameAsBookieID=false
statsProviderClass=org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
serverTcpNoDelay=true

rereplicationEntryBatchSize=100
readOnlyModeEnabled=true
readBufferSizeBytes=4096
prometheusStatsHttpPort=8100
pageLimit=0
openLedgerRereplicationGracePeriod=30000
openFileLimit=0
numReadWorkerThreads=8
numJournalCallbackThreads=64
numHighPriorityWorkerThreads=8
numAddWorkerThreads=0
nettyMaxFrameSizeBytes=5253120
minorCompactionThreshold=0.2
minorCompactionInterval=3600
minUsableSizeForIndexFileCreation=1073741824
maxPendingReadRequestsPerThread=2500
maxPendingAddRequestsPerThread=10000
majorCompactionThreshold=0.5
majorCompactionInterval=86400
lostBookieRecoveryDelay=0
logSizeLimit=1073741824
ledgerStorageClass=org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
ledgerDirectories=/data1/bookkeeper/ledger1
journalWriteBufferSizeKB=64
journalSyncData=false
journalRemoveFromPageCache=true

ournalPreAllocSizeMB=16
journalMaxSizeMB=2048
journalMaxGroupWaitMSec=1
journalMaxBackups=5
journalFormatVersionToWrite=5
journalFlushWhenQueueEmpty=false
journalDirectories=/data1/bookkeeper/journal
journalBufferedWritesThreshold=524288
journalAlignmentSize=4096
journalAdaptiveGroupWrites=true
isThrottleByBytes=true
httpServerPort=8070
httpServerEnabled=True
httpServerClass=org.apache.bookkeeper.http.vertx.VertxHttpServer
gcWaitTime=900000
gcOverreplicatedLedgerWaitTime=86400000
flushInterval=60000
flushEntrylogBytes=1048576
fileInfoFormatVersionToWrite=0
entryLogFilePreallocationEnabled=true
enableBusyWait=false
diskUsageThreshold=0.95
diskCheckInterval=10000
dbStorage_writeCacheMaxSizeMb=
dbStorage_rocksDB_writeBufferSizeMB=64
dbStorage_rocksDB_sstSizeInMB=64
dbStorage_rocksDB_numLevels=-1
dbStorage_rocksDB_numFilesInLevel0=4
dbStorage_rocksDB_maxSizeInLevel1MB=256
dbStorage_rocksDB_bloomFilterBitsPerKey=10
dbStorage_rocksDB_blockSize=65536
dbStorage_rocksDB_blockCacheSize=
dbStorage_readAheadCacheMaxSizeMb=
dbStorage_readAheadCacheBatchSize=1000
compactionRateByEntries=1000
compactionRateByBytes=1000000
compactionRate=1000
compactionMaxOutstandingRequests=100000
bookiePort=3181
bookieDeathWatchInterval=1000
autoRecoveryDaemonEnabled=true
auditorPeriodicCheckInterval=604800
auditorPeriodicBookieCheckInterval=86400
allowLoopback=false
advertisedAddress=localhost
allowMultipleDirsUnderSameDiskPartition=true
journalPageCacheFlushIntervalMSec=1
journalWriteData=false


##########################################
##broker.conf配置
##########################################
zookeeperSessionExpiredPolicy=shutdown
zookeeperServers=localhost:2181/pulsar
zooKeeperSessionTimeoutMillis=20000
zooKeeperOperationTimeoutSeconds=30
zooKeeperCacheExpirySeconds=300
webSocketSessionIdleTimeoutMillis=300000
webSocketServiceEnabled=false
webSocketNumIoThreads=8
webSocketMaxTextFrameSize=1048576
webSocketConnectionsPerBroker=8
webServicePortTls=
webServicePort=8080
unblockStuckSubscriptionEnabled=false
ttlDurationDefaultInSeconds=0
transactionMetadataStoreProviderClassName=org.apache.pulsar.transaction.coordinator.impl.MLTransactionMetadataStoreProvider
transactionCoordinatorEnabled=false
transactionBufferSnapshotMinTimeInMillis=5000
transactionBufferSnapshotMaxTransactionCount=1000
topicPublisherThrottlingTickTimeMillis=10
topicLevelPoliciesEnabled=true
topicFencingTimeoutSeconds=0
tokenSecretKey=/opt/bigdata/app/pulsar/data/admin-secret.key
tokenPublicKey=
tokenAuthClaim=
tokenAudienceClaim=
tokenAudience=
tlsTrustStoreType=JKS
tlsTrustStorePassword=
tlsTrustStore=
tlsTrustCertsFilePath=
tlsRequireTrustedClientCertOnConnect=false
tlsProvider=
tlsProtocols=
tlsKeyStoreType=JKS
tlsKeyStorePassword=

tlsKeyStore=
tlsKeyFilePath=
tlsEnabledWithKeyStore=false
tlsEnabled=false
tlsCiphers=
tlsCertificateFilePath=
tlsCertRefreshCheckDurationSec=300
tlsAllowInsecureConnection=false
systemTopicEnabled=true
supportedNamespaceBundleSplitAlgorithms=range_equally_divide,topic_count_equally_divide
superUserRoles=pulsaradmin
subscriptionTypesEnabled=Exclusive,Shared,Failover,Key_Shared
subscriptionRedeliveryTrackerEnabled=true
subscriptionKeySharedUseConsistentHashing=false
subscriptionKeySharedEnable=true
subscriptionKeySharedConsistentHashingReplicaPoints=100
subscriptionExpiryCheckIntervalInMinutes=5
subscriptionExpirationTimeMinutes=0
subscribeThrottlingRatePerConsumer=0
subscribeRatePeriodPerConsumerInSecond=30
statusFilePath=
statsUpdateInitialDelayInSecs=60
statsUpdateFrequencyInSecs=60
skipBrokerShutdownOnOOM=false
schemaRegistryStorageClassName=org.apache.pulsar.broker.service.schema.BookkeeperSchemaStorageFactory
saslJaasClientAllowedIds=
saslJaasBrokerSectionName=
s3ManagedLedgerOffloadServiceEndpoint=
s3ManagedLedgerOffloadRegion=
s3ManagedLedgerOffloadReadBufferSizeInBytes=1048576
s3ManagedLedgerOffloadMaxBlockSizeInBytes=67108864
s3ManagedLedgerOffloadBucket=
retentionCheckIntervalInSeconds=120
replicatorPrefix=pulsar.repl
replicationTlsEnabled=false
replicationProducerQueueSize=1000
replicationPolicyCheckDurationSeconds=600
replicationMetricsEnabled=true
replicationConnectionsPerBroker=16
replicatedSubscriptionsSnapshotTimeoutSeconds=30
replicatedSubscriptionsSnapshotMaxCachedPerSubscription=10
replicatedSubscriptionsSnapshotFrequencyMillis=1000
proxyRoles=
preferLaterVersions=false
preciseTopicPublishRateLimiterEnable=false
preciseDispatcherFlowControl=true
packagesReplicas=1
packagesManagementStorageProvider=org.apache.pulsar.packages.management.storage.bookkeeper.BookKeeperPackagesStorageProvider
packagesManagementLedgerRootPath=/ledgers
offloadersDirectory=./offloaders
numWorkerThreadsForNonPersistentTopic=8
numOrderedExecutorThreads=8
numIOThreads=
numHttpServerThreads=
numExecutorThreadPoolSize=
numCacheExecutorThreadPoolSize=10
numAcceptorThreads=
metricsServletTimeoutMs=30000
messageExpiryCheckIntervalInMinutes=5
maxUnackedMessagesPerSubscriptionOnBrokerBlocked=0.16
maxUnackedMessagesPerSubscription=200000
maxUnackedMessagesPerConsumer=50000
maxUnackedMessagesPerBroker=0
maxTopicsPerNamespace=0
maxTenants=0
maxSubscriptionsPerTopic=0
maxSameAddressProducersPerTopic=0
maxSameAddressConsumersPerTopic=0
maxPublishRatePerTopicInMessages=0
maxPublishRatePerTopicInBytes=0
maxProducersPerTopic=0
maxPendingPublishRequestsPerConnection=1000
maxNumPartitionsPerPartitionedTopic=0
maxNamespacesPerTenant=0
maxMessageSize=5242880
maxMessagePublishBufferSizeInMB=
maxConsumersPerTopic=0
maxConsumersPerSubscription=0
maxConcurrentTopicLoadRequest=5000
maxConcurrentNonPersistentMessagePerConnection=1000
maxConcurrentLookupRequest=50000
maxConcurrentHttpRequests=1024

managedLedgerUnackedRangesOpenCacheSetEnabled=true
managedLedgerTraceTaskExecution=true
managedLedgerReadEntryTimeoutSeconds=0
managedLedgerPrometheusStatsLatencyRolloverSeconds=60
managedLedgerOffloadPrefetchRounds=1
managedLedgerOffloadMaxThreads=2
managedLedgerOffloadDriver=
managedLedgerOffloadDeletionLagMs=14400000
managedLedgerOffloadAutoTriggerSizeThresholdBytes=-1
managedLedgerNumWorkerThreads=8
managedLedgerNumSchedulerThreads=8
managedLedgerNewEntriesCheckDelayInMillis=10
managedLedgerMinLedgerRolloverTimeMinutes=10
managedLedgerMetadataOperationsTimeoutSeconds=60
managedLedgerMaxUnackedRangesToPersistInZooKeeper=1000
managedLedgerMaxUnackedRangesToPersist=10000
managedLedgerMaxSizePerLedgerMbytes=2048
managedLedgerMaxLedgerRolloverTimeMinutes=240
managedLedgerMaxEntriesPerLedger=50000
managedLedgerDigestType=CRC32C
managedLedgerDefaultWriteQuorum=3
managedLedgerDefaultMarkDeleteRateLimit=1.0
managedLedgerDefaultEnsembleSize=3
managedLedgerDefaultAckQuorum=2
managedLedgerCursorRolloverTimeInSeconds=600
managedLedgerCursorPositionFlushSeconds = 60
managedLedgerCursorMaxEntriesPerLedger=1000
managedLedgerCursorBackloggedThreshold=1000
managedLedgerCacheSizeMB=
managedLedgerCacheEvictionWatermark=0.9
managedLedgerCacheEvictionTimeThresholdMillis=1000
managedLedgerCacheEvictionFrequency=100.0
managedLedgerCacheCopyEntries=false
managedLedgerAddEntryTimeoutSeconds=0
loadManagerClassName=org.apache.pulsar.broker.loadbalance.impl.ModularLoadManagerImpl
loadBalancerSheddingIntervalMinutes=1
loadBalancerSheddingGracePeriodMinutes=30
loadBalancerSheddingEnabled=true
loadBalancerResourceQuotaUpdateIntervalMinutes=15
loadBalancerReportUpdateThresholdPercentage=10
loadBalancerReportUpdateMaxIntervalMinutes=15
loadBalancerOverrideBrokerNicSpeedGbps=
loadBalancerNamespaceMaximumBundles=128
loadBalancerNamespaceBundleMaxTopics=1000
loadBalancerNamespaceBundleMaxSessions=1000

loadBalancerNamespaceBundleMaxMsgRate=30000
loadBalancerNamespaceBundleMaxBandwidthMbytes=100
loadBalancerMemoryResourceWeight=0.0
loadBalancerLoadSheddingStrategy=org.apache.pulsar.broker.loadbalance.impl.ThresholdShedder
loadBalancerHostUsageCheckIntervalMinutes=1
loadBalancerHistoryResourcePercentage=0.9
loadBalancerEnabled=true
loadBalancerDirectMemoryResourceWeight=0.0
loadBalancerCPUResourceWeight=0.0
loadBalancerBundleUnloadMinThroughputThreshold=10
loadBalancerBrokerThresholdShedderPercentage=5
loadBalancerBrokerOverloadedThresholdPercentage=85
loadBalancerBrokerMaxTopics=50000
loadBalancerBandwithOutResourceWeight=1.0
loadBalancerBandwithInResourceWeight=1.0
loadBalancerAutoUnloadSplitBundlesEnabled=false
loadBalancerAutoBundleSplitEnabled=false
lazyCursorRecovery=false
keepAliveIntervalSeconds=30
isSchemaValidationEnforced=false
isRunningStandalone=
httpRequestsMaxPerSecond=100.0
httpRequestsLimitEnabled=false
httpMaxRequestSize=-1
haProxyProtocolEnabled=false
globalZookeeperServers=
gcsManagedLedgerOffloadServiceAccountKeyFile=
gcsManagedLedgerOffloadRegion=
gcsManagedLedgerOffloadReadBufferSizeInBytes=1048576
gcsManagedLedgerOffloadMaxBlockSizeInBytes=67108864
gcsManagedLedgerOffloadBucket=
functionsWorkerEnabled=false
forceDeleteTenantAllowed=false
forceDeleteNamespaceAllowed=true
fileSystemURI=
fileSystemProfilePath=../conf/filesystem_offload_core_site.xml
failureDomainsEnabled=false
exposeTopicLevelMetricsInPrometheus=true
exposePublisherStats=true
exposeProducerLevelMetricsInPrometheus=true
exposePreciseBacklogInPrometheus=false
exposeManagedLedgerMetricsInPrometheus=true
exposeManagedCursorMetricsInPrometheus=true
exposeConsumerLevelMetricsInPrometheus=true
encryptionRequireOnProducer=false
enableRunBookieTogether=false
enableRunBookieAutoRecoveryTogether=false
enableReplicatedSubscriptions=true
enablePersistentTopics=true
enablePackagesManagement=false
enableNonPersistentTopics=true
enableBusyWait=false
dispatcherMinReadBatchSize=1
dispatcherMaxRoundRobinBatchSize=20
dispatcherMaxReadSizeBytes=5242880
dispatcherMaxReadBatchSize=100
dispatchThrottlingRateRelativeToPublishRate=false
dispatchThrottlingRatePerTopicInMsg=0
dispatchThrottlingRatePerTopicInByte=0
dispatchThrottlingRatePerSubscriptionInMsg=0
dispatchThrottlingRatePerSubscriptionInByte=0
dispatchThrottlingRatePerReplicatorInMsg=0
dispatchThrottlingRatePerReplicatorInByte=0
dispatchThrottlingOnNonBacklogConsumerEnabled=true
disableHttpDebugMethods=false
delayedDeliveryTickTimeMillis=1000
delayedDeliveryEnabled=true
defaultRetentionTimeInMinutes=0
defaultRetentionSizeInMB=0
defaultNumberOfNamespaceBundles=4
defaultNumPartitions=1
defaultNamespaceBundleSplitAlgorithm=range_equally_divide
configurationStoreServers=localhost:2181/pulsar
clusterName=zhuyelan
clientLibraryVersionCheckEnabled=false
brokerShutdownTimeoutMs=60000
brokerServicePurgeInactiveFrequencyInSeconds=60
brokerServicePortTls=
brokerServicePort=6650
brokerServiceCompactionThresholdInBytes=0
brokerServiceCompactionPhaseOneLoopTimeInSeconds=30
brokerServiceCompactionMonitorIntervalInSeconds=60
brokerPublisherThrottlingTickTimeMillis=50
brokerPublisherThrottlingMaxMessageRate=0
brokerPublisherThrottlingMaxByteRate=0
brokerDeleteInactiveTopicsMode=delete_when_no_subscriptions
brokerDeleteInactiveTopicsMaxInactiveDurationSeconds=
brokerDeleteInactiveTopicsFrequencySeconds=60
brokerDeleteInactiveTopicsEnabled=false
brokerDeleteInactivePartitionedTopicMetadataEnabled=false
brokerDeduplicationSnapshotIntervalSeconds=120
brokerDeduplicationSnapshotFrequencyInSeconds=10
brokerDeduplicationProducerInactivityTimeoutMinutes=360
brokerDeduplicationMaxNumberOfProducers=10000
brokerDeduplicationEntriesInterval=1000
brokerDeduplicationEnabled=false
brokerClientTrustCertsFilePath=
brokerClientTlsTrustStoreType=JKS
brokerClientTlsTrustStorePassword=
brokerClientTlsTrustStore=
brokerClientTlsProtocols=
brokerClientTlsEnabledWithKeyStore=false
brokerClientTlsEnabled=false
brokerClientTlsCiphers=
brokerClientSslProvider=

brokerClientAuthenticationPlugin=org.apache.pulsar.client.impl.auth.AuthenticationToken
brokerClientAuthenticationParameters={"token":"eyJhbGciOiJIUzI1NiJ9.eyJzdWIiOiJwdWxzYXJhZG1pbiJ9.dYRw56hr-LGkIuPG5dy-U3BqByZ05vwO_FitPv6PDik"}
bootstrapNamespaces=
bookkeeperUseV2WireProtocol=true
bookkeeperTLSTrustStorePasswordPath=
bookkeeperTLSTrustCertsFilePath=
bookkeeperTLSTrustCertTypes=PEM
bookkeeperTLSProviderFactoryClass=org.apache.bookkeeper.tls.TLSContextFactory
bookkeeperTLSKeyStorePasswordPath=
bookkeeperTLSKeyFileType=PEM
bookkeeperTLSKeyFilePath=
bookkeeperTLSClientAuthentication=false
bookkeeperTLSCertificateFilePath=
bookkeeperNumberOfChannelsPerBookie=16
bookkeeperMetadataServiceUri=
bookkeeperExplicitLacIntervalInMills=0
bookkeeperEnableStickyReads=true
bookkeeperDiskWeightBasedPlacementEnabled=false
bookkeeperClientTimeoutInSeconds=30
bookkeeperClientSpeculativeReadTimeoutInMillis=0
bookkeeperClientSecondaryIsolationGroups=
bookkeeperClientReorderReadSequenceEnabled=false
bookkeeperClientRegionawarePolicyEnabled=false
bookkeeperClientRackawarePolicyEnabled=false
bookkeeperClientQuarantineRatio=1.0
bookkeeperClientNumWorkerThreads=
bookkeeperClientMinNumRacksPerWriteQuorum=2
bookkeeperClientMinAvailableBookiesInIsolationGroups=
bookkeeperClientIsolationGroups=
bookkeeperClientHealthCheckQuarantineTimeInSeconds=1800
bookkeeperClientHealthCheckIntervalSeconds=60
bookkeeperClientHealthCheckErrorThresholdPerInterval=5
bookkeeperClientHealthCheckEnabled=true
bookkeeperClientGetBookieInfoRetryIntervalSeconds=60
bookkeeperClientGetBookieInfoIntervalSeconds=86400
bookkeeperClientEnforceMinNumRacksPerWriteQuorum=false
bookkeeperClientAuthenticationPlugin=
bookkeeperClientAuthenticationParametersName=
bookkeeperClientAuthenticationParameters=
bindAddress=0.0.0.0
backlogQuotaDefaultRetentionPolicy=producer_request_hold
backlogQuotaDefaultLimitSecond=-1
backlogQuotaDefaultLimitGB=-1
backlogQuotaCheckIntervalInSeconds=60
backlogQuotaCheckEnabled=true
autoSkipNonRecoverableData=false
authorizationProvider=org.apache.pulsar.broker.authorization.PulsarAuthorizationProvider
authorizationEnabled=true
authorizationAllowWildcardsMatching=false
authenticationRefreshCheckSeconds=60
authenticationProviders=org.apache.pulsar.broker.authentication.AuthenticationProviderToken
authenticationEnabled=true
authenticateOriginalAuthData=true
athenzDomainNames=
anonymousUserRole=
allowAutoTopicCreationType=non-partitioned
allowAutoTopicCreation=false
allowAutoSubscriptionCreation=false
advertisedAddress=主机IP地址
activeConsumerFailoverDelayTimeMillis=1000
acknowledgmentAtBatchIndexLevelEnabled=false

评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值