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 void
BookieAuthProvider.Factory. init(ServerConfiguration conf)
Initialize the factory with the server configuration and protobuf message registry.static BookieAuthProvider.Factory
AuthProviderFactoryFactory. 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) ServerConfiguration
BookieShell. bkConf
protected ServerConfiguration
AbstractLogCompactor. conf
(package private) ServerConfiguration
BookieImpl. conf
(package private) ServerConfiguration
DefaultEntryLogger. conf
(package private) ServerConfiguration
EntryMemTable. conf
(package private) ServerConfiguration
GarbageCollectorThread. conf
(package private) ServerConfiguration
Journal. conf
(package private) ServerConfiguration
JournalChannel. configuration
Methods in org.apache.bookkeeper.bookie with parameters of type ServerConfiguration Modifier and Type Method Description static ByteBufAllocatorWithOomHandler
BookieResources. createAllocator(ServerConfiguration conf)
static DiskChecker
BookieResources. createDiskChecker(ServerConfiguration conf)
static LedgerDirsManager
BookieResources. createIndexDirsManager(ServerConfiguration conf, DiskChecker diskChecker, StatsLogger statsLogger, LedgerDirsManager fallback)
static LedgerDirsManager
BookieResources. createLedgerDirsManager(ServerConfiguration conf, DiskChecker diskChecker, StatsLogger statsLogger)
static LedgerStorage
BookieResources. createLedgerStorage(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)
static MetadataBookieDriver
BookieResources. createMetadataDriver(ServerConfiguration conf, StatsLogger statsLogger)
Instantiate the metadata driver for the Bookie.void
Cookie. deleteFromRegistrationManager(RegistrationManager rm, ServerConfiguration conf, Version version)
Deletes cookie from registration manager.static void
FileSystemUpgrade. finalizeUpgrade(ServerConfiguration conf)
static boolean
BookieImpl. format(ServerConfiguration conf, boolean isInteractive, boolean force)
Format the bookie server data.static Cookie.Builder
Cookie. generateCookie(ServerConfiguration conf)
Generate cookie from the given configuration.static java.util.List<java.io.File>
FileSystemUpgrade. getAllDirectories(ServerConfiguration conf)
static BookieSocketAddress
BookieImpl. getBookieAddress(ServerConfiguration conf)
Return the configured address of the bookie.static BookieId
BookieImpl. getBookieId(ServerConfiguration conf)
void
InterleavedLedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)
void
LedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)
Initialize the LedgerStorage implementation.void
SortedLedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)
void
InterleavedLedgerStorage. initializeWithEntryLogger(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, EntryLogger entryLogger, StatsLogger statsLogger)
(package private) void
InterleavedLedgerStorage. initializeWithEntryLogListener(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, DefaultEntryLogger.EntryLogListener entryLogListener, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)
static LedgerStorage
BookieImpl. mountLedgerStorageOffline(ServerConfiguration conf, LedgerStorage ledgerStorage)
Initialize LedgerStorage instance without checkpointing for use within the shell and other RO users.static BookieImpl
BookieImpl. 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 Journal
Journal. newJournal(int journalIndex, java.io.File journalDirectory, ServerConfiguration conf, LedgerDirsManager ledgerDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator, JournalAliveListener journalAliveListener)
static LegacyCookieValidation
LegacyCookieValidation. newLegacyCookieValidation(ServerConfiguration conf, RegistrationManager registrationManager)
BookieFileChannel
DefaultFileChannelProvider. open(java.io.File file, ServerConfiguration configuration)
BookieFileChannel
FileChannelProvider. 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 void
FileSystemUpgrade. rollback(ServerConfiguration conf)
static void
FileSystemUpgrade. upgrade(ServerConfiguration conf)
void
Cookie. 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 boolean
DbLedgerStorage. getBooleanVariableOrDefault(ServerConfiguration conf, java.lang.String keyName, boolean defaultValue)
(package private) static long
DbLedgerStorage. getLongVariableOrDefault(ServerConfiguration conf, java.lang.String keyName, long defaultValue)
void
DbLedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)
void
SingleDirectoryDbLedgerStorage. initialize(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, StatsLogger statsLogger, io.netty.buffer.ByteBufAllocator allocator)
KeyValueStorage
KeyValueStorageFactory. newKeyValueStorage(java.lang.String defaultBasePath, java.lang.String subPath, KeyValueStorageFactory.DbConfigType dbConfigType, ServerConfiguration conf)
protected SingleDirectoryDbLedgerStorage
DbLedgerStorage. newSingleDirectoryDbLedgerStorage(ServerConfiguration conf, LedgerManager ledgerManager, LedgerDirsManager ledgerDirsManager, LedgerDirsManager indexDirsManager, EntryLogger entryLogger, StatsLogger statsLogger, long writeCacheSize, long readCacheSize, int readAheadCacheBatchSize, long readAheadCacheBatchBytesSize)
static void
DbLedgerStorage. 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 boolean
BookKeeperAdmin. format(ServerConfiguration conf, boolean isInteractive, boolean force)
Format the BookKeeper metadata in zookeeper.static boolean
BookKeeperAdmin. 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 boolean
BookKeeperAdmin. initNewCluster(ServerConfiguration conf)
Initializes new cluster by creating required znodes for the cluster.static boolean
BookKeeperAdmin. 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 ServerConfiguration
ServerConfiguration. getThis()
ServerConfiguration
ServerConfiguration. setAdvertisedAddress(java.lang.String advertisedAddress)
Configure the bookie to advertise a specific address.ServerConfiguration
ServerConfiguration. setAllowEphemeralPorts(boolean allow)
Configure the bookie to allow using an ephemeral port.ServerConfiguration
ServerConfiguration. setAllowLoopback(boolean allow)
Configure the bookie to allow loopback interfaces to be used as the primary bookie interface.ServerConfiguration
ServerConfiguration. setAllowMultipleDirsUnderSameDiskPartition(boolean allow)
Configure the Bookie to allow/disallow multiple ledger/index/journal directories in the same filesystem diskpartition.ServerConfiguration
ServerConfiguration. 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.ServerConfiguration
ServerConfiguration. setAuditorLedgerVerificationPercentage(long auditorLedgerVerificationPercentage)
Set what percentage of a ledger (fragment)'s entries will be verified.ServerConfiguration
ServerConfiguration. setAuthorizedRoles(java.lang.String roles)
Set authorized roles.ServerConfiguration
ServerConfiguration. setAutoRecoveryDaemonEnabled(boolean enabled)
Sets that whether the auto-recovery service can start along with Bookie server itself or not.ServerConfiguration
ServerConfiguration. setBookieId(java.lang.String bookieId)
Configure the bookie to advertise a specific BookieId.ServerConfiguration
ServerConfiguration. setBookiePort(int port)
Set new bookie port that bookie server listen on.ServerConfiguration
ServerConfiguration. setCloseChannelOnResponseTimeout(boolean value)
Configures action in case if server timed out sending response to the client.ServerConfiguration
ServerConfiguration. setCompactionMaxOutstandingRequests(int maxOutstandingRequests)
Set the maximum number of entries which can be compacted without flushing.ServerConfiguration
ServerConfiguration. setCompactionRate(int rate)
Set the rate of compaction adds.ServerConfiguration
ServerConfiguration. setCompactionRateByBytes(int rate)
Set the rate of compaction adds.ServerConfiguration
ServerConfiguration. setCompactionRateByEntries(int rate)
Set the rate of compaction adds.ServerConfiguration
ServerConfiguration. setDataIntegrityCheckingEnabled(boolean enabled)
Enabled data integrity checker.ServerConfiguration
ServerConfiguration. 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.ServerConfiguration
ServerConfiguration. setDefaultRocksDBConf(java.lang.String defaultRocksdbConf)
Set default rocksdb conf.ServerConfiguration
ServerConfiguration. 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.ServerConfiguration
ServerConfiguration. setDiskCheckInterval(int interval)
Set the disk checker interval to monitor ledger disk space.ServerConfiguration
ServerConfiguration. setDiskLowWaterMarkUsageThreshold(float threshold)
Set the disk free space low water mark threshold.ServerConfiguration
ServerConfiguration. 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.ServerConfiguration
ServerConfiguration. setDiskUsageWarnThreshold(float threshold)
Set the warning threshold for disk usage.ServerConfiguration
ServerConfiguration. setEnableLocalTransport(boolean enableLocalTransport)
Configure the bookie to listen for BookKeeper clients executed on the local JVM.ServerConfiguration
ServerConfiguration. setEnableTaskExecutionStats(boolean enabled)
Enable/Disable recording task execution stats.ServerConfiguration
ServerConfiguration. setEntryLocationRocksdbConf(java.lang.String entryLocationRocksdbConf)
Set entry Location rocksdb conf.ServerConfiguration
ServerConfiguration. setEntryLogFilePreAllocationEnabled(boolean enabled)
Enable/disable entry log file preallocation.ServerConfiguration
ServerConfiguration. setEntrylogMapAccessExpiryTimeInSeconds(int entrylogMapAccessExpiryTimeInSeconds)
ServerConfiguration
ServerConfiguration. setEntryLogPerLedgerCounterLimitsMultFactor(int entryLogPerLedgerCounterLimitsMultFactor)
ServerConfiguration
ServerConfiguration. setEntryLogPerLedgerEnabled(boolean entryLogPerLedgerEnabled)
ServerConfiguration
ServerConfiguration. setEntryLogSizeLimit(long logSizeLimit)
Set entry logger size limitation.ServerConfiguration
ServerConfiguration. setExtraServerComponents(java.lang.String[] componentClasses)
Set the extra list of server lifecycle components to enable on a bookie server.ServerConfiguration
ServerConfiguration. setFileInfoCacheInitialCapacity(int initialCapacity)
Set the minimum total size for the internal file info cache tables for initialization.ServerConfiguration
ServerConfiguration. setFileInfoFormatVersionToWrite(int version)
Set fileinfo format version to write.ServerConfiguration
ServerConfiguration. setFileInfoMaxIdleTime(long idleTime)
Set the max idle time allowed for a open file info existed in file info cache.ServerConfiguration
ServerConfiguration. setFlushInterval(int flushInterval)
Set flush interval.ServerConfiguration
ServerConfiguration. setFlushIntervalInBytes(long flushInterval)
Set entry log flush interval in bytes.ServerConfiguration
ServerConfiguration. setForceAllowCompaction(boolean enable)
Allow manually force compact the entry log or not.ServerConfiguration
ServerConfiguration. setForceReadOnlyBookie(boolean enabled)
Sets that whether force start a bookie in readonly mode.ServerConfiguration
ServerConfiguration. setGcEntryLogMetadataCacheEnabled(boolean gcEntryLogMetadataCacheEnabled)
Set whether the bookie is configured to use persistent entrylogMetadataMap.ServerConfiguration
ServerConfiguration. setGcEntryLogMetadataCachePath(java.lang.String gcEntrylogMetadataCachePath)
Set directory to persist Entrylog metadata if gcPersistentEntrylogMetadataMapEnabled is true.ServerConfiguration
ServerConfiguration. setGcOverreplicatedLedgerMaxConcurrentRequests(int gcOverreplicatedLedgerMaxConcurrentRequests)
Max number of concurrent requests in garbage collection of overreplicated ledgers.ServerConfiguration
ServerConfiguration. setGcOverreplicatedLedgerWaitTime(long gcWaitTime, java.util.concurrent.TimeUnit unit)
Set wait time for garbage collection of overreplicated ledgers.ServerConfiguration
ServerConfiguration. setGcWaitTime(long gcWaitTime)
Set garbage collection wait time.ServerConfiguration
ServerConfiguration. setHttpServerEnabled(boolean enabled)
Set whether to start the http server or not.ServerConfiguration
ServerConfiguration. setHttpServerHost(java.lang.String host)
Set Http server host listening on.ServerConfiguration
ServerConfiguration. setHttpServerKeyStorePassword(java.lang.String keyStorePassword)
Set Http server keyStore password.ServerConfiguration
ServerConfiguration. setHttpServerKeystorePath(java.lang.String keystorePath)
Set Http server keystore path.ServerConfiguration
ServerConfiguration. setHttpServerPort(int port)
Set Http server port listening on.ServerConfiguration
ServerConfiguration. setHttpServerTlsEnable(boolean tlsEnable)
Set if Http Server Tls enable.ServerConfiguration
ServerConfiguration. setHttpServerTrustStorePasswordPassword(java.lang.String trustStorePassword)
Set Http server trustStore password.ServerConfiguration
ServerConfiguration. setHttpServerTrustStorePath(java.lang.String trustStorePath)
Set Http server trustStore path.ServerConfiguration
ServerConfiguration. setIgnoreExtraServerComponentsStartupFailures(boolean enabled)
Set the flag whether to ignore startup failures on loading server components specified atgetExtraServerComponents()
.ServerConfiguration
ServerConfiguration. setIndexDirName(java.lang.String[] indexDirs)
Set dir name to store index files.ServerConfiguration
ServerConfiguration. setIsForceGCAllowWhenNoSpace(boolean force)
Set whether force GC is allowed when disk full or almost full.ServerConfiguration
ServerConfiguration. setIsThrottleByBytes(boolean byBytes)
Set whether use bytes to throttle garbage collector compaction or not.ServerConfiguration
ServerConfiguration. setJournalAdaptiveGroupWrites(boolean enabled)
Enable/disable group journal force writes.ServerConfiguration
ServerConfiguration. setJournalAlignmentSize(int size)
Set journal alignment size.ServerConfiguration
ServerConfiguration. setJournalBufferedEntriesThreshold(int maxEntries)
Set maximum entries to buffer to impose on a journal write to achieve grouping.ServerConfiguration
ServerConfiguration. setJournalBufferedWritesThreshold(long maxBytes)
Set maximum bytes to buffer to impose on a journal write to achieve grouping.ServerConfiguration
ServerConfiguration. setJournalChannelProvider(java.lang.String journalChannelProvider)
Set JournalChannelProvider classname.ServerConfiguration
ServerConfiguration. setJournalDirName(java.lang.String journalDir)
Set dir name to store journal files.ServerConfiguration
ServerConfiguration. setJournalDirsName(java.lang.String[] journalDirs)
Set dir names to store journal files.ServerConfiguration
ServerConfiguration. setJournalFlushWhenQueueEmpty(boolean enabled)
Set if we should flush the journal when queue is empty.ServerConfiguration
ServerConfiguration. setJournalFormatVersionToWrite(int version)
Set journal format version to write.ServerConfiguration
ServerConfiguration. setJournalMaxGroupWaitMSec(long journalMaxGroupWaitMSec)
Sets the maximum latency to impose on a journal write to achieve grouping.ServerConfiguration
ServerConfiguration. setJournalMaxMemorySizeMb(long journalMaxMemorySizeMb)
Set the max amount of memory that can be used by the journal.ServerConfiguration
ServerConfiguration. setJournalPageCacheFlushIntervalMSec(long journalPageCacheFlushIntervalMSec)
Set PageCache flush interval in second.ServerConfiguration
ServerConfiguration. setJournalQueueSize(int journalQueueSize)
Set the size of the journal queue.ServerConfiguration
ServerConfiguration. setJournalRemovePagesFromCache(boolean enabled)
Sets that whether should we remove pages from page cache after force write.ServerConfiguration
ServerConfiguration. setJournalReuseFiles(boolean journalReuseFiles)
Set reuse journal files.ServerConfiguration
ServerConfiguration. setJournalSyncData(boolean syncData)
Enable or disable journal syncs.ServerConfiguration
ServerConfiguration. setJournalWriteBufferSizeKB(int bufferSizeKB)
Set the size of the write buffers used for the journal.ServerConfiguration
ServerConfiguration. setJournalWriteData(boolean journalWriteData)
Should the data be written to journal before acknowledgment.ServerConfiguration
ServerConfiguration. setLedgerDirNames(java.lang.String[] ledgerDirs)
Set dir names to store ledger data.ServerConfiguration
ServerConfiguration. setLedgerMetadataRocksdbConf(java.lang.String ledgerMetadataRocksdbConf)
Set ledger metadata rocksdb conf.ServerConfiguration
ServerConfiguration. setLedgerStorageClass(java.lang.String ledgerStorageClass)
Set theLedgerStorage
implementation class name.ServerConfiguration
ServerConfiguration. setListeningInterface(java.lang.String iface)
Set the network interface that the bookie should listen on.ServerConfiguration
ServerConfiguration. setMajorCompactionInterval(long interval)
Set interval to run major compaction.ServerConfiguration
ServerConfiguration. setMajorCompactionMaxTimeMillis(long majorCompactionMaxTimeMillis)
Set the maximum milliseconds to run major compaction.ServerConfiguration
ServerConfiguration. setMajorCompactionThreshold(double threshold)
Set threshold of major compaction.ServerConfiguration
ServerConfiguration. setMaxAddsInProgressLimit(int value)
Set max number of adds in progress.ServerConfiguration
ServerConfiguration. setMaxBackupJournals(int maxBackupJournals)
Set max number of older journal files to kept.ServerConfiguration
ServerConfiguration. setMaxBatchReadSize(long maxBatchReadSize)
Set the max batch read size.ServerConfiguration
ServerConfiguration. setMaximumNumberOfActiveEntryLogs(int maximumNumberOfActiveEntryLogs)
ServerConfiguration
ServerConfiguration. setMaxJournalSizeMB(long maxJournalSize)
Set new max journal file size.ServerConfiguration
ServerConfiguration. setMaxPendingAddRequestPerThread(int maxPendingAddRequestsPerThread)
Set the max number of pending add requests for each add worker thread.ServerConfiguration
ServerConfiguration. setMaxPendingReadRequestPerThread(int maxPendingReadRequestsPerThread)
Set the max number of pending read requests for each read worker thread.ServerConfiguration
ServerConfiguration. setMaxReadsInProgressLimit(int value)
Set max number of reads in progress.ServerConfiguration
ServerConfiguration. setMinorCompactionInterval(long interval)
Set interval to run minor compaction.ServerConfiguration
ServerConfiguration. setMinorCompactionMaxTimeMillis(long minorCompactionMaxTimeMillis)
Set the maximum milliseconds to run minor compaction.ServerConfiguration
ServerConfiguration. setMinorCompactionThreshold(double threshold)
Set threshold of minor compaction.ServerConfiguration
ServerConfiguration. setMinUsableSizeForEntryLogCreation(long minUsableSizeForEntryLogCreation)
Sets the minimum safe usable size to be available in ledger directory for Bookie to create entry log files.ServerConfiguration
ServerConfiguration. setMinUsableSizeForHighPriorityWrites(long minUsableSizeForHighPriorityWrites)
Sets the minimum safe usable size to be available in ledger directory for Bookie to accept high priority writes.ServerConfiguration
ServerConfiguration. 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).ServerConfiguration
ServerConfiguration. setNettyMaxFrameSizeBytes(int maxSize)
Set the max number of bytes a single message can be that is read by the bookie.ServerConfiguration
ServerConfiguration. setNumAddWorkerThreads(int numThreads)
Set the number of threads that would handle write requests.ServerConfiguration
ServerConfiguration. setNumHighPriorityWorkerThreads(int numThreads)
Set the number of threads that should be used for high priority requests (i.e.ServerConfiguration
ServerConfiguration. setNumJournalCallbackThreads(int numThreads)
Deprecated.ServerConfiguration
ServerConfiguration. setNumLongPollWorkerThreads(int numThreads)
Set the number of threads that should handle long poll requests.ServerConfiguration
ServerConfiguration. setNumOfMemtableFlushThreads(int numOfMemtableFlushThreads)
ServerConfiguration
ServerConfiguration. setNumReadWorkerThreads(int numThreads)
Set the number of threads that would handle read requests.ServerConfiguration
ServerConfiguration. setOpenFileLimit(int fileLimit)
Set limitation of number of open files.ServerConfiguration
ServerConfiguration. setOperationMaxNumbersInSingleRocksDBWriteBatch(int maxNumbersInSingleRocksDBBatch)
Set the max operation numbers in a single rocksdb write batch.ServerConfiguration
ServerConfiguration. setPageLimit(int pageLimit)
Set limitation number of index pages in ledger cache.ServerConfiguration
ServerConfiguration. setPageSize(int pageSize)
Set page size.ServerConfiguration
ServerConfiguration. setPersistBookieStatusEnabled(boolean enabled)
Whether to persist the bookie status so that when bookie server restarts, it will continue using the previous status.ServerConfiguration
ServerConfiguration. setReadBufferBytes(int readBufferSize)
Set the number of bytes we should use as capacity for org.apache.bookkeeper.bookie.BufferedReadChannel.ServerConfiguration
ServerConfiguration. setReadOnlyModeEnabled(boolean enabled)
Set whether the bookie is able to go into read-only mode.ServerConfiguration
ServerConfiguration. setReadOnlyModeOnAnyDiskFullEnabled(boolean enabled)
Set whether the bookie is able to go into read-only mode when any disk is full.ServerConfiguration
ServerConfiguration. setReadWorkerThreadsThrottlingEnabled(boolean throttle)
Use auto-throttling of the read-worker threads.ServerConfiguration
ServerConfiguration. setRequestTimerNumTicks(int tickCount)
Set the number of ticks per wheel for the request timer.ServerConfiguration
ServerConfiguration. setRequestTimerTickDurationMs(int tickDuration)
Set the tick duration in milliseconds.ServerConfiguration
ServerConfiguration. setSanityCheckMetricsEnabled(boolean sanityCheckMetricsEnabled)
Enable sanity check metrics in bookie stats.ServerConfiguration
ServerConfiguration. setServerNumIOThreads(int numThreads)
Set the number of IO threads.ServerConfiguration
ServerConfiguration. setServerSockKeepalive(boolean keepalive)
Set socket keepalive setting.ServerConfiguration
ServerConfiguration. setServerSockLinger(int linger)
Set socket linger timeout on close.ServerConfiguration
ServerConfiguration. setServerTcpNoDelay(boolean noDelay)
Set socket nodelay setting.ServerConfiguration
ServerConfiguration. setServerWriteBufferHighWaterMark(int waterMark)
Set server netty channel write buffer high water mark.ServerConfiguration
ServerConfiguration. setServerWriteBufferLowWaterMark(int waterMark)
Set server netty channel write buffer low water mark.ServerConfiguration
ServerConfiguration. setSkipListArenaChunkSize(int size)
Set the number of bytes we used as chunk allocation for org.apache.bookkeeper.bookie.SkipListArena.ServerConfiguration
ServerConfiguration. setSkipListArenaMaxAllocSize(int size)
Set the max size we should allocate from the skiplist arena.ServerConfiguration
ServerConfiguration. setSkipListSizeLimit(int size)
Set skip list size limit.ServerConfiguration
ServerConfiguration. setSkipReplayJournalInvalidRecord(boolean skipReplayJournalInvalidRecord)
When this config is set to true,if we replay journal failed, we will skip.ServerConfiguration
ServerConfiguration. setSortedLedgerStorageEnabled(boolean enabled)
Deprecated.UsesetLedgerStorageClass(String)
to configure the implementation classServerConfiguration
ServerConfiguration. setStatisticsEnabled(boolean enabled)
Turn on/off statistics.ServerConfiguration
ServerConfiguration. setStatsProviderClass(java.lang.Class<? extends StatsProvider> providerClass)
Set the stats provider used by bookie.ServerConfiguration
ServerConfiguration. setTLSCertificatePath(java.lang.String arg)
Set the path to file containing TLS Certificate.ServerConfiguration
ServerConfiguration. setTLSKeyStore(java.lang.String arg)
Set the keystore path for the client.ServerConfiguration
ServerConfiguration. setTLSKeyStorePasswordPath(java.lang.String arg)
Set the path to file containing keystore password, if the client keystore is password protected.ServerConfiguration
ServerConfiguration. setTLSKeyStoreType(java.lang.String arg)
Set the keystore type for client.ServerConfiguration
ServerConfiguration. setTLSTrustStore(java.lang.String arg)
Set the truststore path for the client.ServerConfiguration
ServerConfiguration. setTLSTrustStorePasswordPath(java.lang.String arg)
Set the path to file containing truststore password, if the client truststore is password protected.ServerConfiguration
ServerConfiguration. setTLSTrustStoreType(java.lang.String arg)
Set the truststore type for client.ServerConfiguration
ServerConfiguration. setUseHostNameAsBookieID(boolean useHostName)
Configure the bookie to use its hostname to register with the co-ordination service(eg: zookeeper) and in ledger metadata.ServerConfiguration
ServerConfiguration. 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.ServerConfiguration
ServerConfiguration. setUseTargetEntryLogSizeForGc(boolean useTargetEntryLogSizeForGc)
ServerConfiguration
ServerConfiguration. setUseTransactionalCompaction(boolean useTransactionalCompaction)
Set whether to use transactional compaction and using a separate log for compaction or not.ServerConfiguration
ServerConfiguration. setVerifyMetadataOnGc(boolean verifyMetadataOnGC)
Set whether the bookie is configured to double check prior to gc.ServerConfiguration
ServerConfiguration. setWaitTimeoutOnResponseBackpressureMillis(long value)
Timeout controlling wait on response send in case of unresponsive client (i.e.ServerConfiguration
ServerConfiguration. setWriteBufferBytes(int writeBufferBytes)
Set the number of bytes used as capacity for the write buffer.ServerConfiguration
ServerConfiguration. setZkRetryBackoffMaxMs(int retryMs)
Set zookeeper client backoff retry max time in millis.ServerConfiguration
ServerConfiguration. 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 MetadataBookieDriver
MetadataBookieDriver. initialize(ServerConfiguration conf, StatsLogger statsLogger)
Initialize the metadata driver.MetadataBookieDriver
NullMetadataBookieDriver. initialize(ServerConfiguration conf, StatsLogger statsLogger)
static <T> T
MetadataDrivers. 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> T
MetadataDrivers. 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> T
MetadataDrivers. 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) ServerConfiguration
ZKMetadataBookieDriver. serverConf
Methods in org.apache.bookkeeper.meta.zk with parameters of type ServerConfiguration Modifier and Type Method Description MetadataBookieDriver
ZKMetadataBookieDriver. initialize(ServerConfiguration conf, StatsLogger statsLogger)
(package private) ZKRegistrationManager
ZKMetadataBookieDriver. 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) ServerConfiguration
BookieNettyServer. conf
(package private) ServerConfiguration
BookieServer. conf
Methods in org.apache.bookkeeper.proto that return ServerConfiguration Modifier and Type Method Description (package private) ServerConfiguration
BookieRequestProcessor. getServerCfg()
The server configuration.Methods in org.apache.bookkeeper.proto with parameters of type ServerConfiguration Modifier and Type Method Description static BookieServer
BookieServer. 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 ServerConfiguration
AuditorTask. conf
Methods in org.apache.bookkeeper.replication with parameters of type ServerConfiguration Modifier and Type Method Description (package private) static BookKeeper
Auditor. createBookKeeperClient(ServerConfiguration conf)
(package private) static BookKeeper
Auditor. createBookKeeperClient(ServerConfiguration conf, StatsLogger statsLogger)
(package private) static BookKeeper
Auditor. createBookKeeperClientThrowUnavailableException(ServerConfiguration conf)
(package private) BookKeeper
AuditorTask. 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 void
SASLBookieAuthProviderFactory. 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 ServerConfiguration
BookieConfiguration. 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) ServerConfiguration
BKHttpServiceProvider.Builder. serverConf
Methods in org.apache.bookkeeper.server.http with parameters of type ServerConfiguration Modifier and Type Method Description BKHttpServiceProvider.Builder
BKHttpServiceProvider.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 ServerConfiguration
AutoRecoveryStatusService. conf
protected ServerConfiguration
ConfigurationService. conf
protected ServerConfiguration
DecommissionService. conf
protected ServerConfiguration
DeleteLedgerService. conf
protected ServerConfiguration
ExpandStorageService. conf
protected ServerConfiguration
GCDetailsService. conf
protected ServerConfiguration
GetLastLogMarkService. conf
protected ServerConfiguration
GetLedgerMetaService. conf
protected ServerConfiguration
ListBookieInfoService. conf
protected ServerConfiguration
ListBookiesService. conf
protected ServerConfiguration
ListDiskFilesService. conf
protected ServerConfiguration
ListLedgerService. conf
protected ServerConfiguration
ListUnderReplicatedLedgerService. conf
protected ServerConfiguration
LostBookieRecoveryDelayService. conf
protected ServerConfiguration
ReadLedgerEntryService. conf
protected ServerConfiguration
RecoveryBookieService. conf
protected ServerConfiguration
TriggerAuditService. conf
protected ServerConfiguration
TriggerGCService. conf
protected ServerConfiguration
WhoIsAuditorService. 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 void
BookieAuthZFactory. 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 boolean
ListUnderReplicatedCommand. apply(ServerConfiguration conf, ListUnderReplicatedCommand.LURFlags cmdFlags)
boolean
LostBookieRecoveryDelayCommand. apply(ServerConfiguration conf, LostBookieRecoveryDelayCommand.LBRDFlags cmdFlags)
boolean
QueryAutoRecoveryStatusCommand. apply(ServerConfiguration conf, QueryAutoRecoveryStatusCommand.QFlags cmdFlags)
boolean
ToggleCommand. apply(ServerConfiguration conf, ToggleCommand.AutoRecoveryFlags cmdFlags)
boolean
TriggerAuditCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)
boolean
WhoIsAuditorCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)
boolean
ListUnderReplicatedCommand. handler(ServerConfiguration bkConf, ListUnderReplicatedCommand.LURFlags flags)
boolean
LostBookieRecoveryDelayCommand. handler(ServerConfiguration conf, LostBookieRecoveryDelayCommand.LBRDFlags flags)
boolean
QueryAutoRecoveryStatusCommand. handler(ServerConfiguration conf, QueryAutoRecoveryStatusCommand.QFlags flag)
boolean
TriggerAuditCommand. 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 boolean
ClusterInfoCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)
boolean
DecommissionCommand. apply(ServerConfiguration conf, DecommissionCommand.DecommissionFlags cmdFlags)
boolean
EndpointInfoCommand. apply(ServerConfiguration conf, EndpointInfoCommand.EndpointInfoFlags cmdFlags)
boolean
InfoCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)
boolean
InitCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)
boolean
InstanceIdCommand. apply(ServerConfiguration conf, CliFlags cmdFlags)
boolean
MetaFormatCommand. apply(ServerConfiguration conf, MetaFormatCommand.MetaFormatFlags flags)
boolean
NukeExistingClusterCommand. apply(ServerConfiguration conf, NukeExistingClusterCommand.NukeExistingClusterFlags cmdFlags)
boolean
RecoverCommand. 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 boolean
DeleteLedgerCommand. apply(ServerConfiguration conf, DeleteLedgerCommand.DeleteLedgerFlags cmdFlags)
boolean
LedgerMetaDataCommand. 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 boolean
AdminCommand. 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 boolean
SwitchOfHealthCheckCommand. 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 boolean
BookieCommand. apply(ServerConfiguration conf, BookieFlagsT cmdFlags)
boolean
ClientCommand. 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 LocalBookKeeper
LocalBookKeeper. getLocalBookies(java.lang.String zkHost, int zkPort, int numBookies, boolean shouldStartZK, ServerConfiguration conf)
static io.netty.channel.EventLoopGroup
EventLoopUtil. getServerAcceptorGroup(ServerConfiguration conf, java.util.concurrent.ThreadFactory threadFactory)
static io.netty.channel.EventLoopGroup
EventLoopUtil. 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)
-