Uses of Class
org.apache.bookkeeper.conf.ServerConfiguration
-
Packages that use ServerConfiguration Package Description org.apache.bookkeeper.auth Classes used to handle authentication in bookies and clients.org.apache.bookkeeper.bookie Provides a Bookie server that stores entries for clients.org.apache.bookkeeper.bookie.datainteg Package of the classes for defining bookie stats.org.apache.bookkeeper.bookie.storage.ldb Classes related to DB based ledger storage.org.apache.bookkeeper.client BookKeeper Client.org.apache.bookkeeper.conf Configurations used by bookkeeper.org.apache.bookkeeper.discover Classes related to service discovery.org.apache.bookkeeper.meta Classes for interacting with bookkeeper ledgers and ledger metadata.org.apache.bookkeeper.meta.zk ZooKeeper based metadata implementation.org.apache.bookkeeper.proto Classes related to the Bookkeeper protocol.org.apache.bookkeeper.replication Classes for replicating Bookkeeper data.org.apache.bookkeeper.sasl SASL and JAAS Authentication classes.org.apache.bookkeeper.server BookKeeper Server (Bookie) related components.org.apache.bookkeeper.server.conf Server component related configuration.org.apache.bookkeeper.server.http Package for bookkeeper http service.org.apache.bookkeeper.server.http.service Define the services running in bookkeeper admin http server.org.apache.bookkeeper.tls Security and TLS-related classes.org.apache.bookkeeper.tools.cli.commands.autorecovery org.apache.bookkeeper.tools.cli.commands.bookie Commands to operate a single bookie.org.apache.bookkeeper.tools.cli.commands.bookies Commands on operating a cluster of bookies.org.apache.bookkeeper.tools.cli.commands.client This package contains all client related commands.org.apache.bookkeeper.tools.cli.commands.cookie Cookie related cli commands.org.apache.bookkeeper.tools.cli.commands.health org.apache.bookkeeper.tools.cli.helpers This classes provides some helper mixins for easily to add commands to bookie shell.org.apache.bookkeeper.util Bookkeeper utilities. -
-
Uses of ServerConfiguration in org.apache.bookkeeper.auth
Methods in org.apache.bookkeeper.auth with parameters of type ServerConfiguration Modifier and Type Method Description voidBookieAuthProvider.Factory. init(ServerConfiguration conf)Initialize the factory with the server configuration and protobuf message registry.static BookieAuthProvider.FactoryAuthProviderFactoryFactory. newBookieAuthProviderFactory(ServerConfiguration conf) -
Uses of ServerConfiguration in org.apache.bookkeeper.bookie
Fields in org.apache.bookkeeper.bookie declared as ServerConfiguration Modifier and Type Field Description (package private) ServerConfigurationBookieShell. bkConfprotected ServerConfigurationAbstractLogCompactor. conf(package private) ServerConfigurationBookieImpl. conf(package private) ServerConfigurationDefaultEntryLogger. conf(package private) ServerConfigurationEntryMemTable. conf(package private) ServerConfigurationGarbageCollectorThread. conf(package private) ServerConfigurationJournal. conf(package private) ServerConfigurationJournalChannel. configurationMethods in org.apache.bookkeeper.bookie with parameters of type ServerConfiguration Modifier and Type Method Description static ByteBufAllocatorWithOomHandlerBookieResources. createAllocator(ServerConfiguration conf)static DiskCheckerBookieResources. createDiskChecker(ServerConfiguration conf)static LedgerDirsManagerBookieResources. createIndexDirsManager(ServerConfiguration conf, DiskChecker diskChecker, StatsLogger statsLogger, LedgerDirsManager fallback)static LedgerDirsManagerBookieResources. createLedgerDirsManager(ServerConfiguration conf, DiskChecker diskChecker, StatsLogger statsLogger)static LedgerStorageBookieResources. createLedgerStorage(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)static MetadataBookieDriverBookieResources. createMetadataDriver(ServerConfiguration conf, StatsLogger statsLogger)Instantiate the metadata driver for the Bookie.voidCookie. deleteFromRegistrationManager(RegistrationManager rm, ServerConfiguration conf, Version version)Deletes cookie from registration manager.static voidFileSystemUpgrade. finalizeUpgrade(ServerConfiguration conf)static booleanBookieImpl. format(ServerConfiguration conf, boolean isInteractive, boolean force)Format the bookie server data.static Cookie.BuilderCookie. generateCookie(ServerConfiguration conf)Generate cookie from the given configuration.static java.util.List<java.io.File>FileSystemUpgrade. getAllDirectories(ServerConfiguration conf)static BookieSocketAddressBookieImpl. getBookieAddress(ServerConfiguration conf)Return the configured address of the bookie.static BookieIdBookieImpl. getBookieId(ServerConfiguration conf)voidInterleavedLedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)voidLedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)Initialize the LedgerStorage implementation.voidSortedLedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)voidInterleavedLedgerStorage. initializeWithEntryLogger(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, EntryLogger entryLogger, StatsLogger statsLogger)(package private) voidInterleavedLedgerStorage. initializeWithEntryLogListener(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, DefaultEntryLogger.EntryLogListener entryLogListener, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)static LedgerStorageBookieImpl. mountLedgerStorageOffline(ServerConfiguration conf, LedgerStorage ledgerStorage)Initialize LedgerStorage instance without checkpointing for use within the shell and other RO users.static BookieImplBookieImpl. newBookieImpl(ServerConfiguration conf, RegistrationManager registrationManager, LedgerStorage storage, DiskChecker diskChecker, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator, java.util.function.Supplier<BookieServiceInfo> bookieServiceInfoProvider)(package private) static JournalJournal. newJournal(int journalIndex, java.io.File journalDirectory, ServerConfiguration conf, LedgerDirsManager ledgerDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator, JournalAliveListener journalAliveListener)static LegacyCookieValidationLegacyCookieValidation. newLegacyCookieValidation(ServerConfiguration conf, RegistrationManager registrationManager)BookieFileChannelDefaultFileChannelProvider. open(java.io.File file, ServerConfiguration configuration)BookieFileChannelFileChannelProvider. open(java.io.File file, ServerConfiguration configuration)Get the BookieFileChannel with the given file and configuration.static Versioned<Cookie>Cookie. readFromRegistrationManager(RegistrationManager rm, ServerConfiguration conf)Read cookie from registration manager.static voidFileSystemUpgrade. rollback(ServerConfiguration conf)static voidFileSystemUpgrade. upgrade(ServerConfiguration conf)voidCookie. writeToRegistrationManager(RegistrationManager rm, ServerConfiguration conf, Version version)Writes cookie details to registration manager.Constructors in org.apache.bookkeeper.bookie with parameters of type ServerConfiguration Constructor Description AbstractLogCompactor(ServerConfiguration conf, AbstractLogCompactor.LogRemovalListener logRemovalListener)BookieImpl(ServerConfiguration conf, RegistrationManager registrationManager, LedgerStorage storage, DiskChecker diskChecker, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator, java.util.function.Supplier<BookieServiceInfo> bookieServiceInfoProvider)BookieStateManager(ServerConfiguration conf, RegistrationManager registrationManager)BookieStateManager(ServerConfiguration conf, StatsLogger statsLogger, RegistrationManager rm, java.util.List<java.io.File> statusDirs, java.util.function.Supplier<BookieId> bookieIdSupplier, java.util.function.Supplier<BookieServiceInfo> bookieServiceInfoProvider)BookieStateManager(ServerConfiguration conf, StatsLogger statsLogger, RegistrationManager rm, LedgerDirsManager ledgerDirsManager, java.util.function.Supplier<BookieServiceInfo> bookieServiceInfoProvider)DefaultEntryLogger(ServerConfiguration conf)DefaultEntryLogger(ServerConfiguration conf, LedgerDirsManager ledgerDirsManager)Create an EntryLogger that stores it's log files in the given directories.DefaultEntryLogger(ServerConfiguration conf, LedgerDirsManager ledgerDirsManager, DefaultEntryLogger.EntryLogListener listener, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)DefaultFileChannel(java.io.File file, ServerConfiguration serverConfiguration)EntryLogCompactor(ServerConfiguration conf, EntryLogger entryLogger, CompactableLedgerStorage ledgerStorage, AbstractLogCompactor.LogRemovalListener logRemover)EntryLoggerAllocator(ServerConfiguration conf, LedgerDirsManager ledgerDirsManager, DefaultEntryLogger.RecentEntryLogsStatus recentlyCreatedEntryLogsStatus, long logId, io.netty.buffer.ByteBufAllocator byteBufAllocator)EntryLogManagerBase(ServerConfiguration conf, LedgerDirsManager ledgerDirsManager, EntryLoggerAllocator entryLoggerAllocator, java.util.List<DefaultEntryLogger.EntryLogListener> listeners)EntryLogManagerForEntryLogPerLedger(ServerConfiguration conf, LedgerDirsManager ledgerDirsManager, EntryLoggerAllocator entryLoggerAllocator, java.util.List<DefaultEntryLogger.EntryLogListener> listeners, DefaultEntryLogger.RecentEntryLogsStatus recentlyCreatedEntryLogsStatus, StatsLogger statsLogger)EntryLogManagerForSingleEntryLog(ServerConfiguration conf, LedgerDirsManager ledgerDirsManager, EntryLoggerAllocator entryLoggerAllocator, java.util.List<DefaultEntryLogger.EntryLogListener> listeners, DefaultEntryLogger.RecentEntryLogsStatus recentlyCreatedEntryLogsStatus)EntryMemTable(ServerConfiguration conf, CheckpointSource source, StatsLogger statsLogger)Constructor.EntryMemTableWithParallelFlusher(ServerConfiguration conf, CheckpointSource source, StatsLogger statsLogger)GarbageCollectorThread(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, CompactableLedgerStorage ledgerStorage, EntryLogger entryLogger, StatsLogger statsLogger)Create a garbage collector thread.GarbageCollectorThread(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, CompactableLedgerStorage ledgerStorage, EntryLogger entryLogger, StatsLogger statsLogger, java.util.concurrent.ScheduledExecutorService gcExecutor)Create a garbage collector thread.IndexInMemPageMgr(int pageSize, int entriesPerPage, ServerConfiguration conf, IndexPersistenceMgr indexPersistenceManager, StatsLogger statsLogger)IndexPersistenceMgr(int pageSize, int entriesPerPage, ServerConfiguration conf, SnapshotMap<java.lang.Long,java.lang.Boolean> activeLedgers, LedgerDirsManager ledgerDirsManager, StatsLogger statsLogger)InterleavedStorageRegenerateIndexOp(ServerConfiguration conf, java.util.Set<java.lang.Long> ledgerIds, byte[] password)Journal(int journalIndex, java.io.File journalDirectory, ServerConfiguration conf, LedgerDirsManager ledgerDirsManager)Journal(int journalIndex, java.io.File journalDirectory, ServerConfiguration conf, LedgerDirsManager ledgerDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)Journal(int journalIndex, java.io.File journalDirectory, ServerConfiguration conf, LedgerDirsManager ledgerDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator, JournalAliveListener journalAliveListener)JournalChannel(java.io.File journalDirectory, long logId, long preAllocSize, int writeBufferSize, int journalAlignSize, boolean fRemoveFromPageCache, int formatVersionToWrite, Journal.BufferedChannelBuilder bcBuilder, ServerConfiguration conf, FileChannelProvider provider, java.lang.Long toReplaceLogId)JournalChannel(java.io.File journalDirectory, long logId, long preAllocSize, int writeBufferSize, int journalAlignSize, boolean fRemoveFromPageCache, int formatVersionToWrite, ServerConfiguration conf, FileChannelProvider provider)JournalChannel(java.io.File journalDirectory, long logId, long preAllocSize, int writeBufferSize, long position, ServerConfiguration conf, FileChannelProvider provider)JournalChannel(java.io.File journalDirectory, long logId, long preAllocSize, int writeBufferSize, ServerConfiguration conf, FileChannelProvider provider)LedgerCacheImpl(ServerConfiguration conf, SnapshotMap<java.lang.Long,java.lang.Boolean> activeLedgers, LedgerDirsManager ledgerDirsManager)LedgerCacheImpl(ServerConfiguration conf, SnapshotMap<java.lang.Long,java.lang.Boolean> activeLedgers, LedgerDirsManager ledgerDirsManager, StatsLogger statsLogger)LedgerDirsManager(ServerConfiguration conf, java.io.File[] dirs, DiskChecker diskChecker)LedgerDirsManager(ServerConfiguration conf, java.io.File[] dirs, DiskChecker diskChecker, StatsLogger statsLogger)LedgerDirsMonitor(ServerConfiguration conf, DiskChecker diskChecker, java.util.List<LedgerDirsManager> dirsManagers)LegacyCookieValidation(ServerConfiguration conf, RegistrationManager registrationManager)ReadOnlyBookie(ServerConfiguration conf, RegistrationManager registrationManager, LedgerStorage storage, DiskChecker diskChecker, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator, java.util.function.Supplier<BookieServiceInfo> bookieServiceInfoProvider)ReadOnlyDefaultEntryLogger(ServerConfiguration conf)ScanAndCompareGarbageCollector(LedgerManager ledgerManager, CompactableLedgerStorage ledgerStorage, ServerConfiguration conf, StatsLogger statsLogger)SkipListArena(ServerConfiguration cfg)SyncThread(ServerConfiguration conf, LedgerDirsManager.LedgerDirsListener dirsListener, LedgerStorage ledgerStorage, CheckpointSource checkpointSource, StatsLogger statsLogger)Throttler(ServerConfiguration conf)TransactionalEntryLogCompactor(ServerConfiguration conf, EntryLogger entryLogger, CompactableLedgerStorage ledgerStorage, AbstractLogCompactor.LogRemovalListener logRemover) -
Uses of ServerConfiguration in org.apache.bookkeeper.bookie.datainteg
Constructors in org.apache.bookkeeper.bookie.datainteg with parameters of type ServerConfiguration Constructor Description DataIntegrityCookieValidation(ServerConfiguration conf, RegistrationManager registrationManager, DataIntegrityCheck dataIntegCheck) -
Uses of ServerConfiguration in org.apache.bookkeeper.bookie.storage.ldb
Methods in org.apache.bookkeeper.bookie.storage.ldb with parameters of type ServerConfiguration Modifier and Type Method Description (package private) static booleanDbLedgerStorage. getBooleanVariableOrDefault(ServerConfiguration conf, java.lang.String keyName, boolean defaultValue)(package private) static longDbLedgerStorage. getLongVariableOrDefault(ServerConfiguration conf, java.lang.String keyName, long defaultValue)voidDbLedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)voidSingleDirectoryDbLedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)KeyValueStorageKeyValueStorageFactory. newKeyValueStorage(java.lang.String defaultBasePath, java.lang.String subPath, KeyValueStorageFactory.DbConfigType dbConfigType, ServerConfiguration conf)protected SingleDirectoryDbLedgerStorageDbLedgerStorage. newSingleDirectoryDbLedgerStorage(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, EntryLogger entryLogger, StatsLogger statsLogger, long writeCacheSize, long readCacheSize, int readAheadCacheBatchSize, long readAheadCacheBatchBytesSize)static voidDbLedgerStorage. readLedgerIndexEntries(long ledgerId, ServerConfiguration serverConf, SingleDirectoryDbLedgerStorage.LedgerLoggerProcessor processor)Reads ledger index entries to get list of entry-logger that contains given ledgerId.Constructors in org.apache.bookkeeper.bookie.storage.ldb with parameters of type ServerConfiguration Constructor Description EntryLocationIndex(ServerConfiguration conf, KeyValueStorageFactory storageFactory, java.lang.String basePath, StatsLogger stats)KeyValueStorageRocksDB(java.lang.String basePath, java.lang.String subPath, KeyValueStorageFactory.DbConfigType dbConfigType, ServerConfiguration conf)KeyValueStorageRocksDB(java.lang.String basePath, java.lang.String subPath, KeyValueStorageFactory.DbConfigType dbConfigType, ServerConfiguration conf, boolean readOnly)LedgerMetadataIndex(ServerConfiguration conf, KeyValueStorageFactory storageFactory, java.lang.String basePath, StatsLogger stats)LedgersIndexCheckOp(ServerConfiguration conf, boolean verbose)LedgersIndexRebuildOp(ServerConfiguration conf, boolean verbose)LocationsIndexRebuildOp(ServerConfiguration conf)PersistentEntryLogMetadataMap(java.lang.String metadataPath, ServerConfiguration conf)SingleDirectoryDbLedgerStorage(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, EntryLogger entryLogger, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator, long writeCacheSize, long readCacheSize, int readAheadCacheBatchSize, long readAheadCacheBatchBytesSize) -
Uses of ServerConfiguration in org.apache.bookkeeper.client
Methods in org.apache.bookkeeper.client with parameters of type ServerConfiguration Modifier and Type Method Description static booleanBookKeeperAdmin. format(ServerConfiguration conf, boolean isInteractive, boolean force)Format the BookKeeper metadata in zookeeper.static booleanBookKeeperAdmin. initBookie(ServerConfiguration conf)Initializes bookie, by making sure that the journalDir, ledgerDirs and indexDirs are empty and there is no registered Bookie with this BookieId.static booleanBookKeeperAdmin. initNewCluster(ServerConfiguration conf)Initializes new cluster by creating required znodes for the cluster.static booleanBookKeeperAdmin. nukeExistingCluster(ServerConfiguration conf, java.lang.String ledgersRootPath, java.lang.String instanceId, boolean force)Nukes existing cluster metadata. -
Uses of ServerConfiguration in org.apache.bookkeeper.conf
Methods in org.apache.bookkeeper.conf that return ServerConfiguration Modifier and Type Method Description protected ServerConfigurationServerConfiguration. getThis()ServerConfigurationServerConfiguration. removeBookieId()Remove the configured BookieId for the bookie.ServerConfigurationServerConfiguration. setAdvertisedAddress(java.lang.String advertisedAddress)Configure the bookie to advertise a specific address.ServerConfigurationServerConfiguration. setAllowEphemeralPorts(boolean allow)Configure the bookie to allow using an ephemeral port.ServerConfigurationServerConfiguration. setAllowLoopback(boolean allow)Configure the bookie to allow loopback interfaces to be used as the primary bookie interface.ServerConfigurationServerConfiguration. setAllowMultipleDirsUnderSameDiskPartition(boolean allow)Configure the Bookie to allow/disallow multiple ledger/index/journal directories in the same filesystem diskpartition.ServerConfigurationServerConfiguration. setAllowStorageExpansion(boolean val)Change the setting of whether or not we should allow ledger/index dirs to be added to the current set of dirs.ServerConfigurationServerConfiguration. setAuditorLedgerVerificationPercentage(long auditorLedgerVerificationPercentage)Set what percentage of a ledger (fragment)'s entries will be verified.ServerConfigurationServerConfiguration. setAuthorizedRoles(java.lang.String roles)Set authorized roles.ServerConfigurationServerConfiguration. setAutoRecoveryDaemonEnabled(boolean enabled)Sets that whether the auto-recovery service can start along with Bookie server itself or not.ServerConfigurationServerConfiguration. setBookieId(java.lang.String bookieId)Configure the bookie to advertise a specific BookieId.ServerConfigurationServerConfiguration. setBookiePort(int port)Set new bookie port that bookie server listen on.ServerConfigurationServerConfiguration. setCloseChannelOnResponseTimeout(boolean value)Configures action in case if server timed out sending response to the client.ServerConfigurationServerConfiguration. setCompactionMaxOutstandingRequests(int maxOutstandingRequests)Set the maximum number of entries which can be compacted without flushing.ServerConfigurationServerConfiguration. setCompactionRate(int rate)Set the rate of compaction adds.ServerConfigurationServerConfiguration. setCompactionRateByBytes(int rate)Set the rate of compaction adds.ServerConfigurationServerConfiguration. setCompactionRateByEntries(int rate)Set the rate of compaction adds.ServerConfigurationServerConfiguration. setDataIntegrityCheckingEnabled(boolean enabled)Enabled data integrity checker.ServerConfigurationServerConfiguration. setDataIntegrityStampMissingCookiesEnabled(boolean enabled)When this config is set to true and the data integrity checker is also enabled then any missing cookie files in the ledger directories do not prevent the bookie from booting.ServerConfigurationServerConfiguration. setDefaultRocksDBConf(java.lang.String defaultRocksdbConf)Set default rocksdb conf.ServerConfigurationServerConfiguration. setDisableServerSocketBind(boolean disableServerSocketBind)Configure the bookie to disable bind on network interfaces, this bookie will be available only to BookKeeper clients executed on the local JVM.ServerConfigurationServerConfiguration. setDiskCheckInterval(int interval)Set the disk checker interval to monitor ledger disk space.ServerConfigurationServerConfiguration. setDiskLowWaterMarkUsageThreshold(float threshold)Set the disk free space low water mark threshold.ServerConfigurationServerConfiguration. setDiskUsageThreshold(float threshold)Set the Disk free space threshold as a fraction of the total after which disk will be considered as full during disk check.ServerConfigurationServerConfiguration. setDiskUsageWarnThreshold(float threshold)Set the warning threshold for disk usage.ServerConfigurationServerConfiguration. setEnableLocalTransport(boolean enableLocalTransport)Configure the bookie to listen for BookKeeper clients executed on the local JVM.ServerConfigurationServerConfiguration. setEnableTaskExecutionStats(boolean enabled)Enable/Disable recording task execution stats.ServerConfigurationServerConfiguration. setEntryLocationCompactionInterval(long interval)Set interval to run entry location compaction.ServerConfigurationServerConfiguration. setEntryLocationRocksdbConf(java.lang.String entryLocationRocksdbConf)Set entry Location rocksdb conf.ServerConfigurationServerConfiguration. setEntryLogFilePreAllocationEnabled(boolean enabled)Enable/disable entry log file preallocation.ServerConfigurationServerConfiguration. setEntrylogMapAccessExpiryTimeInSeconds(int entrylogMapAccessExpiryTimeInSeconds)ServerConfigurationServerConfiguration. setEntryLogPerLedgerCounterLimitsMultFactor(int entryLogPerLedgerCounterLimitsMultFactor)ServerConfigurationServerConfiguration. setEntryLogPerLedgerEnabled(boolean entryLogPerLedgerEnabled)ServerConfigurationServerConfiguration. setEntryLogSizeLimit(long logSizeLimit)Set entry logger size limitation.ServerConfigurationServerConfiguration. setExtraServerComponents(java.lang.String[] componentClasses)Set the extra list of server lifecycle components to enable on a bookie server.ServerConfigurationServerConfiguration. setFileInfoCacheInitialCapacity(int initialCapacity)Set the minimum total size for the internal file info cache tables for initialization.ServerConfigurationServerConfiguration. setFileInfoFormatVersionToWrite(int version)Set fileinfo format version to write.ServerConfigurationServerConfiguration. setFileInfoMaxIdleTime(long idleTime)Set the max idle time allowed for a open file info existed in file info cache.ServerConfigurationServerConfiguration. setFlushInterval(int flushInterval)Set flush interval.ServerConfigurationServerConfiguration. setFlushIntervalInBytes(long flushInterval)Set entry log flush interval in bytes.ServerConfigurationServerConfiguration. setForceAllowCompaction(boolean enable)Allow manually force compact the entry log or not.ServerConfigurationServerConfiguration. setForceReadOnlyBookie(boolean enabled)Sets that whether force start a bookie in readonly mode.ServerConfigurationServerConfiguration. setGcEntryLogMetadataCacheEnabled(boolean gcEntryLogMetadataCacheEnabled)Set whether the bookie is configured to use persistent entrylogMetadataMap.ServerConfigurationServerConfiguration. setGcEntryLogMetadataCachePath(java.lang.String gcEntrylogMetadataCachePath)Set directory to persist Entrylog metadata if gcPersistentEntrylogMetadataMapEnabled is true.ServerConfigurationServerConfiguration. setGcMetadataOpRateLimit(int gcRateLimit)Set the rate limit of metadata operations in garbage collection.ServerConfigurationServerConfiguration. setGcOverreplicatedLedgerMaxConcurrentRequests(int gcOverreplicatedLedgerMaxConcurrentRequests)Max number of concurrent requests in garbage collection of overreplicated ledgers.ServerConfigurationServerConfiguration. setGcOverreplicatedLedgerWaitTime(long gcWaitTime, java.util.concurrent.TimeUnit unit)Set wait time for garbage collection of overreplicated ledgers.ServerConfigurationServerConfiguration. setGcWaitTime(long gcWaitTime)Set garbage collection wait time.ServerConfigurationServerConfiguration. setHttpServerEnabled(boolean enabled)Set whether to start the http server or not.ServerConfigurationServerConfiguration. setHttpServerHost(java.lang.String host)Set Http server host listening on.ServerConfigurationServerConfiguration. setHttpServerKeyStorePassword(java.lang.String keyStorePassword)Set Http server keyStore password.ServerConfigurationServerConfiguration. setHttpServerKeystorePath(java.lang.String keystorePath)Set Http server keystore path.ServerConfigurationServerConfiguration. setHttpServerPort(int port)Set Http server port listening on.ServerConfigurationServerConfiguration. setHttpServerTlsEnable(boolean tlsEnable)Set if Http Server Tls enable.ServerConfigurationServerConfiguration. setHttpServerTrustStorePasswordPassword(java.lang.String trustStorePassword)Set Http server trustStore password.ServerConfigurationServerConfiguration. setHttpServerTrustStorePath(java.lang.String trustStorePath)Set Http server trustStore path.ServerConfigurationServerConfiguration. setIgnoreExtraServerComponentsStartupFailures(boolean enabled)Set the flag whether to ignore startup failures on loading server components specified atgetExtraServerComponents().ServerConfigurationServerConfiguration. setIndexDirName(java.lang.String[] indexDirs)Set dir name to store index files.ServerConfigurationServerConfiguration. setIsForceGCAllowWhenNoSpace(boolean force)Set whether force GC is allowed when disk full or almost full.ServerConfigurationServerConfiguration. setIsThrottleByBytes(boolean byBytes)Set whether use bytes to throttle garbage collector compaction or not.ServerConfigurationServerConfiguration. setJournalAdaptiveGroupWrites(boolean enabled)Enable/disable group journal force writes.ServerConfigurationServerConfiguration. setJournalAlignmentSize(int size)Set journal alignment size.ServerConfigurationServerConfiguration. setJournalBufferedEntriesThreshold(int maxEntries)Set maximum entries to buffer to impose on a journal write to achieve grouping.ServerConfigurationServerConfiguration. setJournalBufferedWritesThreshold(long maxBytes)Set maximum bytes to buffer to impose on a journal write to achieve grouping.ServerConfigurationServerConfiguration. setJournalChannelProvider(java.lang.String journalChannelProvider)Set JournalChannelProvider classname.ServerConfigurationServerConfiguration. setJournalDirName(java.lang.String journalDir)Set dir name to store journal files.ServerConfigurationServerConfiguration. setJournalDirsName(java.lang.String[] journalDirs)Set dir names to store journal files.ServerConfigurationServerConfiguration. setJournalFlushWhenQueueEmpty(boolean enabled)Set if we should flush the journal when queue is empty.ServerConfigurationServerConfiguration. setJournalFormatVersionToWrite(int version)Set journal format version to write.ServerConfigurationServerConfiguration. setJournalMaxGroupWaitMSec(long journalMaxGroupWaitMSec)Sets the maximum latency to impose on a journal write to achieve grouping.ServerConfigurationServerConfiguration. setJournalMaxMemorySizeMb(long journalMaxMemorySizeMb)Set the max amount of memory that can be used by the journal.ServerConfigurationServerConfiguration. setJournalPageCacheFlushIntervalMSec(long journalPageCacheFlushIntervalMSec)Set PageCache flush interval in second.ServerConfigurationServerConfiguration. setJournalQueueSize(int journalQueueSize)Set the size of the journal queue.ServerConfigurationServerConfiguration. setJournalRemovePagesFromCache(boolean enabled)Sets that whether should we remove pages from page cache after force write.ServerConfigurationServerConfiguration. setJournalReuseFiles(boolean journalReuseFiles)Set reuse journal files.ServerConfigurationServerConfiguration. setJournalSyncData(boolean syncData)Enable or disable journal syncs.ServerConfigurationServerConfiguration. setJournalWriteBufferSizeKB(int bufferSizeKB)Set the size of the write buffers used for the journal.ServerConfigurationServerConfiguration. setJournalWriteData(boolean journalWriteData)Should the data be written to journal before acknowledgment.ServerConfigurationServerConfiguration. setLedgerDirNames(java.lang.String[] ledgerDirs)Set dir names to store ledger data.ServerConfigurationServerConfiguration. setLedgerMetadataRocksdbConf(java.lang.String ledgerMetadataRocksdbConf)Set ledger metadata rocksdb conf.ServerConfigurationServerConfiguration. setLedgerStorageClass(java.lang.String ledgerStorageClass)Set theLedgerStorageimplementation class name.ServerConfigurationServerConfiguration. setListeningInterface(java.lang.String iface)Set the network interface that the bookie should listen on.ServerConfigurationServerConfiguration. setMajorCompactionInterval(long interval)Set interval to run major compaction.ServerConfigurationServerConfiguration. setMajorCompactionMaxTimeMillis(long majorCompactionMaxTimeMillis)Set the maximum milliseconds to run major compaction.ServerConfigurationServerConfiguration. setMajorCompactionThreshold(double threshold)Set threshold of major compaction.ServerConfigurationServerConfiguration. setMaxAddsInProgressLimit(int value)Set max number of adds in progress.ServerConfigurationServerConfiguration. setMaxBackupJournals(int maxBackupJournals)Set max number of older journal files to kept.ServerConfigurationServerConfiguration. setMaxBatchReadSize(long maxBatchReadSize)Set the max batch read size.ServerConfigurationServerConfiguration. setMaximumNumberOfActiveEntryLogs(int maximumNumberOfActiveEntryLogs)ServerConfigurationServerConfiguration. setMaxJournalSizeMB(long maxJournalSize)Set new max journal file size.ServerConfigurationServerConfiguration. setMaxPendingAddRequestPerThread(int maxPendingAddRequestsPerThread)Set the max number of pending add requests for each add worker thread.ServerConfigurationServerConfiguration. setMaxPendingReadRequestPerThread(int maxPendingReadRequestsPerThread)Set the max number of pending read requests for each read worker thread.ServerConfigurationServerConfiguration. setMaxReadsInProgressLimit(int value)Set max number of reads in progress.ServerConfigurationServerConfiguration. setMinorCompactionInterval(long interval)Set interval to run minor compaction.ServerConfigurationServerConfiguration. setMinorCompactionMaxTimeMillis(long minorCompactionMaxTimeMillis)Set the maximum milliseconds to run minor compaction.ServerConfigurationServerConfiguration. setMinorCompactionThreshold(double threshold)Set threshold of minor compaction.ServerConfigurationServerConfiguration. setMinUsableSizeForEntryLogCreation(long minUsableSizeForEntryLogCreation)Sets the minimum safe usable size to be available in ledger directory for Bookie to create entry log files.ServerConfigurationServerConfiguration. setMinUsableSizeForHighPriorityWrites(long minUsableSizeForHighPriorityWrites)Sets the minimum safe usable size to be available in ledger directory for Bookie to accept high priority writes.ServerConfigurationServerConfiguration. setMinUsableSizeForIndexFileCreation(long minUsableSizeForIndexFileCreation)Sets the minimum safe Usable size to be available in index directory for Bookie to create Index File while replaying journal at the time of Bookie Start in Readonly Mode (in bytes).ServerConfigurationServerConfiguration. setNettyMaxFrameSizeBytes(int maxSize)Set the max number of bytes a single message can be that is read by the bookie.ServerConfigurationServerConfiguration. setNumAddWorkerThreads(int numThreads)Set the number of threads that would handle write requests.ServerConfigurationServerConfiguration. setNumHighPriorityWorkerThreads(int numThreads)Set the number of threads that should be used for high priority requests (i.e.ServerConfigurationServerConfiguration. setNumJournalCallbackThreads(int numThreads)Deprecated.ServerConfigurationServerConfiguration. setNumLongPollWorkerThreads(int numThreads)Set the number of threads that should handle long poll requests.ServerConfigurationServerConfiguration. setNumOfMemtableFlushThreads(int numOfMemtableFlushThreads)ServerConfigurationServerConfiguration. setNumReadWorkerThreads(int numThreads)Set the number of threads that would handle read requests.ServerConfigurationServerConfiguration. setOpenFileLimit(int fileLimit)Set limitation of number of open files.ServerConfigurationServerConfiguration. setOperationMaxNumbersInSingleRocksDBWriteBatch(int maxNumbersInSingleRocksDBBatch)Set the max operation numbers in a single rocksdb write batch.ServerConfigurationServerConfiguration. setPageLimit(int pageLimit)Set limitation number of index pages in ledger cache.ServerConfigurationServerConfiguration. setPageSize(int pageSize)Set page size.ServerConfigurationServerConfiguration. setPersistBookieStatusEnabled(boolean enabled)Whether to persist the bookie status so that when bookie server restarts, it will continue using the previous status.ServerConfigurationServerConfiguration. setReadBufferBytes(int readBufferSize)Set the number of bytes we should use as capacity for org.apache.bookkeeper.bookie.BufferedReadChannel.ServerConfigurationServerConfiguration. setReadOnlyModeEnabled(boolean enabled)Set whether the bookie is able to go into read-only mode.ServerConfigurationServerConfiguration. setReadOnlyModeOnAnyDiskFullEnabled(boolean enabled)Set whether the bookie is able to go into read-only mode when any disk is full.ServerConfigurationServerConfiguration. setReadWorkerThreadsThrottlingEnabled(boolean throttle)Use auto-throttling of the read-worker threads.ServerConfigurationServerConfiguration. setRequestTimerNumTicks(int tickCount)Set the number of ticks per wheel for the request timer.ServerConfigurationServerConfiguration. setRequestTimerTickDurationMs(int tickDuration)Set the tick duration in milliseconds.ServerConfigurationServerConfiguration. setSanityCheckMetricsEnabled(boolean sanityCheckMetricsEnabled)Enable sanity check metrics in bookie stats.ServerConfigurationServerConfiguration. setServerNumIOThreads(int numThreads)Set the number of IO threads.ServerConfigurationServerConfiguration. setServerSockKeepalive(boolean keepalive)Set socket keepalive setting.ServerConfigurationServerConfiguration. setServerSockLinger(int linger)Set socket linger timeout on close.ServerConfigurationServerConfiguration. setServerTcpNoDelay(boolean noDelay)Set socket nodelay setting.ServerConfigurationServerConfiguration. setServerWriteBufferHighWaterMark(int waterMark)Set server netty channel write buffer high water mark.ServerConfigurationServerConfiguration. setServerWriteBufferLowWaterMark(int waterMark)Set server netty channel write buffer low water mark.ServerConfigurationServerConfiguration. setSkipListArenaChunkSize(int size)Set the number of bytes we used as chunk allocation for org.apache.bookkeeper.bookie.SkipListArena.ServerConfigurationServerConfiguration. setSkipListArenaMaxAllocSize(int size)Set the max size we should allocate from the skiplist arena.ServerConfigurationServerConfiguration. setSkipListSizeLimit(int size)Set skip list size limit.ServerConfigurationServerConfiguration. setSkipReplayJournalInvalidRecord(boolean skipReplayJournalInvalidRecord)When this config is set to true,if we replay journal failed, we will skip.ServerConfigurationServerConfiguration. setSortedLedgerStorageEnabled(boolean enabled)Deprecated.UsesetLedgerStorageClass(String)to configure the implementation classServerConfigurationServerConfiguration. setStatisticsEnabled(boolean enabled)Turn on/off statistics.ServerConfigurationServerConfiguration. setStatsProviderClass(java.lang.Class<? extends StatsProvider> providerClass)Set the stats provider used by bookie.ServerConfigurationServerConfiguration. setTLSCertificatePath(java.lang.String arg)Set the path to file containing TLS Certificate.ServerConfigurationServerConfiguration. setTLSKeyStore(java.lang.String arg)Set the keystore path for the client.ServerConfigurationServerConfiguration. setTLSKeyStorePasswordPath(java.lang.String arg)Set the path to file containing keystore password, if the client keystore is password protected.ServerConfigurationServerConfiguration. setTLSKeyStoreType(java.lang.String arg)Set the keystore type for client.ServerConfigurationServerConfiguration. setTLSTrustStore(java.lang.String arg)Set the truststore path for the client.ServerConfigurationServerConfiguration. setTLSTrustStorePasswordPath(java.lang.String arg)Set the path to file containing truststore password, if the client truststore is password protected.ServerConfigurationServerConfiguration. setTLSTrustStoreType(java.lang.String arg)Set the truststore type for client.ServerConfigurationServerConfiguration. setUseHostNameAsBookieID(boolean useHostName)Configure the bookie to use its hostname to register with the co-ordination service(eg: zookeeper) and in ledger metadata.ServerConfigurationServerConfiguration. setUseShortHostName(boolean useShortHostName)Configure the bookie to use its short hostname or FQDN hostname to register with the co-ordination service(eg: zookeeper) and in ledger metadata.ServerConfigurationServerConfiguration. setUseTargetEntryLogSizeForGc(boolean useTargetEntryLogSizeForGc)ServerConfigurationServerConfiguration. setUseTransactionalCompaction(boolean useTransactionalCompaction)Set whether to use transactional compaction and using a separate log for compaction or not.ServerConfigurationServerConfiguration. setVerifyMetadataOnGc(boolean verifyMetadataOnGC)Set whether the bookie is configured to double check prior to gc.ServerConfigurationServerConfiguration. setWaitTimeoutOnResponseBackpressureMillis(long value)Timeout controlling wait on response send in case of unresponsive client (i.e.ServerConfigurationServerConfiguration. setWriteBufferBytes(int writeBufferBytes)Set the number of bytes used as capacity for the write buffer.ServerConfigurationServerConfiguration. setZkRetryBackoffMaxMs(int retryMs)Set zookeeper client backoff retry max time in millis.ServerConfigurationServerConfiguration. setZkRetryBackoffStartMs(int retryMs)Set zookeeper client backoff retry start time in millis. -
Uses of ServerConfiguration in org.apache.bookkeeper.discover
Constructors in org.apache.bookkeeper.discover with parameters of type ServerConfiguration Constructor Description ZKRegistrationManager(ServerConfiguration conf, org.apache.zookeeper.ZooKeeper zk)ZKRegistrationManager(ServerConfiguration conf, org.apache.zookeeper.ZooKeeper zk, java.lang.String ledgersRootPath) -
Uses of ServerConfiguration in org.apache.bookkeeper.meta
Methods in org.apache.bookkeeper.meta with parameters of type ServerConfiguration Modifier and Type Method Description MetadataBookieDriverMetadataBookieDriver. initialize(ServerConfiguration conf, StatsLogger statsLogger)Initialize the metadata driver.MetadataBookieDriverNullMetadataBookieDriver. initialize(ServerConfiguration conf, StatsLogger statsLogger)static <T> TMetadataDrivers. runFunctionWithLedgerManagerFactory(ServerConfiguration conf, java.util.function.Function<LedgerManagerFactory,T> function)Process the provided function with ledger manager factory resolved from the metadata service uri returned byAbstractConfiguration.getMetadataServiceUri().static <T> TMetadataDrivers. runFunctionWithMetadataBookieDriver(ServerConfiguration conf, java.util.function.Function<MetadataBookieDriver,T> function)Process the provided function with metadata bookie driver resolved from the metadata service uri returned byAbstractConfiguration.getMetadataServiceUri().static <T> TMetadataDrivers. runFunctionWithRegistrationManager(ServerConfiguration conf, java.util.function.Function<RegistrationManager,T> function)Process the provided function with registration manager resolved from the metadata service uri returned byAbstractConfiguration.getMetadataServiceUri().Constructors in org.apache.bookkeeper.meta with parameters of type ServerConfiguration Constructor Description ZkLedgerAuditorManager(org.apache.zookeeper.ZooKeeper zkc, ServerConfiguration conf, StatsLogger statsLogger) -
Uses of ServerConfiguration in org.apache.bookkeeper.meta.zk
Fields in org.apache.bookkeeper.meta.zk declared as ServerConfiguration Modifier and Type Field Description (package private) ServerConfigurationZKMetadataBookieDriver. serverConfMethods in org.apache.bookkeeper.meta.zk with parameters of type ServerConfiguration Modifier and Type Method Description MetadataBookieDriverZKMetadataBookieDriver. initialize(ServerConfiguration conf, StatsLogger statsLogger)(package private) ZKRegistrationManagerZKMetadataBookieDriver. newZKRegistrationManager(ServerConfiguration serverConf, org.apache.zookeeper.ZooKeeper zk) -
Uses of ServerConfiguration in org.apache.bookkeeper.proto
Fields in org.apache.bookkeeper.proto declared as ServerConfiguration Modifier and Type Field Description (package private) ServerConfigurationBookieNettyServer. conf(package private) ServerConfigurationBookieServer. confMethods in org.apache.bookkeeper.proto that return ServerConfiguration Modifier and Type Method Description (package private) ServerConfigurationBookieRequestProcessor. getServerCfg()The server configuration.Methods in org.apache.bookkeeper.proto with parameters of type ServerConfiguration Modifier and Type Method Description static BookieServerBookieServer. newBookieServer(ServerConfiguration conf, Bookie bookie, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator, UncleanShutdownDetection uncleanShutdownDetection)Constructors in org.apache.bookkeeper.proto with parameters of type ServerConfiguration Constructor Description BookieNettyServer(ServerConfiguration conf, RequestProcessor processor, io.netty.buffer.ByteBufAllocator allocator)BookieRequestHandler(ServerConfiguration conf, RequestProcessor processor, io.netty.channel.group.ChannelGroup allChannels)BookieRequestProcessor(ServerConfiguration serverCfg, Bookie bookie, StatsLogger statsLogger, SecurityHandlerFactory shFactory, io.netty.buffer.ByteBufAllocator allocator, io.netty.channel.group.ChannelGroup allChannels)BookieServer(ServerConfiguration conf, Bookie bookie, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator, UncleanShutdownDetection uncleanShutdownDetection)SimpleBookieServiceInfoProvider(ServerConfiguration serverConfiguration) -
Uses of ServerConfiguration in org.apache.bookkeeper.replication
Fields in org.apache.bookkeeper.replication declared as ServerConfiguration Modifier and Type Field Description protected ServerConfigurationAuditorTask. confMethods in org.apache.bookkeeper.replication with parameters of type ServerConfiguration Modifier and Type Method Description (package private) static BookKeeperAuditor. createBookKeeperClient(ServerConfiguration conf)(package private) static BookKeeperAuditor. createBookKeeperClient(ServerConfiguration conf, StatsLogger statsLogger)(package private) static BookKeeperAuditor. createBookKeeperClientThrowUnavailableException(ServerConfiguration conf)(package private) BookKeeperAuditorTask. getBookKeeper(ServerConfiguration conf)Get BookKeeper client according to configuration.Constructors in org.apache.bookkeeper.replication with parameters of type ServerConfiguration Constructor Description Auditor(java.lang.String bookieIdentifier, ServerConfiguration conf, BookKeeper bkc, boolean ownBkc, BookKeeperAdmin admin, boolean ownAdmin, StatsLogger statsLogger)Auditor(java.lang.String bookieIdentifier, ServerConfiguration conf, BookKeeper bkc, boolean ownBkc, StatsLogger statsLogger)Auditor(java.lang.String bookieIdentifier, ServerConfiguration conf, StatsLogger statsLogger)AuditorBookieCheckTask(ServerConfiguration conf, AuditorStats auditorStats, BookKeeperAdmin admin, LedgerManager ledgerManager, LedgerUnderreplicationManager ledgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler shutdownTaskHandler, BookieLedgerIndexer bookieLedgerIndexer, java.util.function.BiConsumer<java.util.concurrent.atomic.AtomicBoolean,java.lang.Throwable> hasAuditCheckTask, java.util.function.BiConsumer<java.lang.Void,java.lang.Throwable> submitCheckTask)AuditorCheckAllLedgersTask(ServerConfiguration conf, AuditorStats auditorStats, BookKeeperAdmin admin, LedgerManager ledgerManager, LedgerUnderreplicationManager ledgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler shutdownTaskHandler, java.util.function.BiConsumer<java.util.concurrent.atomic.AtomicBoolean,java.lang.Throwable> hasAuditCheckTask)AuditorElector(java.lang.String bookieId, ServerConfiguration conf)AuditorElector(java.lang.String bookieId, ServerConfiguration conf, BookKeeper bkc, boolean ownBkc)AuditorElector for performing the auditor election.AuditorElector(java.lang.String bookieId, ServerConfiguration conf, BookKeeper bkc, StatsLogger statsLogger, boolean ownBkc)AuditorElector for performing the auditor election.AuditorPlacementPolicyCheckTask(ServerConfiguration conf, AuditorStats auditorStats, BookKeeperAdmin admin, LedgerManager ledgerManager, LedgerUnderreplicationManager ledgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler shutdownTaskHandler, java.util.function.BiConsumer<java.util.concurrent.atomic.AtomicBoolean,java.lang.Throwable> hasAuditCheckTask)AuditorReplicasCheckTask(ServerConfiguration conf, AuditorStats auditorStats, BookKeeperAdmin admin, LedgerManager ledgerManager, LedgerUnderreplicationManager ledgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler shutdownTaskHandler, java.util.function.BiConsumer<java.util.concurrent.atomic.AtomicBoolean,java.lang.Throwable> hasAuditCheckTask)AuditorTask(ServerConfiguration conf, AuditorStats auditorStats, BookKeeperAdmin admin, LedgerManager ledgerManager, LedgerUnderreplicationManager ledgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler shutdownTaskHandler, java.util.function.BiConsumer<java.util.concurrent.atomic.AtomicBoolean,java.lang.Throwable> hasAuditCheckTask)AutoRecoveryMain(ServerConfiguration conf)AutoRecoveryMain(ServerConfiguration conf, StatsLogger statsLogger)ReplicationWorker(ServerConfiguration conf)Replication worker for replicating the ledger fragments from UnderReplicationManager to the targetBookie.ReplicationWorker(ServerConfiguration conf, BookKeeper bkc, boolean ownBkc, StatsLogger statsLogger)ReplicationWorker(ServerConfiguration conf, StatsLogger statsLogger)Replication worker for replicating the ledger fragments from UnderReplicationManager to the targetBookie. -
Uses of ServerConfiguration in org.apache.bookkeeper.sasl
Methods in org.apache.bookkeeper.sasl with parameters of type ServerConfiguration Modifier and Type Method Description voidSASLBookieAuthProviderFactory. init(ServerConfiguration conf)Constructors in org.apache.bookkeeper.sasl with parameters of type ServerConfiguration Constructor Description SASLBookieAuthProvider(BookieConnectionPeer addr, AuthCallbacks.GenericCallback<java.lang.Void> completeCb, ServerConfiguration serverConfiguration, javax.security.auth.Subject subject, java.util.regex.Pattern allowedIdsPattern)SaslServerState(ServerConfiguration serverConfiguration, javax.security.auth.Subject subject, java.util.regex.Pattern allowedIdsPattern) -
Uses of ServerConfiguration in org.apache.bookkeeper.server
Methods in org.apache.bookkeeper.server with parameters of type ServerConfiguration Modifier and Type Method Description static java.util.List<java.io.File>Main. storageDirectoriesFromConf(ServerConfiguration conf) -
Uses of ServerConfiguration in org.apache.bookkeeper.server.conf
Methods in org.apache.bookkeeper.server.conf that return ServerConfiguration Modifier and Type Method Description ServerConfigurationBookieConfiguration. getServerConf()Constructors in org.apache.bookkeeper.server.conf with parameters of type ServerConfiguration Constructor Description BookieConfiguration(ServerConfiguration conf) -
Uses of ServerConfiguration in org.apache.bookkeeper.server.http
Fields in org.apache.bookkeeper.server.http declared as ServerConfiguration Modifier and Type Field Description (package private) ServerConfigurationBKHttpServiceProvider.Builder. serverConfMethods in org.apache.bookkeeper.server.http with parameters of type ServerConfiguration Modifier and Type Method Description BKHttpServiceProvider.BuilderBKHttpServiceProvider.Builder. setServerConfiguration(ServerConfiguration conf) -
Uses of ServerConfiguration in org.apache.bookkeeper.server.http.service
Fields in org.apache.bookkeeper.server.http.service declared as ServerConfiguration Modifier and Type Field Description protected ServerConfigurationAutoRecoveryStatusService. confprotected ServerConfigurationConfigurationService. confprotected ServerConfigurationDecommissionService. confprotected ServerConfigurationDeleteLedgerService. confprotected ServerConfigurationExpandStorageService. confprotected ServerConfigurationGCDetailsService. confprotected ServerConfigurationGetLastLogMarkService. confprotected ServerConfigurationGetLedgerMetaService. confprotected ServerConfigurationListBookieInfoService. confprotected ServerConfigurationListBookiesService. confprotected ServerConfigurationListDiskFilesService. confprotected ServerConfigurationListLedgerService. confprotected ServerConfigurationListUnderReplicatedLedgerService. confprotected ServerConfigurationLostBookieRecoveryDelayService. confprotected ServerConfigurationReadLedgerEntryService. confprotected ServerConfigurationRecoveryBookieService. confprotected ServerConfigurationTriggerAuditService. confprotected ServerConfigurationTriggerGCService. confprotected ServerConfigurationWhoIsAuditorService. conf -
Uses of ServerConfiguration in org.apache.bookkeeper.tls
Methods in org.apache.bookkeeper.tls with parameters of type ServerConfiguration Modifier and Type Method Description voidBookieAuthZFactory. init(ServerConfiguration conf) -
Uses of ServerConfiguration in org.apache.bookkeeper.tools.cli.commands.autorecovery
Methods in org.apache.bookkeeper.tools.cli.commands.autorecovery with parameters of type ServerConfiguration Modifier and Type Method Description booleanListUnderReplicatedCommand. apply(ServerConfiguration conf, ListUnderReplicatedCommand.LURFlags cmdFlags)booleanLostBookieRecoveryDelayCommand. apply(ServerConfiguration conf, LostBookieRecoveryDelayCommand.LBRDFlags cmdFlags)booleanQueryAutoRecoveryStatusCommand. apply(ServerConfiguration conf, QueryAutoRecoveryStatusCommand.QFlags cmdFlags)booleanToggleCommand. apply(ServerConfiguration conf, ToggleCommand.AutoRecoveryFlags cmdFlags)booleanTriggerAuditCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)booleanWhoIsAuditorCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)booleanListUnderReplicatedCommand. handler(ServerConfiguration bkConf, ListUnderReplicatedCommand.LURFlags flags)booleanLostBookieRecoveryDelayCommand. handler(ServerConfiguration conf, LostBookieRecoveryDelayCommand.LBRDFlags flags)booleanQueryAutoRecoveryStatusCommand. handler(ServerConfiguration conf, QueryAutoRecoveryStatusCommand.QFlags flag)booleanTriggerAuditCommand. handler(ServerConfiguration configuration) -
Uses of ServerConfiguration in org.apache.bookkeeper.tools.cli.commands.bookie
-
Uses of ServerConfiguration in org.apache.bookkeeper.tools.cli.commands.bookies
Methods in org.apache.bookkeeper.tools.cli.commands.bookies with parameters of type ServerConfiguration Modifier and Type Method Description booleanClusterInfoCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)booleanDecommissionCommand. apply(ServerConfiguration conf, DecommissionCommand.DecommissionFlags cmdFlags)booleanEndpointInfoCommand. apply(ServerConfiguration conf, EndpointInfoCommand.EndpointInfoFlags cmdFlags)booleanInfoCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)booleanInitCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)booleanInstanceIdCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)booleanMetaFormatCommand. apply(ServerConfiguration conf, MetaFormatCommand.MetaFormatFlags flags)booleanNukeExistingClusterCommand. apply(ServerConfiguration conf, NukeExistingClusterCommand.NukeExistingClusterFlags cmdFlags)booleanRecoverCommand. apply(ServerConfiguration conf, RecoverCommand.RecoverFlags cmdFlags) -
Uses of ServerConfiguration in org.apache.bookkeeper.tools.cli.commands.client
Methods in org.apache.bookkeeper.tools.cli.commands.client with parameters of type ServerConfiguration Modifier and Type Method Description booleanDeleteLedgerCommand. apply(ServerConfiguration conf, DeleteLedgerCommand.DeleteLedgerFlags cmdFlags)booleanLedgerMetaDataCommand. apply(ServerConfiguration conf, LedgerMetaDataCommand.LedgerMetadataFlag cmdFlags) -
Uses of ServerConfiguration in org.apache.bookkeeper.tools.cli.commands.cookie
Methods in org.apache.bookkeeper.tools.cli.commands.cookie with parameters of type ServerConfiguration Modifier and Type Method Description booleanAdminCommand. apply(ServerConfiguration conf, AdminCommand.AdminFlags cmdFlags) -
Uses of ServerConfiguration in org.apache.bookkeeper.tools.cli.commands.health
Methods in org.apache.bookkeeper.tools.cli.commands.health with parameters of type ServerConfiguration Modifier and Type Method Description booleanSwitchOfHealthCheckCommand. apply(ServerConfiguration conf, SwitchOfHealthCheckCommand.HealthCheckFlags cmdFlags) -
Uses of ServerConfiguration in org.apache.bookkeeper.tools.cli.helpers
Methods in org.apache.bookkeeper.tools.cli.helpers with parameters of type ServerConfiguration Modifier and Type Method Description abstract booleanBookieCommand. apply(ServerConfiguration conf, BookieFlagsT cmdFlags)booleanClientCommand. apply(ServerConfiguration conf, ClientFlagsT cmdFlags) -
Uses of ServerConfiguration in org.apache.bookkeeper.util
Methods in org.apache.bookkeeper.util with parameters of type ServerConfiguration Modifier and Type Method Description static LocalBookKeeperLocalBookKeeper. getLocalBookies(java.lang.String zkHost, int zkPort, int numBookies, boolean shouldStartZK, ServerConfiguration conf)static io.netty.channel.EventLoopGroupEventLoopUtil. getServerAcceptorGroup(ServerConfiguration conf, java.util.concurrent.ThreadFactory threadFactory)static io.netty.channel.EventLoopGroupEventLoopUtil. getServerEventLoopGroup(ServerConfiguration conf, java.util.concurrent.ThreadFactory threadFactory)Constructors in org.apache.bookkeeper.util with parameters of type ServerConfiguration Constructor Description LocalBookKeeper(int numberOfBookies, ServerConfiguration baseConf, java.lang.String localBookiesConfigDirName, boolean stopOnExit, java.lang.String dirSuffix, java.lang.String zkHost, int zkPort)
-