A B C D E F G H I J K L M N O P Q R S T U V W X Z 
All Classes All Packages

A

abort() - Method in interface org.apache.bookkeeper.bookie.storage.CompactionEntryLog
Abort the compaction log.
abort() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
abort() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.CompactionPhase
 
abort() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.FlushCompactionLogPhase
 
abort() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.ScanEntryLogPhase
 
abort() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.UpdateIndexPhase
 
AbstractBuilder() - Constructor for class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
AbstractComponent<ConfT extends ComponentConfiguration> - Class in org.apache.bookkeeper.common.component
The base class represents a component.
AbstractComponent(String, ConfT) - Constructor for class org.apache.bookkeeper.common.component.AbstractComponent
 
AbstractConfiguration<T extends AbstractConfiguration> - Class in org.apache.bookkeeper.conf
Abstract configuration.
AbstractConfiguration() - Constructor for class org.apache.bookkeeper.conf.AbstractConfiguration
 
AbstractDNSToSwitchMapping - Class in org.apache.bookkeeper.net
This is a base class for DNS to Switch mappings.
AbstractDNSToSwitchMapping() - Constructor for class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
Create an unconfigured instance.
AbstractDNSToSwitchMapping(Configuration) - Constructor for class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
Create an instance, caching the configuration file.
AbstractHashProvider<P extends HashParameters> - Class in com.scurrilous.circe.impl
Base implementation for hash function providers.
AbstractHashProvider(Class<P>) - Constructor for class com.scurrilous.circe.impl.AbstractHashProvider
Constructs a new AbstractHashProvider with the given base parameters class.
AbstractHierarchicalLedgerManager - Class in org.apache.bookkeeper.meta
An abstract class for managing hierarchical ledgers.
AbstractHierarchicalLedgerManager(AbstractConfiguration, ZooKeeper) - Constructor for class org.apache.bookkeeper.meta.AbstractHierarchicalLedgerManager
Constructor.
AbstractIncrementalIntHash - Class in com.scurrilous.circe.impl
Base implementation for incremental stateless integer hash functions.
AbstractIncrementalIntHash() - Constructor for class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
AbstractIncrementalLongHash - Class in com.scurrilous.circe.impl
Base implementation for incremental stateless long integer hash functions.
AbstractIncrementalLongHash() - Constructor for class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
AbstractIntCrc - Class in com.scurrilous.circe.crc
Base implementation of int-width CRC functions.
AbstractIntCrc(String, int, int, int) - Constructor for class com.scurrilous.circe.crc.AbstractIntCrc
 
AbstractLifecycleComponent<ConfT extends ComponentConfiguration> - Class in org.apache.bookkeeper.common.component
AbstractLifecycleComponent(String, ConfT, StatsLogger) - Constructor for class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
AbstractLogCompactor - Class in org.apache.bookkeeper.bookie
Abstract entry log compactor used for compaction.
AbstractLogCompactor(ServerConfiguration, AbstractLogCompactor.LogRemovalListener) - Constructor for class org.apache.bookkeeper.bookie.AbstractLogCompactor
 
AbstractLogCompactor.LogRemovalListener - Interface in org.apache.bookkeeper.bookie
LogRemovalListener.
AbstractLogCompactor.Throttler - Class in org.apache.bookkeeper.bookie
class Throttler.
AbstractLongCrc - Class in com.scurrilous.circe.crc
Base implementation of long-width CRC functions.
AbstractLongCrc(String, int, long, long) - Constructor for class com.scurrilous.circe.crc.AbstractLongCrc
 
AbstractSlogger - Class in org.apache.bookkeeper.slogger
Abstract implementation of slogger.
AbstractSlogger(Iterable<Object>) - Constructor for class org.apache.bookkeeper.slogger.AbstractSlogger
 
AbstractSlogger.CtxIterator - Class in org.apache.bookkeeper.slogger
 
AbstractSlogger.Level - Enum in org.apache.bookkeeper.slogger
Levels at which slogger can slog.
AbstractStatefulHash - Class in com.scurrilous.circe.impl
Base implementation for stateful hash functions.
AbstractStatefulHash() - Constructor for class com.scurrilous.circe.impl.AbstractStatefulHash
 
AbstractStatelessIntHash - Class in com.scurrilous.circe.impl
Base implementation for stateless (but not incremental) integer hash functions.
AbstractStatelessIntHash() - Constructor for class com.scurrilous.circe.impl.AbstractStatelessIntHash
 
AbstractStatelessLongHash - Class in com.scurrilous.circe.impl
Base implementation for stateless (but not incremental) long integer hash functions.
AbstractStatelessLongHash() - Constructor for class com.scurrilous.circe.impl.AbstractStatelessLongHash
 
AbstractZkLedgerManager - Class in org.apache.bookkeeper.meta
Abstract ledger manager based on zookeeper, which provides common methods such as query zk nodes.
AbstractZkLedgerManager(AbstractConfiguration, ZooKeeper) - Constructor for class org.apache.bookkeeper.meta.AbstractZkLedgerManager
ZooKeeper-based Ledger Manager Constructor.
AbstractZkLedgerManager.CancelWatchLedgerMetadataTask - Class in org.apache.bookkeeper.meta
CancelWatchLedgerMetadataTask class.
AbstractZkLedgerManager.ReadLedgerMetadataTask - Class in org.apache.bookkeeper.meta
ReadLedgerMetadataTask class.
AbstractZkLedgerManagerFactory - Class in org.apache.bookkeeper.meta
Abstract ledger manager factory based on zookeeper, which provides common methods such as format and validateAndNukeExistingCluster.
AbstractZkLedgerManagerFactory() - Constructor for class org.apache.bookkeeper.meta.AbstractZkLedgerManagerFactory
 
accept(long) - Method in interface org.apache.bookkeeper.bookie.Journal.JournalIdFilter
 
accept(long) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogScanner
Tests whether or not the entries belongs to the specified ledger should be processed.
accept(long) - Method in interface org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.ConsumerLong
 
accept(long, long) - Method in interface org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.BiConsumerLong
 
accept(long, long, long, long) - Method in interface org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.BiConsumerLongPair
 
accept(long, long, ByteBuf) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.WriteCache.EntryConsumer
 
accept(long, V) - Method in interface org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.EntryProcessor
 
accept(Integer) - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.WriteCallback
 
accept(Versioned<Set<BookieId>>, Throwable) - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
accept(T, Throwable) - Method in interface org.apache.bookkeeper.common.concurrent.FutureEventListener
 
acceptorGroup - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
acceptServiceUri(ServiceURI) - Method in class org.apache.bookkeeper.tools.common.BKCommand
 
acceptsMemoryAddress(T) - Method in interface org.apache.bookkeeper.util.ByteBufVisitor.ByteBufVisitorCallback
 
acceptsMemoryAddressBuffer() - Static method in class com.scurrilous.circe.checksum.Crc32cIntChecksum
 
acceptsMemoryAddressBuffer() - Method in interface com.scurrilous.circe.checksum.IntHash
 
acceptsMemoryAddressBuffer() - Method in class com.scurrilous.circe.checksum.Java8IntHash
 
acceptsMemoryAddressBuffer() - Method in class com.scurrilous.circe.checksum.Java9IntHash
 
acceptsMemoryAddressBuffer() - Method in class com.scurrilous.circe.checksum.JniIntHash
 
acceptsMemoryAddressBuffer() - Method in class org.apache.bookkeeper.proto.checksum.CRC32CDigestManager
 
acceptsMemoryAddressBuffer() - Method in class org.apache.bookkeeper.proto.checksum.CRC32DigestManager
 
acceptsMemoryAddressBuffer() - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
acceptsMemoryAddressBuffer() - Method in class org.apache.bookkeeper.proto.checksum.DummyDigestManager
 
acceptsMemoryAddressBuffer() - Method in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
ackBeforeSync - Variable in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
ackQuorumSize - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
ackQuorumSize - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
ackQuorumSize(int) - Method in class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand.Flags
 
ACKQUORUMSIZE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
ackSet - Variable in class org.apache.bookkeeper.client.ForceLedgerOp
 
ackSet - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
ackSet - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
acls - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
acquire() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.BufferPool
 
acquire(int) - Method in class org.apache.bookkeeper.bookie.AbstractLogCompactor.Throttler
 
acquire(int) - Method in class org.apache.bookkeeper.client.LedgerFragmentReplicator.Throttler
 
acquireAddCompletion(PerChannelBookieClient.CompletionKey, BookkeeperInternalCallbacks.WriteCallback, Object, long, long) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
acquireCore() - Static method in class org.apache.bookkeeper.common.util.affinity.CpuAffinity
Acquire ownership of one CPU core for the current thread.
acquireCore() - Static method in class org.apache.bookkeeper.common.util.affinity.impl.CpuAffinityImpl
 
acquirePermit() - Method in class org.apache.bookkeeper.client.LedgerChecker
Acquires a permit from permit manager, blocking until all are available.
acquireUnderreplicatedLedger(long) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
 
acquireUnderreplicatedLedger(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
acquireUnderreplicatedLedger(long) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
acquireUnderreplicatedLedgerLock(ZooKeeper, String, long, List<ACL>) - Static method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
Acquire the underreplicated ledger lock.
acquireV2Key(long, long, BookkeeperProtocol.OperationType) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
ACTIVE_ENTRY_LOG_COUNT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ACTIVE_ENTRY_LOG_SPACE_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ACTIVE_LEDGER_COUNT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ACTIVE_NON_TLS_CHANNEL_COUNTER - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
ACTIVE_TLS_CHANNEL_COUNTER - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
ActiveLedgerFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand.ActiveLedgerFlags
 
activeLedgers - Variable in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
activeLedgers - Variable in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
add(long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
add(ByteBuf) - Method in class org.apache.bookkeeper.util.ByteBufList
Append a ByteBuf at the end of this ByteBufList.
add(Node) - Method in interface org.apache.bookkeeper.net.NetworkTopology
Add a node to the network topology.
add(Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Add a leaf node.
add(Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Add node n to the subtree of this node.
add(Node) - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
add(T) - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
add(V) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
ADD_ENTRY - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
ADD_ENTRY = 2;
ADD_ENTRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ADD_ENTRY_BLOCKED - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ADD_ENTRY_BLOCKED_WAIT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ADD_ENTRY_IN_PROGRESS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ADD_ENTRY_QUORUM_TIMEOUT_SEC - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
ADD_ENTRY_REJECTED - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ADD_ENTRY_REQUEST - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ADD_ENTRY_TIMEOUT_SEC - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
ADD_ENTRY_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
ADD_ENTRY = 2;
ADD_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
ADD_OP_OUTSTANDING - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
ADD_OP_UR - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
addAllAuth(Iterable<String>) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string auth = 5;
addAllCustomMetadata(Iterable<? extends DataFormats.LedgerMetadataFormat.cMetadataMapEntry>) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
addAllEndpoints(Iterable<? extends DataFormats.BookieServiceInfoFormat.Endpoint>) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
addAllEnsembleMember(Iterable<String>) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
repeated string ensembleMember = 1;
addAllExtensions(Iterable<String>) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string extensions = 6;
addAllReplica(Iterable<String>) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
repeated string replica = 1;
addAllRequestContext(Iterable<? extends BookkeeperProtocol.ContextPair>) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
addAllSegment(Iterable<? extends DataFormats.LedgerMetadataFormat.Segment>) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
addAndGet(long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
Atomically add the specified delta to a current value identified by the key.
addAuth(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string auth = 5;
addAuthBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string auth = 5;
addAuthInfo(String, byte[]) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
addBookie() - Method in class org.apache.bookkeeper.util.LocalBookKeeper
 
addBookie(int, int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.QuorumCoverageSet
Add a bookie to the result set.
addBookie(BookieNode) - Method in interface org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.CoverageSet
 
addBookie(BookieNode) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackOrRegionDurabilityCoverageSet
 
addBookie(BookieNode) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackQuorumCoverageSet
 
addChildWatcher(Watcher) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperWatcherBase
 
addCommand(Command) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
addComplete(int, LedgerHandle, long, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.AddCallback
Callback to implement if latency information is not desired.
addComplete(int, LedgerHandle, long, Object) - Method in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
addComplete(int, LedgerHandle, long, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.SyncAddCallback
Implementation of callback interface for synchronous read method.
addCompleteWithLatency(int, LedgerHandle, long, long, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.AddCallback
Callback declaration which additionally passes quorum write complete latency.
addCompleteWithLatency(int, LedgerHandle, long, long, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.AddCallbackWithLatency
Callback declaration which additionally passes quorum write complete latency.
AddCompletion(Recycler.Handle<PerChannelBookieClient.AddCompletion>) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
addComponent(LifecycleComponent) - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack.Builder
 
addCount(long) - Method in interface org.apache.bookkeeper.stats.Counter
Add delta to the value associated with this stat.
addCount(long) - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullCounter
 
addCount(long) - Method in class org.apache.bookkeeper.stats.otel.OtelCounter
 
addCount(long) - Method in class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
 
addCount(long) - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedLongAdderCounter
 
addCustomMetadata(int, DataFormats.LedgerMetadataFormat.cMetadataMapEntry) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
addCustomMetadata(int, DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
addCustomMetadata(DataFormats.LedgerMetadataFormat.cMetadataMapEntry) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
addCustomMetadata(DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
addCustomMetadataBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
addCustomMetadataBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
addDefaultFaultDomainBookies(Set<BookieId>) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
addDefaultRackBookiesIfMinNumRacksIsEnforced(Set<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
addDelay - Variable in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
addEndpoints(int, DataFormats.BookieServiceInfoFormat.Endpoint) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
addEndpoints(int, DataFormats.BookieServiceInfoFormat.Endpoint.Builder) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
addEndpoints(DataFormats.BookieServiceInfoFormat.Endpoint) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
addEndpoints(DataFormats.BookieServiceInfoFormat.Endpoint.Builder) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
addEndpointsBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
addEndpointsBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
addEnsembleMember(String) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
repeated string ensembleMember = 1;
addEnsembleMemberBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
repeated string ensembleMember = 1;
addEntry(byte[]) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry synchronously to an open ledger.
addEntry(byte[]) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
addEntry(byte[], int, int) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry synchronously to an open ledger.
addEntry(byte[], int, int) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
addEntry(long, byte[]) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry synchronously to an open ledger.
addEntry(long, byte[]) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
Add entry synchronously to an open ledger.
addEntry(long, byte[], int, int) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry synchronously to an open ledger.
addEntry(long, byte[], int, int) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
Add entry synchronously to an open ledger.
addEntry(long, byte[], long, ReferenceCounted, BookkeeperInternalCallbacks.WriteCallback, Object, int, boolean, EnumSet<WriteFlag>) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
This method should be called only after connection has been checked for PerChannelBookieClient.connectIfNeededAndDoOp(GenericCallback).
addEntry(long, long, ByteBuffer, CacheCallback) - Method in class org.apache.bookkeeper.bookie.EntryMemTable
Write an update.
addEntry(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
addEntry(long, ByteBuf) - Method in interface org.apache.bookkeeper.bookie.storage.CompactionEntryLog
Add an entry to the log.
addEntry(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
addEntry(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.WriterWithMetadata
 
addEntry(long, ByteBuf) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Add an entry for ledger ```ledgerId``` to the entrylog.
addEntry(long, ByteBuf, boolean) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
addEntry(long, ByteBuf, boolean) - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
addEntry(long, ByteBuf, boolean) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
addEntry(long, ByteBuf, boolean) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
addEntry(long, ByteBuf, boolean) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
addEntry(long, ByteBuffer) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
addEntry(long, ByteBuffer) - Method in class org.apache.bookkeeper.bookie.ReadOnlyDefaultEntryLogger
 
addEntry(ByteBuf) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
addEntry(ByteBuf) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
addEntry(ByteBuf) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
addEntry(ByteBuf) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorReadOnlyImpl
 
addEntry(ByteBuf) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Add an entry to the storage.
addEntry(ByteBuf) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
addEntry(ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
addEntry(ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
addEntry(ByteBuf, boolean, BookkeeperInternalCallbacks.WriteCallback, Object, byte[]) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
addEntry(ByteBuf, boolean, BookkeeperInternalCallbacks.WriteCallback, Object, byte[]) - Method in class org.apache.bookkeeper.bookie.BookieImpl
Add entry to a ledger.
addEntry(BookieId, long, byte[], long, ReferenceCounted, BookkeeperInternalCallbacks.WriteCallback, Object, int, boolean, EnumSet<WriteFlag>) - Method in interface org.apache.bookkeeper.proto.BookieClient
Add an entry for ledger ledgerId on the bookie at address address.
addEntry(BookieId, long, byte[], long, ReferenceCounted, BookkeeperInternalCallbacks.WriteCallback, Object, int, boolean, EnumSet<WriteFlag>) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
ADDENTRY - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The Add entry request payload will be a ledger entry exactly as it should be logged.
addEntryBlockedStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
AddEntryQuorumTimeoutException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Add entry operation timeouts on waiting quorum responses.
addEntryQuorumTimeoutNanos - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
addEntrySuccessBookies - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
addEntryTimeoutNanos - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
addExecutorDecorators(ExecutorService) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
addExecutorDecorators(ExecutorService) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
 
addExtensions(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string extensions = 6;
addExtensionsBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string extensions = 6;
addFailed(BookieId) - Method in class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl.SinBin
Returns true if this is the first error for this bookie.
addLacComplete(int, LedgerHandle, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.AddLacCallback
Callback declaration.
addLacComplete(int, LedgerHandle, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.LastAddConfirmedCallback
Implementation of callback interface for synchronous read method.
addLatency(long, TimeUnit) - Method in interface org.apache.bookkeeper.stats.Counter
An operation succeeded with the given eventLatency.
addLatency(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullCounter
 
addLatency(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.otel.OtelCounter
 
addLatency(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
When counter is used to count time.
addLatency(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedLongAdderCounter
 
addLedgerDirsListener(LedgerDirsManager.LedgerDirsListener) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
 
addLedgerSize(long, long) - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
addLedgerToIndex(long, boolean, byte[], LedgerCache.PageEntriesIterable) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
addLedgerToIndex(long, boolean, byte[], LedgerCache.PageEntriesIterable) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
Add an already existing ledger to the index.
addLifecycleListener(LifecycleListener) - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
addLifecycleListener(LifecycleListener) - Method in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
addLifecycleListener(LifecycleListener) - Method in interface org.apache.bookkeeper.common.component.LifecycleComponent
 
addLifecycleListener(LifecycleListener) - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
addListener(DefaultEntryLogger.EntryLogListener) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
addListener(RegistrationClient.RegistrationListener) - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
addLocation(long, long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
addLocation(KeyValueStorage.Batch, long, long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
addMissingIndices(int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
If we want a write set to cover all bookies in an ensemble of size X, then all of the index from 0..X must exist in the write set.
addNode(BookieNode) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.EnsembleForReplacementWithNoConstraints
 
addNode(BookieNode) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
addNode(T) - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy.Ensemble
Append the new bookie node to the ensemble only if the ensemble doesnt already contain the same bookie.
addProperty(String, Object) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
addPropertyDirect(String, Object) - Method in class org.apache.bookkeeper.common.conf.ConcurrentConfiguration
 
addRegistrationListener(RegistrationManager.RegistrationListener) - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Add a listener to be triggered when an registration event occurs.
addRegistrationListener(RegistrationManager.RegistrationListener) - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
addRegistrationListener(RegistrationManager.RegistrationListener) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
addReplica(String) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
repeated string replica = 1;
addReplicaBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
repeated string replica = 1;
ADDREQUEST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
addRequestContext(int, BookkeeperProtocol.ContextPair) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
addRequestContext(int, BookkeeperProtocol.ContextPair.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
addRequestContext(BookkeeperProtocol.ContextPair) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
addRequestContext(BookkeeperProtocol.ContextPair.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
addRequestContextBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
addRequestContextBuilder(int) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
ADDRESPONSE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
address - Variable in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
address2NodePlacement - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
address2Region - Variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
addsBlocked - Variable in class org.apache.bookkeeper.proto.RequestStats
 
addSegment(int, DataFormats.LedgerMetadataFormat.Segment) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
addSegment(int, DataFormats.LedgerMetadataFormat.Segment.Builder) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
addSegment(DataFormats.LedgerMetadataFormat.Segment) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
addSegment(DataFormats.LedgerMetadataFormat.Segment.Builder) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
addSegmentBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
addSegmentBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
addsInProgress - Variable in class org.apache.bookkeeper.proto.RequestStats
 
addsSemaphore - Variable in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
addToFilledDirs(File) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Add the dir to filled dirs list.
addToLength(long) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add to the length of the ledger in bytes.
addToWritableDirs(File, boolean) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Add the dir to writable dirs list.
addWatcher(Watcher<T>) - Method in class org.apache.bookkeeper.common.util.Watchable
Adds an watcher to the set of watchers for this object, provided that it is not the same as some watcher already in the set.
admin - Variable in class org.apache.bookkeeper.replication.AuditorTask
 
AdminCommand - Class in org.apache.bookkeeper.tools.cli.commands.cookie
Command to update cookie.
AdminCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand
 
AdminCommand.AdminFlags - Class in org.apache.bookkeeper.tools.cli.commands.cookie
Flags for admin command.
AdminFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand.AdminFlags
 
administrativeOpen - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
adv - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
advance() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo.EntryIterator
 
Advanced - org.apache.bookkeeper.common.allocator.LeakDetectionPolicy
Instruments 1% of the allocated buffer to track for leaks, reporting stack traces of places where the buffer was used.
ADVERTISED_ADDRESS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
AFTER - org.apache.bookkeeper.versioning.Version.Occurred
 
afterClose() - Method in interface org.apache.bookkeeper.common.component.LifecycleListener
 
afterStart() - Method in interface org.apache.bookkeeper.common.component.LifecycleListener
 
afterStop() - Method in interface org.apache.bookkeeper.common.component.LifecycleListener
 
alertStatName - Variable in class org.apache.bookkeeper.stats.AlertStatsLogger
 
AlertStatsLogger - Class in org.apache.bookkeeper.stats
This class is used to raise alert when we detect an event that should never happen in production.
AlertStatsLogger(StatsLogger, String) - Constructor for class org.apache.bookkeeper.stats.AlertStatsLogger
 
AlertStatsLogger(StatsLogger, String, String) - Constructor for class org.apache.bookkeeper.stats.AlertStatsLogger
 
algorithm() - Method in class com.scurrilous.circe.crc.AbstractIntCrc
 
algorithm() - Method in class com.scurrilous.circe.crc.AbstractLongCrc
 
algorithm() - Method in class com.scurrilous.circe.crc.JavaCrc32
 
algorithm() - Method in class com.scurrilous.circe.crc.Sse42Crc32C
 
algorithm() - Method in interface com.scurrilous.circe.Hash
Returns the canonical name of this hash algorithm.
algorithm() - Method in interface com.scurrilous.circe.HashParameters
Returns the canonical name of the hash algorithm.
algorithm() - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
algorithm() - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
algorithm() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
algorithm() - Method in class com.scurrilous.circe.impl.IntStatelessLongHash
 
algorithm() - Method in class com.scurrilous.circe.params.CrcParameters
 
algorithm() - Method in class com.scurrilous.circe.params.MurmurHash3Parameters
 
algorithm() - Method in enum com.scurrilous.circe.params.MurmurHash3Variant
Returns the algorithm name corresponding to this variant.
algorithm() - Method in class com.scurrilous.circe.params.SimpleHashParameters
 
algorithm() - Method in class com.scurrilous.circe.params.SipHash24Parameters
 
align64(int) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
ALIGNMENT - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
all(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ListBookiesCommand.Flags
 
ALL_FIELDS - Static variable in interface org.apache.bookkeeper.metastore.MetastoreTable
 
ALL_PROVIDERS - Static variable in class com.scurrilous.circe.HashProviders
 
allChannels - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
allChannels - Variable in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
allDisksFull(boolean) - Method in interface org.apache.bookkeeper.bookie.LedgerDirsManager.LedgerDirsListener
This will be notified whenever all disks are detected as full.
allDisksWritable() - Method in interface org.apache.bookkeeper.bookie.LedgerDirsManager.LedgerDirsListener
This will be notified whenever all disks are detected as not full.
alloc() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
allocateBytes(int) - Method in class org.apache.bookkeeper.bookie.SkipListArena
Allocate a slice of the given length.
allocationToRacksOrRegions - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackOrRegionDurabilityCoverageSet
 
allocator - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 
allocator - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
allocator - Variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
allocator - Variable in class org.apache.bookkeeper.client.BookKeeper.Builder
 
allocator - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
allocator - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
allocator(ByteBufAllocator) - Method in interface org.apache.bookkeeper.client.api.BookKeeperBuilder
Configure the bookkeeper client with a provided ByteBufAllocator.
allocator(ByteBufAllocator) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
Configure the bookkeeper client with a provided ByteBufAllocator.
allocator(ByteBufAllocator) - Method in class org.apache.bookkeeper.client.impl.BookKeeperBuilderImpl
 
allocator(ByteBufAllocator) - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
 
ALLOCATOR_EXIT_ON_OUT_OF_MEMORY - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ALLOCATOR_LEAK_DETECTION_POLICY - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ALLOCATOR_OOM_POLICY - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ALLOCATOR_POOLING_CONCURRENCY - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ALLOCATOR_POOLING_POLICY - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
allocatorExecutor - Variable in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
ALLOW_EPHEMERAL_PORTS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ALLOW_LOOPBACK - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ALLOW_MULTIPLEDIRS_UNDER_SAME_DISKPARTITION - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ALLOW_SHADED_LEDGER_MANAGER_FACTORY_CLASS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ALLOW_STORAGE_EXPANSION - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
allowedRoles - Variable in class org.apache.bookkeeper.tls.BookieAuthZFactory
 
allowFailFast - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
allowFailFast - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
allowFailFastOnUnwritableChannel() - Method in class org.apache.bookkeeper.client.PendingAddOp
 
allowFailFastOnUnwritableChannel() - Method in class org.apache.bookkeeper.client.ReadOpBase
 
allowReadOnlyMode - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
allowReadOnlyMode(boolean) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
allowRetry(int) - Method in class org.apache.bookkeeper.zookeeper.ZooWorker
 
allowRetry(int, long) - Method in class org.apache.bookkeeper.zookeeper.ExponentialBackoffRetryPolicy
 
allowRetry(int, long) - Method in class org.apache.bookkeeper.zookeeper.ExponentialBackOffWithDeadlinePolicy
 
allowRetry(int, long) - Method in interface org.apache.bookkeeper.zookeeper.RetryPolicy
Called when retrying an operation failed for some reason.
ANONYMOUS - Static variable in class org.apache.bookkeeper.auth.BookKeeperPrincipal
 
ANY - Static variable in interface org.apache.bookkeeper.versioning.Version
Match any version.
anyDiskFull(boolean) - Method in interface org.apache.bookkeeper.bookie.LedgerDirsManager.LedgerDirsListener
This will be notified whenever any disks are detected as full.
append(byte[]) - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Add an entry synchronously to an open ledger.
append(byte[], int, int) - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Add an entry synchronously to an open ledger.
append(ByteBuf) - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Add entry synchronously to an open ledger.
append(ByteBuffer) - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Add entry synchronously to an open ledger.
appendAsync(byte[]) - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Add an entry asynchronously to an open ledger.
appendAsync(byte[], int, int) - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Add an entry asynchronously to an open ledger.
appendAsync(ByteBuf) - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Add entry asynchronously to an open ledger.
appendAsync(ByteBuf) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry asynchronously to an open ledger.
appendAsync(ByteBuffer) - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Add entry asynchronously to an open ledger.
appendLedgersMap() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.BufferedLogChannel
Append the ledger map at the end of the entry log.
appendRequestContext(BookkeeperProtocol.Request.Builder) - Static method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
apply(long) - Method in interface org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.LongLongFunction
 
apply(long, long) - Method in interface org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.LongLongPairFunction
 
apply(GlobalFlagsT, String[]) - Method in class org.apache.bookkeeper.tools.framework.CliCommand
 
apply(GlobalFlagsT, String[]) - Method in class org.apache.bookkeeper.tools.framework.CliCommandGroup
 
apply(GlobalFlagsT, String[]) - Method in interface org.apache.bookkeeper.tools.framework.Command
Process the command.
apply(GlobalFlagsT, String[]) - Method in class org.apache.bookkeeper.tools.framework.HelpCommand
 
apply(String, CompositeConfiguration, String[]) - Method in class org.apache.bookkeeper.tools.common.BKCommand
Made this as public for allowing old bookie shell use new cli command.
apply(ServiceURI, CompositeConfiguration, BKFlags, BookieFlagsT) - Method in class org.apache.bookkeeper.tools.cli.helpers.BookieCommand
 
apply(ServiceURI, CompositeConfiguration, BKFlags, ClientFlagsT) - Method in class org.apache.bookkeeper.tools.cli.helpers.ClientCommand
 
apply(ServiceURI, CompositeConfiguration, BKFlags, CommandFlagsT) - Method in class org.apache.bookkeeper.tools.common.BKCommand
 
apply(ServiceURI, CompositeConfiguration, BKFlags, CookieFlagsT) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.CookieCommand
 
apply(ClientConfiguration, ClientFlagsT) - Method in class org.apache.bookkeeper.tools.cli.helpers.ClientCommand
 
apply(ClientConfiguration, DiscoveryFlagsT) - Method in class org.apache.bookkeeper.tools.cli.helpers.DiscoveryCommand
 
apply(ServerConfiguration, BookieFlagsT) - Method in class org.apache.bookkeeper.tools.cli.helpers.BookieCommand
 
apply(ServerConfiguration, ClientFlagsT) - Method in class org.apache.bookkeeper.tools.cli.helpers.ClientCommand
 
apply(ServerConfiguration, ListUnderReplicatedCommand.LURFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand
 
apply(ServerConfiguration, LostBookieRecoveryDelayCommand.LBRDFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.LostBookieRecoveryDelayCommand
 
apply(ServerConfiguration, QueryAutoRecoveryStatusCommand.QFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.QueryAutoRecoveryStatusCommand
 
apply(ServerConfiguration, ToggleCommand.AutoRecoveryFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ToggleCommand
 
apply(ServerConfiguration, CheckDBLedgersIndexCommand.CheckLedgersIndexFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.CheckDBLedgersIndexCommand
 
apply(ServerConfiguration, ConvertToDBStorageCommand.CTDBFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToDBStorageCommand
 
apply(ServerConfiguration, ConvertToInterleavedStorageCommand.CTISFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToInterleavedStorageCommand
 
apply(ServerConfiguration, FlipBookieIdCommand.FlipBookieIdFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand
 
apply(ServerConfiguration, FormatCommand.Flags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FormatCommand
 
apply(ServerConfiguration, LedgerCommand.LedgerFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.LedgerCommand
 
apply(ServerConfiguration, ListActiveLedgersCommand.ActiveLedgerFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand
 
apply(ServerConfiguration, ListFilesOnDiscCommand.LFODFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListFilesOnDiscCommand
 
apply(ServerConfiguration, ListLedgersCommand.ListLedgersFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListLedgersCommand
 
apply(ServerConfiguration, ReadJournalCommand.ReadJournalFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand
 
apply(ServerConfiguration, ReadLedgerCommand.ReadLedgerFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand
 
apply(ServerConfiguration, ReadLogCommand.ReadLogFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand
 
apply(ServerConfiguration, ReadLogMetadataCommand.ReadLogMetadataFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand
 
apply(ServerConfiguration, RebuildDBLedgersIndexCommand.RebuildLedgersIndexFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.RebuildDBLedgersIndexCommand
 
apply(ServerConfiguration, RegenerateInterleavedStorageIndexFileCommand.RISIFFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.RegenerateInterleavedStorageIndexFileCommand
 
apply(ServerConfiguration, SanityTestCommand.SanityFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.SanityTestCommand
 
apply(ServerConfiguration, UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand
 
apply(ServerConfiguration, DecommissionCommand.DecommissionFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.DecommissionCommand
 
apply(ServerConfiguration, EndpointInfoCommand.EndpointInfoFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.EndpointInfoCommand
 
apply(ServerConfiguration, MetaFormatCommand.MetaFormatFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.MetaFormatCommand
 
apply(ServerConfiguration, NukeExistingClusterCommand.NukeExistingClusterFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.NukeExistingClusterCommand
 
apply(ServerConfiguration, RecoverCommand.RecoverFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand
 
apply(ServerConfiguration, DeleteLedgerCommand.DeleteLedgerFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.client.DeleteLedgerCommand
 
apply(ServerConfiguration, LedgerMetaDataCommand.LedgerMetadataFlag) - Method in class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand
 
apply(ServerConfiguration, AdminCommand.AdminFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand
 
apply(ServerConfiguration, SwitchOfHealthCheckCommand.HealthCheckFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.health.SwitchOfHealthCheckCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.TriggerAuditCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.WhoIsAuditorCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.InitCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.LastMarkCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.LocalConsistencyCheckCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.RebuildDBLedgerLocationsIndexCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.InfoCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.InitCommand
 
apply(ServerConfiguration, CliFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.InstanceIdCommand
 
apply(RegistrationManager, CookieFlagsT) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.CookieCommand
 
apply(RegistrationManager, CreateCookieCommand.Flags) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.CreateCookieCommand
 
apply(RegistrationManager, DeleteCookieCommand.Flags) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.DeleteCookieCommand
 
apply(RegistrationManager, GenerateCookieCommand.Flags) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand
 
apply(RegistrationManager, GetCookieCommand.Flags) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.GetCookieCommand
 
apply(RegistrationManager, UpdateCookieCommand.Flags) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.UpdateCookieCommand
 
apply(BookieNode) - Method in interface org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.CoverageSet
 
apply(BookieNode) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackOrRegionDurabilityCoverageSet
 
apply(BookieNode) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackQuorumCoverageSet
 
apply(BookieNode, ITopologyAwareEnsemblePlacementPolicy.Ensemble) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.TruePredicate
 
apply(BookieNode, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
apply(BKFlags, CommandFlagsT) - Method in class org.apache.bookkeeper.tools.common.BKCommand
 
apply(BKFlags, String[]) - Method in class org.apache.bookkeeper.tools.common.BKCommand
 
apply(T, ITopologyAwareEnsemblePlacementPolicy.Ensemble<T>) - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy.Predicate
 
areAckedBookiesAdheringToPlacementPolicy(Set<BookieId>, int, int) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Returns true if the bookies that have acknowledged a write adhere to the minimum fault domains as defined in the placement policy in use.
areAckedBookiesAdheringToPlacementPolicy(Set<BookieId>, int, int) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
areAckedBookiesAdheringToPlacementPolicy(Set<BookieId>, int, int) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
areChildrenLeaves() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Determine if children a leaves, default implementation calls NetworkTopologyImpl.InnerNode.isRack().
areEntriesOfLedgerStoredInTheBookie(long, BookieId, LedgerMetadata) - Static method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
areEntriesOfLedgerStoredInTheBookie(long, BookieId, LedgerManager) - Static method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
arguments - Variable in class org.apache.bookkeeper.tools.framework.CliFlags
 
argumentsUsage() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
array - Variable in class org.apache.bookkeeper.bookie.storage.ldb.LongPairWrapper
 
array - Variable in class org.apache.bookkeeper.bookie.storage.ldb.LongWrapper
 
array() - Method in class org.apache.bookkeeper.util.ByteBufList
Returns a reference to the array backing this ByteBufList.
array() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
ArrayGroupSort - Class in org.apache.bookkeeper.bookie.storage.ldb
Sort an array of longs, grouping the items in tuples.
arrayOffset() - Method in class org.apache.bookkeeper.util.ByteBufList
Returns the offset of the first byte within the backing byte array of this buffer.
arrayOffset() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
ArrayUtil - Class in org.apache.bookkeeper.bookie.storage.ldb
Utility to serialize/deserialize longs into byte arrays.
ArrayUtil() - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.ArrayUtil
 
ASC - org.apache.bookkeeper.metastore.MetastoreScannableTable.Order
 
asJson() - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
returns the string representation of json format of this config.
asJson() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
returns the string representation of json format of this config.
asMap() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
asMap() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
asReadOnly() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
assertFingerPrint(ByteBuf) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
asShellCommand(String, CompositeConfiguration) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.CookieCommand
 
asStateless() - Method in class com.scurrilous.circe.crc.JavaCrc32
 
asStateless() - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
asStateless() - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
asStateless() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
asStateless() - Method in interface com.scurrilous.circe.StatefulIntHash
Returns an instance of stateless version of this hash function.
asStateless() - Method in interface com.scurrilous.circe.StatefulLongHash
Returns an instance of stateless version of this hash function.
asyncAddEntry(byte[], int, int, AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry asynchronously to an open ledger, using an offset and range.
asyncAddEntry(byte[], int, int, AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
LedgerHandleAdv will not allow addEntry without providing an entryId.
asyncAddEntry(byte[], int, int, AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
asyncAddEntry(byte[], AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry asynchronously to an open ledger.
asyncAddEntry(byte[], AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
asyncAddEntry(long, byte[], int, int, AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry asynchronously to an open ledger, using an offset and range.
asyncAddEntry(long, byte[], int, int, AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
Add entry asynchronously to an open ledger, using an offset and range.
asyncAddEntry(long, byte[], int, int, AsyncCallback.AddCallbackWithLatency, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry asynchronously to an open ledger, using an offset and range.
asyncAddEntry(long, byte[], int, int, AsyncCallback.AddCallbackWithLatency, Object) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
Add entry asynchronously to an open ledger, using an offset and range.
asyncAddEntry(long, byte[], AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry asynchronously to an open ledger.
asyncAddEntry(long, byte[], AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
Add entry asynchronously to an open ledger.
asyncAddEntry(long, ByteBuf, AsyncCallback.AddCallbackWithLatency, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry asynchronously to an open ledger, using an offset and range.
asyncAddEntry(long, ByteBuf, AsyncCallback.AddCallbackWithLatency, Object) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
Add entry asynchronously to an open ledger, using an offset and range.
asyncAddEntry(ByteBuf, AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
asyncAddEntry(ByteBuf, AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
LedgerHandleAdv will not allow addEntry without providing an entryId.
asyncBatchReadEntries(long, int, long, AsyncCallback.ReadCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries in asynchronously.
asyncBatchReadEntriesInternal(long, int, long, AsyncCallback.ReadCallback, Object, boolean) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
asyncBatchReadUnconfirmedEntries(long, int, long, AsyncCallback.ReadCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries asynchronously, allowing to read after the LastAddConfirmed range.
AsyncCallback - Interface in org.apache.bookkeeper.client
Defines all the callback interfaces for the async operations in bookkeeper client.
AsyncCallback.AddCallback - Interface in org.apache.bookkeeper.client
Async Callback for adding entries to ledgers.
AsyncCallback.AddCallbackWithLatency - Interface in org.apache.bookkeeper.client
Async Callback for adding entries to ledgers with latency information.
AsyncCallback.AddLacCallback - Interface in org.apache.bookkeeper.client
Async Callback for updating LAC for ledgers.
AsyncCallback.CloseCallback - Interface in org.apache.bookkeeper.client
Async Callback for closing ledgers.
AsyncCallback.CreateCallback - Interface in org.apache.bookkeeper.client
Async Callback for creating ledgers.
AsyncCallback.DeleteCallback - Interface in org.apache.bookkeeper.client
Async Callback for deleting ledgers.
AsyncCallback.IsClosedCallback - Interface in org.apache.bookkeeper.client
Async Callback for checking if a ledger is closed.
AsyncCallback.OpenCallback - Interface in org.apache.bookkeeper.client
Async Callback for opening ledgers.
AsyncCallback.ReadCallback - Interface in org.apache.bookkeeper.client
Async Callback for reading entries from ledgers.
AsyncCallback.ReadLastConfirmedAndEntryCallback - Interface in org.apache.bookkeeper.client
Async Callback for long polling read request.
AsyncCallback.ReadLastConfirmedCallback - Interface in org.apache.bookkeeper.client
Async Callback for reading LAC for ledgers.
AsyncCallback.RecoverCallback - Interface in org.apache.bookkeeper.client
Async Callback for recovering ledgers.
asyncClose(AsyncCallback.CloseCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Asynchronous close, any adds in flight will return errors.
asyncClose(AsyncCallback.CloseCallback, Object) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
asyncCloseInternal(AsyncCallback.CloseCallback, Object, int) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
asyncCreateFullPathOptimistic(ZooKeeper, String, byte[], List<ACL>, CreateMode, AsyncCallback.StringCallback, Object) - Static method in class org.apache.bookkeeper.util.ZkUtils
Asynchronously create zookeeper path recursively and optimistically.
asyncCreateLedger(int, int, int, BookKeeper.DigestType, byte[], AsyncCallback.CreateCallback, Object, Map<String, byte[]>) - Method in class org.apache.bookkeeper.client.BookKeeper
Creates a new ledger asynchronously.
asyncCreateLedger(int, int, BookKeeper.DigestType, byte[], AsyncCallback.CreateCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeper
Creates a new ledger asynchronously.
asyncCreateLedgerAdv(int, int, int, BookKeeper.DigestType, byte[], AsyncCallback.CreateCallback, Object, Map<String, byte[]>) - Method in class org.apache.bookkeeper.client.BookKeeper
Creates a new ledger asynchronously and returns LedgerHandleAdv which can accept entryId.
asyncCreateLedgerAdv(long, int, int, int, BookKeeper.DigestType, byte[], AsyncCallback.CreateCallback, Object, Map<String, byte[]>) - Method in class org.apache.bookkeeper.client.BookKeeper
Asynchronously creates a new ledger using the interface which accepts a ledgerId as input.
asyncDeleteFullPathOptimistic(ZooKeeper, String, int, AsyncCallback.VoidCallback, String) - Static method in class org.apache.bookkeeper.util.ZkUtils
Asynchronously deletes zookeeper path recursively and optimistically.
asyncDeleteLedger(long, AsyncCallback.DeleteCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeper
Deletes a ledger asynchronously.
asyncExplicitLacFlush(long) - Method in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
Make a LastAddUpdate request.
asyncGetLedgersContainBookies(Set<BookieId>, BookkeeperInternalCallbacks.GenericCallback<SortedMap<Long, LedgerMetadata>>) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
asyncGetListOfEntriesOfLedger(BookieId, long) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Makes async request for getting list of entries of ledger from a bookie and returns Future for the result.
asyncIsClosed(long, AsyncCallback.IsClosedCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeper
Check asynchronously whether the ledger with identifier lId has been closed.
asyncOpenLedger(long, AsyncCallback.OpenCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Open a ledger as an administrator.
asyncOpenLedger(long, BookKeeper.DigestType, byte[], AsyncCallback.OpenCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeper
Open existing ledger asynchronously for reading.
asyncOpenLedgerNoRecovery(long, AsyncCallback.OpenCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Open a ledger as an administrator without recovering the ledger.
asyncOpenLedgerNoRecovery(long, BookKeeper.DigestType, byte[], AsyncCallback.OpenCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeper
Open existing ledger asynchronously for reading, but it does not try to recover the ledger if it is not yet closed.
asyncProcessLedgers(MetastoreCursor, BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
asyncProcessLedgers(BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
asyncProcessLedgers(BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.FlatLedgerManager
 
asyncProcessLedgers(BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
asyncProcessLedgers(BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in interface org.apache.bookkeeper.meta.LedgerManager
Loop to process all ledgers.
asyncProcessLedgers(BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManager
 
asyncProcessLedgers(BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.LongHierarchicalLedgerManager
 
asyncProcessLedgers(BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
asyncProcessLedgers(BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
asyncProcessLedgersInSingleNode(String, BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
Process ledgers in a single zk node.
asyncProcessLevelNodes(String, BookkeeperInternalCallbacks.Processor<String>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.AbstractHierarchicalLedgerManager
Process hash nodes in a given path.
asyncReadEntries(int, MetastoreCursor.ReadEntriesCallback, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreCursor
 
asyncReadEntries(int, MetastoreCursor.ReadEntriesCallback, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreCursor
Asynchronously read entries from the cursor, up to the specified numEntries.
asyncReadEntries(long, long, AsyncCallback.ReadCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries asynchronously.
asyncReadEntriesInternal(long, long, AsyncCallback.ReadCallback, Object, boolean) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
asyncReadExplicitLastConfirmed(AsyncCallback.ReadLastConfirmedCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Obtains asynchronously the explicit last add confirmed from a quorum of bookies.
asyncReadLastConfirmed(AsyncCallback.ReadLastConfirmedCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Obtains asynchronously the last confirmed write from a quorum of bookies.
asyncReadLastConfirmedAndEntry(long, long, boolean, AsyncCallback.ReadLastConfirmedAndEntryCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Asynchronous read next entry and the latest last add confirmed.
asyncReadLastEntry(AsyncCallback.ReadCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
asyncReadLastEntry(AsyncCallback.ReadCallback, Object) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
asyncReadUnconfirmedEntries(long, long, AsyncCallback.ReadCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries asynchronously, allowing to read after the LastAddConfirmed range.
asyncRecoverBookieData(long, Set<BookieId>, boolean, boolean, AsyncCallback.RecoverCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Recover a specific ledger.
asyncRecoverBookieData(Set<BookieId>, boolean, boolean, boolean, AsyncCallback.RecoverCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
asyncRecoverBookieData(Set<BookieId>, AsyncCallback.RecoverCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
asyncRecoverBookieData(BookieId, AsyncCallback.RecoverCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Async method to rebuild and recover the ledger fragments data that was stored on the source bookie.
asyncRecoveryAddEntry(byte[], int, int, AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Make a recovery add entry request.
asyncTryReadLastConfirmed(AsyncCallback.ReadLastConfirmedCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Obtains asynchronously the last confirmed write from a quorum of bookies.
atLeast(Number) - Static method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
A numeric range that checks the lower bound.
atMost(Number) - Static method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
A numeric range that checks the upper bound.
attempts - Variable in class org.apache.bookkeeper.zookeeper.ZooWorker
 
AUDIT_BOOKIES_TIME - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
auditBookies() - Method in class org.apache.bookkeeper.replication.AuditorBookieCheckTask
 
auditor - Variable in class org.apache.bookkeeper.replication.AuditorElector
 
Auditor - Class in org.apache.bookkeeper.replication
Auditor is a single entity in the entire Bookie cluster and will be watching all the bookies under 'ledgerrootpath/available' zkpath.
Auditor(String, ServerConfiguration, BookKeeper, boolean, BookKeeperAdmin, boolean, StatsLogger) - Constructor for class org.apache.bookkeeper.replication.Auditor
 
Auditor(String, ServerConfiguration, BookKeeper, boolean, StatsLogger) - Constructor for class org.apache.bookkeeper.replication.Auditor
 
Auditor(String, ServerConfiguration, StatsLogger) - Constructor for class org.apache.bookkeeper.replication.Auditor
 
AUDITOR_ACQUIRE_CONCURRENT_OPEN_LEDGER_OPERATIONS_TIMEOUT_MSEC - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
AUDITOR_LEDGER_VERIFICATION_PERCENTAGE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
AUDITOR_MAX_NUMBER_OF_CONCURRENT_OPEN_LEDGER_OPERATIONS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
AUDITOR_PERIODIC_BOOKIE_CHECK_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
AUDITOR_PERIODIC_CHECK_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
AUDITOR_PERIODIC_PLACEMENT_POLICY_CHECK_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
AUDITOR_REPLICAS_CHECK_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
AUDITOR_SCOPE - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
auditorBookieCheckTask - Variable in class org.apache.bookkeeper.replication.Auditor
 
AuditorBookieCheckTask - Class in org.apache.bookkeeper.replication
 
AuditorBookieCheckTask(ServerConfiguration, AuditorStats, BookKeeperAdmin, LedgerManager, LedgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler, BookieLedgerIndexer, BiConsumer<AtomicBoolean, Throwable>, BiConsumer<Void, Throwable>) - Constructor for class org.apache.bookkeeper.replication.AuditorBookieCheckTask
 
auditorCheckAllLedgersTask - Variable in class org.apache.bookkeeper.replication.Auditor
 
AuditorCheckAllLedgersTask - Class in org.apache.bookkeeper.replication
 
AuditorCheckAllLedgersTask(ServerConfiguration, AuditorStats, BookKeeperAdmin, LedgerManager, LedgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler, BiConsumer<AtomicBoolean, Throwable>) - Constructor for class org.apache.bookkeeper.replication.AuditorCheckAllLedgersTask
 
auditorElector - Variable in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
AuditorElector - Class in org.apache.bookkeeper.replication
Performing auditor election using Apache ZooKeeper.
AuditorElector(String, ServerConfiguration) - Constructor for class org.apache.bookkeeper.replication.AuditorElector
 
AuditorElector(String, ServerConfiguration, BookKeeper, boolean) - Constructor for class org.apache.bookkeeper.replication.AuditorElector
AuditorElector for performing the auditor election.
AuditorElector(String, ServerConfiguration, BookKeeper, StatsLogger, boolean) - Constructor for class org.apache.bookkeeper.replication.AuditorElector
AuditorElector for performing the auditor election.
auditorPlacementPolicyCheckTask - Variable in class org.apache.bookkeeper.replication.Auditor
 
AuditorPlacementPolicyCheckTask - Class in org.apache.bookkeeper.replication
 
AuditorPlacementPolicyCheckTask(ServerConfiguration, AuditorStats, BookKeeperAdmin, LedgerManager, LedgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler, BiConsumer<AtomicBoolean, Throwable>) - Constructor for class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
auditorReplicasCheckTask - Variable in class org.apache.bookkeeper.replication.Auditor
 
AuditorReplicasCheckTask - Class in org.apache.bookkeeper.replication
 
AuditorReplicasCheckTask(ServerConfiguration, AuditorStats, BookKeeperAdmin, LedgerManager, LedgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler, BiConsumer<AtomicBoolean, Throwable>) - Constructor for class org.apache.bookkeeper.replication.AuditorReplicasCheckTask
 
auditorStats - Variable in class org.apache.bookkeeper.replication.AuditorTask
 
AuditorStats - Class in org.apache.bookkeeper.replication
 
AuditorStats(StatsLogger) - Constructor for class org.apache.bookkeeper.replication.AuditorStats
 
AuditorTask - Class in org.apache.bookkeeper.replication
 
AuditorTask(ServerConfiguration, AuditorStats, BookKeeperAdmin, LedgerManager, LedgerUnderreplicationManager, AuditorTask.ShutdownTaskHandler, BiConsumer<AtomicBoolean, Throwable>) - Constructor for class org.apache.bookkeeper.replication.AuditorTask
 
AuditorTask.ShutdownTaskHandler - Interface in org.apache.bookkeeper.replication
ShutdownTaskHandler used to shutdown auditor executor.
auditTask - Variable in class org.apache.bookkeeper.replication.Auditor
 
AUTH - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
AUTH = 5;
AUTH - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Auth message.
AUTH_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
AUTH_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
AUTH = 5;
AuthCallbacks - Class in org.apache.bookkeeper.auth
Callbacks for AuthProviders.
AuthCallbacks() - Constructor for class org.apache.bookkeeper.auth.AuthCallbacks
 
AuthCallbacks.GenericCallback<T> - Interface in org.apache.bookkeeper.auth
Generic callback used in authentication providers.
authenticated - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
authenticated - Variable in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler
 
AUTHENTICATION_DISABLED_PLUGIN_NAME - Static variable in class org.apache.bookkeeper.auth.AuthProviderFactoryFactory
 
authenticationError(ChannelHandlerContext, int) - Method in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
AuthenticationException(String) - Constructor for exception org.apache.bookkeeper.proto.AuthHandler.AuthenticationException
 
AuthHandler - Class in org.apache.bookkeeper.proto
 
AuthHandler() - Constructor for class org.apache.bookkeeper.proto.AuthHandler
 
AuthHandler.AuthenticationException - Exception in org.apache.bookkeeper.proto
 
AuthHandler.ClientSideHandler - Class in org.apache.bookkeeper.proto
 
AuthHandler.ClientSideHandler.AuthHandshakeCompleteCallback - Class in org.apache.bookkeeper.proto
 
AuthHandler.ClientSideHandler.AuthRequestCallback - Class in org.apache.bookkeeper.proto
 
AuthHandler.ServerSideHandler - Class in org.apache.bookkeeper.proto
 
AuthHandler.ServerSideHandler.AuthHandshakeCompleteCallback - Class in org.apache.bookkeeper.proto
 
AuthHandler.ServerSideHandler.AuthResponseCallback - Class in org.apache.bookkeeper.proto
 
AuthHandler.ServerSideHandler.AuthResponseCallbackLegacy - Class in org.apache.bookkeeper.proto
 
AuthHandshakeCompleteCallback() - Constructor for class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthHandshakeCompleteCallback
 
AuthHandshakeCompleteCallback(ChannelHandlerContext) - Constructor for class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler.AuthHandshakeCompleteCallback
 
authMessage - Variable in class org.apache.bookkeeper.proto.BookieProtocol.AuthRequest
 
authMessage - Variable in class org.apache.bookkeeper.proto.BookieProtocol.AuthResponse
 
AUTHORIZED_ROLES - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
authorizedId - Variable in class org.apache.bookkeeper.proto.BookieNettyServer.BookieSideConnectionPeerContextHandler
 
AUTHPLUGINNAME_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
authProvider - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
authProvider - Variable in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler
 
authProviderFactory - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
authProviderFactory - Variable in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler
 
authProviderFactory - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
AuthProviderFactoryFactory - Class in org.apache.bookkeeper.auth
A factory to manage the authentication provider factories.
AuthProviderFactoryFactory() - Constructor for class org.apache.bookkeeper.auth.AuthProviderFactoryFactory
 
AuthRequest(byte, BookkeeperProtocol.AuthMessage) - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.AuthRequest
 
AUTHREQUEST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
AuthRequestCallback(ChannelHandlerContext, String) - Constructor for class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler.AuthRequestCallback
 
AuthResponse(byte, BookkeeperProtocol.AuthMessage) - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.AuthResponse
 
AUTHRESPONSE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
AuthResponseCallback(BookkeeperProtocol.Request, Channel, String) - Constructor for class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthResponseCallback
 
AuthResponseCallbackLegacy(BookieProtocol.AuthRequest, Channel) - Constructor for class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthResponseCallbackLegacy
 
AuthToken - Class in org.apache.bookkeeper.auth
A generic payload for Authentication Messages.
AUTO_RECOVERY_DAEMON_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
AutoCloseableLifecycleComponent - Class in org.apache.bookkeeper.common.component
Allows for AutoClosable resources to be added to the component lifecycle without having to implement ServerLifecycleComponent directly.
AutoCloseableLifecycleComponent(String, AutoCloseable) - Constructor for class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
autoRecovery - Variable in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
AutoRecoveryCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.AutoRecoveryCmd
 
AutoRecoveryFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.ToggleCommand.AutoRecoveryFlags
 
AutoRecoveryMain - Class in org.apache.bookkeeper.replication
Class to start/stop the AutoRecovery daemons Auditor and ReplicationWorker.
AutoRecoveryMain(ServerConfiguration) - Constructor for class org.apache.bookkeeper.replication.AutoRecoveryMain
 
AutoRecoveryMain(ServerConfiguration, StatsLogger) - Constructor for class org.apache.bookkeeper.replication.AutoRecoveryMain
 
AutoRecoveryService - Class in org.apache.bookkeeper.server.service
A ServerLifecycleComponent that runs autorecovery.
AutoRecoveryService(BookieConfiguration, StatsLogger) - Constructor for class org.apache.bookkeeper.server.service.AutoRecoveryService
 
AutoRecoveryStatusService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handles Autorecovery status related http requests.
AutoRecoveryStatusService(ServerConfiguration) - Constructor for class org.apache.bookkeeper.server.http.service.AutoRecoveryStatusService
 
autoShrink - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
autoShrink - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
autoShrink - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
autoShrink - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
autoShrink - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
autoShrink - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
autoShrink(boolean) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
autoShrink(boolean) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
autoShrink(boolean) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
autoShrink(boolean) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
autoShrink(boolean) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
autoShrink(boolean) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
availability - Variable in class org.apache.bookkeeper.feature.FixedValueFeature
 
availability - Variable in class org.apache.bookkeeper.feature.SettableFeatureProvider
 
availability() - Method in interface org.apache.bookkeeper.feature.Feature
Returns the availability of this feature, an integer between 0 and 100.
availability() - Method in class org.apache.bookkeeper.feature.FixedValueFeature
 
AvailabilityOfEntriesOfLedger - Class in org.apache.bookkeeper.util
Ordered collection of SequenceGroups will represent entries of the ledger residing in a bookie.
AvailabilityOfEntriesOfLedger(byte[]) - Constructor for class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
AvailabilityOfEntriesOfLedger(long[]) - Constructor for class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
AvailabilityOfEntriesOfLedger(ByteBuf) - Constructor for class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
AvailabilityOfEntriesOfLedger(PrimitiveIterator.OfLong) - Constructor for class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
AVAILABILITYOFENTRIESOFLEDGER_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
AVAILABLE_NODE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
AVAILABLE_NODE - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
availableBookiesChanged() - Method in interface org.apache.bookkeeper.client.BookiesListener
Callback method triggered when the list of available bookies are changed.
availableBookiesChanged(Set<BookieId>) - Method in class org.apache.bookkeeper.client.BookieInfoReader
 
await() - Method in class org.apache.bookkeeper.replication.ReplicationEnableCb
This is a blocking call and causes the current thread to wait until the replication process is enabled.
awaitTermination(long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
awaitTermination(long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 

B

b64Password(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.RegenerateInterleavedStorageIndexFileCommand.RISIFFlags
 
Backoff - Class in org.apache.bookkeeper.common.util
Implements various backoff strategies.
Backoff() - Constructor for class org.apache.bookkeeper.common.util.Backoff
 
Backoff.Constant - Class in org.apache.bookkeeper.common.util
A constant backoff policy.
Backoff.Exponential - Class in org.apache.bookkeeper.common.util
A exponential backoff policy.
Backoff.Jitter - Class in org.apache.bookkeeper.common.util
A Jittered backoff policy.
Backoff.Jitter.Type - Enum in org.apache.bookkeeper.common.util
Jitter type.
Backoff.Policy - Interface in org.apache.bookkeeper.common.util
Back off policy.
backoffMultiplier - Variable in class org.apache.bookkeeper.client.DefaultSpeculativeRequestExecutionPolicy
 
BadVersion - org.apache.bookkeeper.metastore.MSException.Code
 
BadVersionException(String) - Constructor for exception org.apache.bookkeeper.metastore.MSException.BadVersionException
 
BadVersionException(String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MSException.BadVersionException
 
basename - Variable in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
 
BATCH_READ_ENABLED - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
BATCH_READ_ENTRY - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
BATCH_READ_ENTRY = 12;
BATCH_READ_ENTRY - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
 
BATCH_READ_ENTRY_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
BATCH_READ_ENTRY = 12;
batchCount() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage.Batch
 
BatchedArrayBlockingQueue<T> - Class in org.apache.bookkeeper.common.collections
This implements a BlockingQueue backed by an array with fixed capacity.
BatchedArrayBlockingQueue(int) - Constructor for class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
BatchedBlockingQueue<T> - Interface in org.apache.bookkeeper.common.collections
 
BatchedLedgerEntryRequest(List<BookieId>, long, long, int, long) - Constructor for class org.apache.bookkeeper.client.BatchedReadOp.BatchedLedgerEntryRequest
 
BatchedReadCompletion(PerChannelBookieClient.CompletionKey, BookkeeperInternalCallbacks.BatchedReadEntryCallback, Object, long, long) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.BatchedReadCompletion
 
BatchedReadEntryProcessor - Class in org.apache.bookkeeper.proto
 
BatchedReadOp - Class in org.apache.bookkeeper.client
 
BatchedReadOp(LedgerHandle, ClientContext, long, int, long, boolean) - Constructor for class org.apache.bookkeeper.client.BatchedReadOp
 
BatchedReadOp.BatchedLedgerEntryRequest - Class in org.apache.bookkeeper.client
 
BatchedReadOp.SequenceReadRequest - Class in org.apache.bookkeeper.client
 
BatchedReadResponse(byte, int, long, long, long) - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
BatchedReadResponse(byte, int, long, long, long, ByteBufList) - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
BatchImpl(BookieId, long, LedgerMetadata, EntryCopierImpl.SinBin) - Constructor for class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl.BatchImpl
 
batchRead(long, int, long) - Method in interface org.apache.bookkeeper.client.api.ReadHandle
 
batchReadAsync(long, int, long) - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Read a sequence of entries asynchronously.
batchReadAsync(long, int, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries in asynchronously.
batchReadEnabled - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
batchReadEntries(long, int, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries synchronously.
batchReadEntries(long, long, int, long, BookkeeperInternalCallbacks.BatchedReadEntryCallback, Object, int, byte[], boolean) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
batchReadEntries(BookieId, long, long, int, long, BookkeeperInternalCallbacks.BatchedReadEntryCallback, Object, int) - Method in interface org.apache.bookkeeper.proto.BookieClient
Batch read entries with a null masterkey, disallowing failfast.
batchReadEntries(BookieId, long, long, int, long, BookkeeperInternalCallbacks.BatchedReadEntryCallback, Object, int, byte[]) - Method in interface org.apache.bookkeeper.proto.BookieClient
Batch read entries, disallowing failfast.
batchReadEntries(BookieId, long, long, int, long, BookkeeperInternalCallbacks.BatchedReadEntryCallback, Object, int, byte[], boolean) - Method in interface org.apache.bookkeeper.proto.BookieClient
Batch read entries from bookie at address address.
batchReadEntries(BookieId, long, long, int, long, BookkeeperInternalCallbacks.BatchedReadEntryCallback, Object, int, byte[], boolean) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
batchReadUnconfirmedEntries(long, int, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries synchronously, allowing to read after the LastAddConfirmed range.
This is the same of LedgerHandle.asyncBatchReadUnconfirmedEntries(long, int, long, ReadCallback, Object)
batchRecoverLedgerFragmentEntry(long, long, LedgerHandle, AsyncCallback.VoidCallback, Set<BookieId>, BiConsumer<Long, Long>) - Method in class org.apache.bookkeeper.client.LedgerFragmentReplicator
 
bbytes - Variable in class org.apache.bookkeeper.streaming.LedgerInputStream
 
bbytes - Variable in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
bc - Variable in class org.apache.bookkeeper.bookie.JournalChannel
 
BC - Static variable in class org.apache.bookkeeper.tls.TLSContextFactory
 
BC_FIPS - Static variable in class org.apache.bookkeeper.tls.TLSContextFactory
 
BC_FIPS_PROVIDER_CLASS - Static variable in class org.apache.bookkeeper.tls.TLSContextFactory
 
BC_NON_FIPS_PROVIDER_CLASS - Static variable in class org.apache.bookkeeper.tls.TLSContextFactory
 
BC_PROVIDER - Static variable in class org.apache.bookkeeper.tls.TLSContextFactory
 
BEFORE - org.apache.bookkeeper.versioning.Version.Occurred
 
beforeClose() - Method in interface org.apache.bookkeeper.common.component.LifecycleListener
 
beforeStart() - Method in interface org.apache.bookkeeper.common.component.LifecycleListener
 
beforeStop() - Method in interface org.apache.bookkeeper.common.component.LifecycleListener
 
best(HashParameters) - Static method in class com.scurrilous.circe.HashProviders
Returns the best hash provider supporting at least a stateful implementation of a hash function with the given parameters.
best(HashParameters, EnumSet<HashSupport>) - Static method in class com.scurrilous.circe.HashProviders
Returns the best hash provider supporting at least the given flags for a hash function with the given parameters.
bestEffortRemoveFromPageCache(int, long, long) - Static method in class org.apache.bookkeeper.util.PageCacheUtil
Remove pages from the file system page cache when they won't be accessed again.
between(Number, Number) - Static method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
A numeric range that checks both lower and upper bounds.
bindAddress - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
bitWidth - Variable in class com.scurrilous.circe.crc.AbstractIntCrc
 
bitWidth - Variable in class com.scurrilous.circe.crc.AbstractLongCrc
 
bitWidth() - Method in class com.scurrilous.circe.params.CrcParameters
Returns the width in bits of the CRC function.
bk - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
bk - Variable in class org.apache.bookkeeper.client.LedgerDeleteOp
 
bk - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
BK_METADATA_BOOKIE_DRIVERS_PROPERTY - Static variable in class org.apache.bookkeeper.meta.MetadataDrivers
 
BK_METADATA_CLIENT_DRIVERS_PROPERTY - Static variable in class org.apache.bookkeeper.meta.MetadataDrivers
 
BK_OPTS - Static variable in class org.apache.bookkeeper.server.Main
 
bka - Variable in class org.apache.bookkeeper.server.http.service.DecommissionService
 
bka - Variable in class org.apache.bookkeeper.server.http.service.ListBookiesService
 
bka - Variable in class org.apache.bookkeeper.server.http.service.LostBookieRecoveryDelayService
 
bka - Variable in class org.apache.bookkeeper.server.http.service.ReadLedgerEntryService
 
bka - Variable in class org.apache.bookkeeper.server.http.service.RecoveryBookieService
 
bka - Variable in class org.apache.bookkeeper.server.http.service.TriggerAuditService
 
bka - Variable in class org.apache.bookkeeper.server.http.service.WhoIsAuditorService
 
BKAddEntryQuorumTimeoutException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKAddEntryQuorumTimeoutException
 
BKAuditException(String) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException.BKAuditException
 
BKAuditException(String, Throwable) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException.BKAuditException
 
BKBookieException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKBookieException
 
BKBookieHandleNotAvailableException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKBookieHandleNotAvailableException
 
bkc - Variable in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
BKClientClosedException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKClientClosedException
 
bkCmd - Variable in class org.apache.bookkeeper.tools.cli.helpers.BookieShellCommand
 
BKCommand<CommandFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.common
Base bk command class.
BKCommand(CliSpec<CommandFlagsT>) - Constructor for class org.apache.bookkeeper.tools.common.BKCommand
 
BKCommandCategories - Class in org.apache.bookkeeper.tools.common
Classes to keep a list of command categories.
BKCommandCategories() - Constructor for class org.apache.bookkeeper.tools.common.BKCommandCategories
 
bkConf - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
BKDataUnknownException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKDataUnknownException
 
BKDigestMatchException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKDigestMatchException
 
BKDigestNotInitializedException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKDigestNotInitializedException
 
BKDuplicateEntryIdException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKDuplicateEntryIdException
 
BKException - Exception in org.apache.bookkeeper.client.api
Super class for all errors which occur using BookKeeper client.
BKException - Exception in org.apache.bookkeeper.client
Class the enumerates all the possible error conditions.
BKException(int) - Constructor for exception org.apache.bookkeeper.client.api.BKException
Create a new exception.
BKException(int) - Constructor for exception org.apache.bookkeeper.client.BKException
 
BKException(int, Throwable) - Constructor for exception org.apache.bookkeeper.client.api.BKException
Create a new exception with the cause.
BKException(int, Throwable) - Constructor for exception org.apache.bookkeeper.client.BKException
 
BKException.BKAddEntryQuorumTimeoutException - Exception in org.apache.bookkeeper.client
Bookkeeper add entry quorum timeout exception.
BKException.BKBookieException - Exception in org.apache.bookkeeper.client
Bookkeeper bookie exception.
BKException.BKBookieHandleNotAvailableException - Exception in org.apache.bookkeeper.client
Bookkeeper bookie handle not available exception.
BKException.BKClientClosedException - Exception in org.apache.bookkeeper.client
Bookkeeper client closed exception.
BKException.BKDataUnknownException - Exception in org.apache.bookkeeper.client
Bookkeeper ledger in limbo and data may or may not exist.
BKException.BKDigestMatchException - Exception in org.apache.bookkeeper.client
Bookkeeper digest match exception.
BKException.BKDigestNotInitializedException - Exception in org.apache.bookkeeper.client
Bookkeeper digest not initialized exception.
BKException.BKDuplicateEntryIdException - Exception in org.apache.bookkeeper.client
Bookkeeper duplicate entry id exception.
BKException.BKIllegalOpException - Exception in org.apache.bookkeeper.client
Bookkeeper illegal operation exception.
BKException.BKIncorrectParameterException - Exception in org.apache.bookkeeper.client
Bookkeeper incorrect parameter exception.
BKException.BKInterruptedException - Exception in org.apache.bookkeeper.client
Bookkeeper interrupted exception.
BKException.BKLedgerClosedException - Exception in org.apache.bookkeeper.client
Bookkeeper ledger closed exception.
BKException.BKLedgerExistException - Exception in org.apache.bookkeeper.client
Bookkeeper ledger exist exception.
BKException.BKLedgerFencedException - Exception in org.apache.bookkeeper.client
Bookkeeper ledger fenced exception.
BKException.BKLedgerIdOverflowException - Exception in org.apache.bookkeeper.client
Bookkeeper ledger id overflow exception.
BKException.BKLedgerRecoveryException - Exception in org.apache.bookkeeper.client
Bookkeeper ledger recovery exception.
BKException.BKMetadataSerializationException - Exception in org.apache.bookkeeper.client
Bookkeeper metadata serialization exception.
BKException.BKMetadataVersionException - Exception in org.apache.bookkeeper.client
Bookkeeper metadata version exception.
BKException.BKNoSuchEntryException - Exception in org.apache.bookkeeper.client
Bookkeeper no such entry exception.
BKException.BKNoSuchLedgerExistsException - Exception in org.apache.bookkeeper.client
Bookkeeper no such ledger exists exception.
BKException.BKNoSuchLedgerExistsOnMetadataServerException - Exception in org.apache.bookkeeper.client
Bookkeeper no such ledger exists on metadata server exception.
BKException.BKNotEnoughBookiesException - Exception in org.apache.bookkeeper.client
Bookkeeper not enough bookies exception.
BKException.BKProtocolVersionException - Exception in org.apache.bookkeeper.client
Bookkeeper protocol version exception.
BKException.BKQuorumException - Exception in org.apache.bookkeeper.client
Bookkeeper quorum exception.
BKException.BKReadException - Exception in org.apache.bookkeeper.client
Bookkeeper read exception.
BKException.BKReplicationException - Exception in org.apache.bookkeeper.client
Bookkeeper replication exception.
BKException.BKSecurityException - Exception in org.apache.bookkeeper.client
Bookkeeper security exception.
BKException.BKTimeoutException - Exception in org.apache.bookkeeper.client
Bookkeeper timeout exception.
BKException.BKTooManyRequestsException - Exception in org.apache.bookkeeper.client
Bookkeeper too many requests exception.
BKException.BKUnauthorizedAccessException - Exception in org.apache.bookkeeper.client
Bookkeeper unauthorized access exception.
BKException.BKUnclosedFragmentException - Exception in org.apache.bookkeeper.client
Bookkeeper unclosed fragment exception.
BKException.BKUnexpectedConditionException - Exception in org.apache.bookkeeper.client
Bookkeeper unexpected condition exception.
BKException.BKWriteException - Exception in org.apache.bookkeeper.client
Bookkeeper write exception.
BKException.BKWriteOnReadOnlyBookieException - Exception in org.apache.bookkeeper.client
Bookkeeper write on readonly bookie exception.
BKException.Code - Interface in org.apache.bookkeeper.client.api
Codes which represent the various exception types.
BKException.Code - Interface in org.apache.bookkeeper.client
Legacy interface which holds constants for BookKeeper error codes.
BKException.MetaStoreException - Exception in org.apache.bookkeeper.client
Metastore exception.
BKException.ZKException - Exception in org.apache.bookkeeper.client
Zookeeper exception.
BKFlags - Class in org.apache.bookkeeper.tools.common
Default BK flags.
BKFlags() - Constructor for class org.apache.bookkeeper.tools.common.BKFlags
 
BKHttpServiceProvider - Class in org.apache.bookkeeper.server.http
Bookkeeper based implementation of HttpServiceProvider, which provide bookkeeper services to handle http requests from different http endpoints.
BKHttpServiceProvider.Builder - Class in org.apache.bookkeeper.server.http
Builder for HttpServiceProvider.
BKIllegalOpException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKIllegalOpException
 
BKIncorrectParameterException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKIncorrectParameterException
 
BKInterruptedException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKInterruptedException
 
BKLedgerClosedException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKLedgerClosedException
 
BKLedgerExistException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKLedgerExistException
 
BKLedgerFencedException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKLedgerFencedException
 
BKLedgerIdOverflowException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKLedgerIdOverflowException
 
BKLedgerRecoveryException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKLedgerRecoveryException
 
BKMetadataSerializationException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKMetadataSerializationException
 
BKMetadataSerializationException(Throwable) - Constructor for exception org.apache.bookkeeper.client.BKException.BKMetadataSerializationException
 
BKMetadataVersionException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKMetadataVersionException
 
BKNoSuchEntryException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKNoSuchEntryException
 
BKNoSuchLedgerExistsException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKNoSuchLedgerExistsException
 
BKNoSuchLedgerExistsOnMetadataServerException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKNoSuchLedgerExistsOnMetadataServerException
 
BKNotEnoughBookiesException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKNotEnoughBookiesException
 
BKNotEnoughBookiesException(Throwable) - Constructor for exception org.apache.bookkeeper.client.BKException.BKNotEnoughBookiesException
 
BKProtocolVersionException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKProtocolVersionException
 
BKQuorumException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKQuorumException
 
BKReadException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKReadException
 
BKReplicationException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKReplicationException
 
BKSecurityException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKSecurityException
 
BKStats - Class in org.apache.bookkeeper.proto
Bookie Server Stats.
BKStats.OpStatData - Class in org.apache.bookkeeper.proto
A read view of stats, also used in CompositeViewData to expose to JMX.
BKStats.OpStats - Class in org.apache.bookkeeper.proto
Operation Statistics.
BKTimeoutException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKTimeoutException
 
BKTooManyRequestsException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKTooManyRequestsException
 
BKUnauthorizedAccessException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKUnauthorizedAccessException
 
BKUnclosedFragmentException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKUnclosedFragmentException
 
BKUnexpectedConditionException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKUnexpectedConditionException
 
BKWriteException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKWriteException
 
BKWriteOnReadOnlyBookieException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKWriteOnReadOnlyBookieException
 
blacklistChannel(Channel) - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
blacklistedChannels - Variable in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
block() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.SyncResult
Deprecated.
 
block(int) - Method in class org.apache.bookkeeper.client.SyncCounter
 
blockAddRequest() - Method in class org.apache.bookkeeper.proto.RequestStats
 
BlockingMpscQueue<T> - Class in org.apache.bookkeeper.common.collections
Blocking queue optimized for multiple producers and single consumer.
BlockingMpscQueue(int) - Constructor for class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
blockReadRequest() - Method in class org.apache.bookkeeper.proto.RequestStats
 
BODY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
BODY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
BODY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
bookie - Variable in class org.apache.bookkeeper.proto.BookieRequestProcessor
This is the Bookie instance that is used to handle all read and write requests.
bookie - Variable in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
bookie(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.EndpointInfoCommand.EndpointInfoFlags
 
Bookie - Interface in org.apache.bookkeeper.bookie
Interface for the bookie.
BOOKIE_ADD_ENTRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_ADD_ENTRY_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_ADDRESS_RESOLVER_ENABLED - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
BOOKIE_AUTH_PROVIDER_FACTORY_CLASS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
BOOKIE_ERROR_THRESHOLD_PER_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
BOOKIE_EXCEPTION - Static variable in class org.apache.bookkeeper.bookie.ExitCode
 
BOOKIE_FAILURE_HISTORY_EXPIRATION_MS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
BOOKIE_FORCE_LEDGER - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_GET_LIST_OF_ENTRIES_OF_LEDGER - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_HEALTH_CHECK_ENABLED - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
BOOKIE_HEALTH_CHECK_INTERVAL_SECONDS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
BOOKIE_ID - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
BOOKIE_LABEL - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
BOOKIE_MAX_MULTIPLE_FOR_WEIGHTED_PLACEMENT - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
BOOKIE_PORT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
BOOKIE_QUARANTINE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_QUARANTINE_RATIO - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
BOOKIE_QUARANTINE_SKIP - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_QUARANTINE_TIME_SECONDS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
BOOKIE_READ_ENTRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_READ_ENTRY_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_RECOVERY_ADD_ENTRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_SCOPE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIE_STATUS_FILENAME - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
BOOKIE_TO_LEDGERS_MAP_CREATION_TIME - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
Bookie.NoEntryException - Exception in org.apache.bookkeeper.bookie
Exception is thrown when no such an entry is found in this bookie.
Bookie.NoLedgerException - Exception in org.apache.bookkeeper.bookie
Exception is thrown when no such a ledger is found in this bookie.
bookieAddress - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
bookieAddress(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
bookieAddress(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
bookieAddressResolver - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
bookieAddressResolver - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
BookieAddressResolver - Interface in org.apache.bookkeeper.proto
Maps a logical BookieId to a ResolvedBookieSocketAddress that it to a network address.
BookieAddressResolver.BookieIdNotResolvedException - Exception in org.apache.bookkeeper.proto
This error happens when there is not enough information to resolve a BookieId to a BookieSocketAddress, this can happen when the Bookie is down and it is not publishing its EndpointInfo.
BookieAddressResolverDisabled - Class in org.apache.bookkeeper.client
Resolve legacy style BookieIDs to Network addresses.
BookieAddressResolverDisabled() - Constructor for class org.apache.bookkeeper.client.BookieAddressResolverDisabled
 
bookieAddressTracking - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
BookieAuthProvider - Interface in org.apache.bookkeeper.auth
Bookie authentication provider interface.
BookieAuthProvider.Factory - Interface in org.apache.bookkeeper.auth
A factory to create the bookie authentication provider.
BookieAuthZFactory - Class in org.apache.bookkeeper.tls
Authorization factory class.
BookieAuthZFactory() - Constructor for class org.apache.bookkeeper.tls.BookieAuthZFactory
 
bookieClient - Variable in class org.apache.bookkeeper.client.BookKeeper
 
bookieClient - Variable in class org.apache.bookkeeper.client.ForceLedgerOp
 
bookieClient - Variable in class org.apache.bookkeeper.client.LedgerChecker
 
bookieClient - Variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
bookieClient - Variable in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
BookieClient - Interface in org.apache.bookkeeper.proto
Low level client for talking to bookies.
BookieClientImpl - Class in org.apache.bookkeeper.proto
Implements the client-side part of the BookKeeper protocol.
BookieClientImpl(ClientConfiguration, EventLoopGroup, ByteBufAllocator, OrderedExecutor, ScheduledExecutorService, StatsLogger, BookieAddressResolver) - Constructor for class org.apache.bookkeeper.proto.BookieClientImpl
 
BookieCommand<BookieFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.cli.helpers
This is a mixin for bookie related commands to extends.
BookieCommand(CliSpec<BookieFlagsT>) - Constructor for class org.apache.bookkeeper.tools.cli.helpers.BookieCommand
 
BookieConfiguration - Class in org.apache.bookkeeper.server.conf
A bookie related ComponentConfiguration.
BookieConfiguration(ServerConfiguration) - Constructor for class org.apache.bookkeeper.server.conf.BookieConfiguration
 
BookieConnectionPeer - Interface in org.apache.bookkeeper.proto
Represents the connection to a BookKeeper client, from the Bookie side.
BookieCriticalThread - Class in org.apache.bookkeeper.bookie
Thread is marked as critical and will exit, when there is an uncaught exception occurred in thread.
BookieCriticalThread(Runnable, String) - Constructor for class org.apache.bookkeeper.bookie.BookieCriticalThread
 
BookieCriticalThread(String) - Constructor for class org.apache.bookkeeper.bookie.BookieCriticalThread
 
BookieException - Exception in org.apache.bookkeeper.bookie
Signals that a Bookie exception of some sort has occurred.
BookieException(int) - Constructor for exception org.apache.bookkeeper.bookie.BookieException
 
BookieException(int, String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException
 
BookieException(int, String, Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException
 
BookieException(int, Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException
 
BookieException.BookieIllegalOpException - Exception in org.apache.bookkeeper.bookie
Signals that an illegal operation attempts to access the data in a bookie.
BookieException.BookieUnauthorizedAccessException - Exception in org.apache.bookkeeper.bookie
Signals that an unauthorized operation attempts to access the data in a bookie.
BookieException.Code - Interface in org.apache.bookkeeper.bookie
An exception code indicates the failure reason.
BookieException.CookieExistException - Exception in org.apache.bookkeeper.bookie
Signal that cookie already exists when creating a new cookie.
BookieException.CookieNotFoundException - Exception in org.apache.bookkeeper.bookie
Signal that no cookie is found when starting a bookie.
BookieException.DataUnknownException - Exception in org.apache.bookkeeper.bookie
Signal when a ledger is in a limbo state and certain operations cannot be performed on it.
BookieException.DiskPartitionDuplicationException - Exception in org.apache.bookkeeper.bookie
Signals when multiple ledger/journal directories are mounted in same disk partition.
BookieException.EntryLogMetadataMapException - Exception in org.apache.bookkeeper.bookie
Signal that error while accessing entry-log metadata map.
BookieException.InvalidCookieException - Exception in org.apache.bookkeeper.bookie
Signal that an invalid cookie is found when starting a bookie.
BookieException.LedgerFencedException - Exception in org.apache.bookkeeper.bookie
Signals that a ledger has been fenced in a bookie.
BookieException.MetadataStoreException - Exception in org.apache.bookkeeper.bookie
Signal when bookie has problems on accessing metadata store.
BookieException.OperationRejectedException - Exception in org.apache.bookkeeper.bookie
Signals that a ledger's operation has been rejected by an internal component because of the resource saturation.
BookieException.UnknownBookieIdException - Exception in org.apache.bookkeeper.bookie
Signal when bookie has problems on accessing metadata store.
BookieException.UpgradeException - Exception in org.apache.bookkeeper.bookie
Signals that an exception occurs on upgrading a bookie.
bookieFailureHistory - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
bookieFailureHistoryExpirationMSec - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
BookieFileChannel - Interface in org.apache.bookkeeper.bookie
A FileChannel for the JournalChannel read and write, we can use this interface to extend the FileChannel which we use in the JournalChannel.
bookieFilesFilter - Static variable in class org.apache.bookkeeper.bookie.FileSystemUpgrade
 
BookieFormatCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.BookieFormatCmd
 
BookieHandleNotAvailableException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Bookies are not available.
BOOKIEHOST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
bookieId - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
bookieId - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
bookieId(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListLedgersCommand.ListLedgersFlags
 
BookieId - Class in org.apache.bookkeeper.net
This is an identifier for a BookieID.
BOOKIEID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
BOOKIEID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
BookieIdNotResolvedException(BookieId, Throwable) - Constructor for exception org.apache.bookkeeper.proto.BookieAddressResolver.BookieIdNotResolvedException
 
BookieIllegalOpException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.BookieIllegalOpException
 
BookieIllegalOpException(String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.BookieIllegalOpException
 
BookieIllegalOpException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.BookieIllegalOpException
 
BookieImpl - Class in org.apache.bookkeeper.bookie
Implements a bookie.
BookieImpl(ServerConfiguration, RegistrationManager, LedgerStorage, DiskChecker, LedgerDirsManager, LedgerDirsManager, StatsLogger, ByteBufAllocator, Supplier<BookieServiceInfo>) - Constructor for class org.apache.bookkeeper.bookie.BookieImpl
 
BookieImpl.NopWriteCallback - Class in org.apache.bookkeeper.bookie
 
bookieIndex - Variable in class org.apache.bookkeeper.client.ReadOpBase.ReadContext
 
bookieIndex - Variable in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
BookieInfo() - Constructor for class org.apache.bookkeeper.client.BookieInfoReader.BookieInfo
 
BookieInfo() - Constructor for class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
BookieInfo(long, long) - Constructor for class org.apache.bookkeeper.client.BookieInfoReader.BookieInfo
 
BookieInfo(long, long) - Constructor for class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
BookieInfoCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.BookieInfoCmd
 
bookieInfoMap - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
bookieInfoReader - Variable in class org.apache.bookkeeper.client.BookKeeper
 
BookieInfoReader - Class in org.apache.bookkeeper.client
A utility class to read BookieInfoReader.BookieInfo from bookies.
BookieInfoReader(BookKeeper, ClientConfiguration, ScheduledExecutorService) - Constructor for class org.apache.bookkeeper.client.BookieInfoReader
 
BookieInfoReader.BookieInfo - Class in org.apache.bookkeeper.client
A class represents the information (e.g.
BookieInfoReader.State - Enum in org.apache.bookkeeper.client
Tracks whether there is an execution in progress as well as whether another is pending.
bookieInfoScheduler - Variable in class org.apache.bookkeeper.client.BookKeeper
 
BookieInfoService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that exposes the current info of the bookie.
BookieInfoService(Bookie) - Constructor for class org.apache.bookkeeper.server.http.service.BookieInfoService
 
BookieInfoService.BookieInfo - Class in org.apache.bookkeeper.server.http.service
POJO definition for the bookie info response.
BookieIsReadyService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that returns 200 if the bookie is ready.
BookieIsReadyService(Bookie) - Constructor for class org.apache.bookkeeper.server.http.service.BookieIsReadyService
 
BookieLedgerIndexer - Class in org.apache.bookkeeper.replication
Preparing bookie vs its corresponding ledgers.
BookieLedgerIndexer(LedgerManager) - Constructor for class org.apache.bookkeeper.replication.BookieLedgerIndexer
 
BookieNettyServer - Class in org.apache.bookkeeper.proto
Netty server for serving bookie requests.
BookieNettyServer(ServerConfiguration, RequestProcessor, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.proto.BookieNettyServer
 
BookieNettyServer.BookieSideConnectionPeerContextHandler - Class in org.apache.bookkeeper.proto
 
BookieNode - Class in org.apache.bookkeeper.net
Bookie Node implementation.
BookieNode(BookieId, String) - Constructor for class org.apache.bookkeeper.net.BookieNode
 
BookieProtocol - Interface in org.apache.bookkeeper.proto
The packets of the Bookie protocol all have a 4-byte integer indicating the type of request or response at the very beginning of the packet followed by a payload.
BookieProtocol.AddResponse - Class in org.apache.bookkeeper.proto
A response that adds data.
BookieProtocol.AuthRequest - Class in org.apache.bookkeeper.proto
An authentication request.
BookieProtocol.AuthResponse - Class in org.apache.bookkeeper.proto
A response with an authentication message.
BookieProtocol.BatchedReadRequest - Class in org.apache.bookkeeper.proto
The request for reading data with batch optimization.
BookieProtocol.BatchedReadResponse - Class in org.apache.bookkeeper.proto
The response for batched read.
BookieProtocol.ErrorResponse - Class in org.apache.bookkeeper.proto
An error response.
BookieProtocol.PacketHeader - Class in org.apache.bookkeeper.proto
The first int of a packet is the header.
BookieProtocol.ParsedAddRequest - Class in org.apache.bookkeeper.proto
This is similar to add request, but it used when processing the request on the bookie side.
BookieProtocol.ReadRequest - Class in org.apache.bookkeeper.proto
A Request that reads data.
BookieProtocol.ReadResponse - Class in org.apache.bookkeeper.proto
A request that reads data.
BookieProtocol.Request - Class in org.apache.bookkeeper.proto
A Bookie request object.
BookieProtocol.Response - Class in org.apache.bookkeeper.proto
A response object.
BookieProtoEncoding - Class in org.apache.bookkeeper.proto
A class for encoding and decoding the Bookkeeper protocol.
BookieProtoEncoding() - Constructor for class org.apache.bookkeeper.proto.BookieProtoEncoding
 
BookieProtoEncoding.EnDecoder - Interface in org.apache.bookkeeper.proto
An encoder/decoder interface for the Bookkeeper protocol.
BookieProtoEncoding.RequestDecoder - Class in org.apache.bookkeeper.proto
A request message decoder.
BookieProtoEncoding.RequestEncoder - Class in org.apache.bookkeeper.proto
A request message encoder.
BookieProtoEncoding.RequestEnDeCoderPreV3 - Class in org.apache.bookkeeper.proto
An encoder/decoder for the Bookkeeper protocol before version 3.
BookieProtoEncoding.RequestEnDecoderV3 - Class in org.apache.bookkeeper.proto
A request encoder/decoder for the Bookkeeper protocol version 3.
BookieProtoEncoding.ResponseDecoder - Class in org.apache.bookkeeper.proto
A response message decoder.
BookieProtoEncoding.ResponseEncoder - Class in org.apache.bookkeeper.proto
A response message encoder.
BookieProtoEncoding.ResponseEnDeCoderPreV3 - Class in org.apache.bookkeeper.proto
A response encoder/decoder for the Bookkeeper protocol before version 3.
BookieProtoEncoding.ResponseEnDecoderV3 - Class in org.apache.bookkeeper.proto
A response encoder/decoder for the Bookkeeper protocol version 3.
bookieReadonlyRegistrationPath - Variable in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
bookieRegistrationPath - Variable in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
BookieRequestHandler - Class in org.apache.bookkeeper.proto
Serverside handler for bookkeeper requests.
BookieRequestHandler(ServerConfiguration, RequestProcessor, ChannelGroup) - Constructor for class org.apache.bookkeeper.proto.BookieRequestHandler
 
BookieRequestProcessor - Class in org.apache.bookkeeper.proto
An implementation of the RequestProcessor interface.
BookieRequestProcessor(ServerConfiguration, Bookie, StatsLogger, SecurityHandlerFactory, ByteBufAllocator, ChannelGroup) - Constructor for class org.apache.bookkeeper.proto.BookieRequestProcessor
 
BookieResources - Class in org.apache.bookkeeper.bookie
Centralizes the creation of injected resources.
BookieResources() - Constructor for class org.apache.bookkeeper.bookie.BookieResources
 
BOOKIES_JOINED - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BOOKIES_LEFT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
BookieSanity() - Constructor for class org.apache.bookkeeper.server.http.service.BookieSanityService.BookieSanity
 
BookieSanityService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that exposes the bookie sanity state.
BookieSanityService(ServerConfiguration) - Constructor for class org.apache.bookkeeper.server.http.service.BookieSanityService
 
BookieSanityService.BookieSanity - Class in org.apache.bookkeeper.server.http.service
POJO definition for the bookie sanity response.
BookieSanityTestCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.BookieSanityTestCmd
 
bookieServer - Variable in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
bookieServer - Variable in class org.apache.bookkeeper.server.http.service.GCDetailsService
 
bookieServer - Variable in class org.apache.bookkeeper.server.http.service.ResumeCompactionService
 
bookieServer - Variable in class org.apache.bookkeeper.server.http.service.SuspendCompactionService
 
bookieServer - Variable in class org.apache.bookkeeper.server.http.service.TriggerGCService
 
BookieServer - Class in org.apache.bookkeeper.proto
Implements the server-side part of the BookKeeper protocol.
BookieServer(ServerConfiguration, Bookie, StatsLogger, ByteBufAllocator, UncleanShutdownDetection) - Constructor for class org.apache.bookkeeper.proto.BookieServer
 
BookieService - Class in org.apache.bookkeeper.server.service
A ServerLifecycleComponent that starts the core bookie server.
BookieService(BookieConfiguration, Bookie, StatsLogger, ByteBufAllocatorWithOomHandler, UncleanShutdownDetection) - Constructor for class org.apache.bookkeeper.server.service.BookieService
 
BookieServiceInfo - Class in org.apache.bookkeeper.discover
Information about services exposed by a Bookie.
BookieServiceInfo() - Constructor for class org.apache.bookkeeper.discover.BookieServiceInfo
 
BookieServiceInfo(Map<String, String>, List<BookieServiceInfo.Endpoint>) - Constructor for class org.apache.bookkeeper.discover.BookieServiceInfo
 
BookieServiceInfo.Endpoint - Class in org.apache.bookkeeper.discover
Information about an endpoint.
bookieServiceInfoProvider - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
BookieServiceInfoUtils - Class in org.apache.bookkeeper.discover
Utility class for BookieServiceInfo.
BookieServiceInfoUtils() - Constructor for class org.apache.bookkeeper.discover.BookieServiceInfoUtils
 
bookiesHealthInfo - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
BookiesHealthInfo - Interface in org.apache.bookkeeper.client
This interface returns heuristics used to determine the health of a Bookkeeper server for read ordering.
BookieShell - Class in org.apache.bookkeeper.bookie
Bookie Shell is to provide utilities for users to administer a bookkeeper cluster.
BookieShell() - Constructor for class org.apache.bookkeeper.bookie.BookieShell
 
BookieShell(LedgerIdFormatter, EntryFormatter) - Constructor for class org.apache.bookkeeper.bookie.BookieShell
 
BookieShell.AutoRecoveryCmd - Class in org.apache.bookkeeper.bookie
Command for administration of autorecovery.
BookieShell.BookieFormatCmd - Class in org.apache.bookkeeper.bookie
Formats the local data present in current bookie server.
BookieShell.BookieInfoCmd - Class in org.apache.bookkeeper.bookie
 
BookieShell.BookieSanityTestCmd - Class in org.apache.bookkeeper.bookie
Command to run a bookie sanity test.
BookieShell.CheckDbLedgersIndexCmd - Class in org.apache.bookkeeper.bookie
Rebuild DbLedgerStorage ledgers index.
BookieShell.ClusterInfoCmd - Class in org.apache.bookkeeper.bookie
 
BookieShell.Command - Interface in org.apache.bookkeeper.bookie
BookieShell command.
BookieShell.ConvertToDbStorageCmd - Class in org.apache.bookkeeper.bookie
Convert bookie indexes from InterleavedStorage to DbLedgerStorage format.
BookieShell.ConvertToInterleavedStorageCmd - Class in org.apache.bookkeeper.bookie
Convert bookie indexes from DbLedgerStorage to InterleavedStorage format.
BookieShell.DecommissionBookieCmd - Class in org.apache.bookkeeper.bookie
Command to trigger AuditTask by resetting lostBookieRecoveryDelay and then make sure the ledgers stored in the bookie are properly replicated and Cookie of the decommissioned bookie should be deleted from metadata server.
BookieShell.DeleteLedgerCmd - Class in org.apache.bookkeeper.bookie
Command to delete a given ledger.
BookieShell.EndpointInfoCmd - Class in org.apache.bookkeeper.bookie
Command to retrieve remote bookie endpoint information.
BookieShell.ForceAuditorChecksCmd - Class in org.apache.bookkeeper.bookie
 
BookieShell.HelpCmd - Class in org.apache.bookkeeper.bookie
Command to print help message.
BookieShell.InitBookieCmd - Class in org.apache.bookkeeper.bookie
Initializes bookie, by making sure that the journalDir, ledgerDirs and indexDirs are empty and there is no registered Bookie with this BookieId.
BookieShell.InitNewCluster - Class in org.apache.bookkeeper.bookie
Initializes new cluster by creating required znodes for the cluster.
BookieShell.LastMarkCmd - Class in org.apache.bookkeeper.bookie
Command to print last log mark.
BookieShell.LedgerCmd - Class in org.apache.bookkeeper.bookie
Ledger Command Handles ledger related operations.
BookieShell.LedgerMetadataCmd - Class in org.apache.bookkeeper.bookie
Print the metadata for a ledger.
BookieShell.ListActiveLedgersCmd - Class in org.apache.bookkeeper.bookie
List active ledgers on entry log file.
BookieShell.ListBookiesCmd - Class in org.apache.bookkeeper.bookie
List available bookies.
BookieShell.ListDiskFilesCmd - Class in org.apache.bookkeeper.bookie
 
BookieShell.ListLedgersCmd - Class in org.apache.bookkeeper.bookie
Command to list all ledgers in the cluster.
BookieShell.ListUnderreplicatedCmd - Class in org.apache.bookkeeper.bookie
Command for listing underreplicated ledgers.
BookieShell.LocalConsistencyCheck - Class in org.apache.bookkeeper.bookie
Check local storage for inconsistencies.
BookieShell.LostBookieRecoveryDelayCmd - Class in org.apache.bookkeeper.bookie
Setter and Getter for LostBookieRecoveryDelay value (in seconds) in metadata store.
BookieShell.MetaFormatCmd - Class in org.apache.bookkeeper.bookie
Format the bookkeeper metadata present in zookeeper.
BookieShell.MyCommand - Class in org.apache.bookkeeper.bookie
 
BookieShell.NukeExistingCluster - Class in org.apache.bookkeeper.bookie
Nuke bookkeeper metadata of existing cluster in zookeeper.
BookieShell.QueryAutoRecoveryStatusCmd - Class in org.apache.bookkeeper.bookie
Command to query autorecovery status.
BookieShell.ReadJournalCmd - Class in org.apache.bookkeeper.bookie
Command to read journal files.
BookieShell.ReadLedgerEntriesCmd - Class in org.apache.bookkeeper.bookie
Command for reading ledger entries.
BookieShell.ReadLogCmd - Class in org.apache.bookkeeper.bookie
Command to read entry log files.
BookieShell.ReadLogMetadataCmd - Class in org.apache.bookkeeper.bookie
Command to print metadata of entrylog.
BookieShell.RebuildDbLedgerLocationsIndexCmd - Class in org.apache.bookkeeper.bookie
Rebuild DbLedgerStorage locations index.
BookieShell.RebuildDbLedgersIndexCmd - Class in org.apache.bookkeeper.bookie
Rebuild DbLedgerStorage ledgers index.
BookieShell.RecoverCmd - Class in org.apache.bookkeeper.bookie
Recover command for ledger data recovery for failed bookie.
BookieShell.RegenerateInterleavedStorageIndexFile - Class in org.apache.bookkeeper.bookie
Regenerate an index file for interleaved storage.
BookieShell.SimpleTestCmd - Class in org.apache.bookkeeper.bookie
Simple test to create a ledger and write to it.
BookieShell.TriggerAuditCmd - Class in org.apache.bookkeeper.bookie
Command to trigger AuditTask by resetting lostBookieRecoveryDelay to its current value.
BookieShell.UpdateBookieInLedgerCmd - Class in org.apache.bookkeeper.bookie
Update bookie into ledger command.
BookieShell.UpdateCookieCmd - Class in org.apache.bookkeeper.bookie
Update cookie command.
BookieShell.UpdateLedgerCmd - Class in org.apache.bookkeeper.bookie
Update ledger command.
BookieShell.UpdateLedgerNotifier - Interface in org.apache.bookkeeper.bookie
A facility for reporting update ledger progress.
BookieShell.WhatIsInstanceId - Class in org.apache.bookkeeper.bookie
Prints the instanceid of the cluster.
BookieShell.WhoIsAuditorCmd - Class in org.apache.bookkeeper.bookie
Print which node has the auditor lock.
BookieShellCommand<CliFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.cli.helpers
This is a util class that converts new cli command to old shell command.
BookieShellCommand(String, BKCommand<CliFlagsT>, CompositeConfiguration) - Constructor for class org.apache.bookkeeper.tools.cli.helpers.BookieShellCommand
 
BookieSideConnectionPeerContextHandler() - Constructor for class org.apache.bookkeeper.proto.BookieNettyServer.BookieSideConnectionPeerContextHandler
 
bookiesJoinedCounter - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
bookiesLeftCounter - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
BookiesListener - Interface in org.apache.bookkeeper.client
Listener for the available bookies changes.
BookieSocketAddress - Class in org.apache.bookkeeper.net
This is a data wrapper class that is an InetSocketAddress, it would use the hostname provided in constructors directly.
BookieSocketAddress(String) - Constructor for class org.apache.bookkeeper.net.BookieSocketAddress
 
BookieSocketAddress(String, int) - Constructor for class org.apache.bookkeeper.net.BookieSocketAddress
 
bookieSrc - Variable in class org.apache.bookkeeper.server.http.service.RecoveryBookieService.RecoveryRequestJsonBody
 
BookieState() - Constructor for class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
BookieStateManager - Class in org.apache.bookkeeper.bookie
An implementation of StateManager.
BookieStateManager(ServerConfiguration, RegistrationManager) - Constructor for class org.apache.bookkeeper.bookie.BookieStateManager
 
BookieStateManager(ServerConfiguration, StatsLogger, RegistrationManager, List<File>, Supplier<BookieId>, Supplier<BookieServiceInfo>) - Constructor for class org.apache.bookkeeper.bookie.BookieStateManager
 
BookieStateManager(ServerConfiguration, StatsLogger, RegistrationManager, LedgerDirsManager, Supplier<BookieServiceInfo>) - Constructor for class org.apache.bookkeeper.bookie.BookieStateManager
 
BookieStateReadOnlyService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handles readOnly state related http requests.
BookieStateReadOnlyService(Bookie) - Constructor for class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService
 
BookieStateReadOnlyService.ReadOnlyState - Class in org.apache.bookkeeper.server.http.service
The object represent the readOnly state.
BookieStateService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that exposes the current state of the bookie.
BookieStateService(Bookie) - Constructor for class org.apache.bookkeeper.server.http.service.BookieStateService
 
BookieStateService.BookieState - Class in org.apache.bookkeeper.server.http.service
POJO definition for the bookie state response.
BookieStats - Class in org.apache.bookkeeper.bookie.stats
A umbrella class for bookie related stats.
BookieStats(StatsLogger, int, int) - Constructor for class org.apache.bookkeeper.bookie.stats.BookieStats
 
BookieStatus - Class in org.apache.bookkeeper.bookie
The status object represents the current status of a bookie instance.
BookieStatus() - Constructor for class org.apache.bookkeeper.bookie.BookieStatus
 
BookieStatus.BookieMode - Enum in org.apache.bookkeeper.bookie
 
BookieThread - Class in org.apache.bookkeeper.bookie
Wrapper that wraps bookie threads.
BookieThread(Runnable, String) - Constructor for class org.apache.bookkeeper.bookie.BookieThread
 
BookieThread(String) - Constructor for class org.apache.bookkeeper.bookie.BookieThread
 
BookieUnauthorizedAccessException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.BookieUnauthorizedAccessException
 
BookieUnauthorizedAccessException(String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.BookieUnauthorizedAccessException
 
bookieWatcher - Variable in class org.apache.bookkeeper.client.BookKeeper
 
bookieWatcher - Variable in class org.apache.bookkeeper.client.LedgerChecker
 
BookieWatcher - Interface in org.apache.bookkeeper.client
Watch for Bookkeeper cluster status.
BookieWatcherImpl - Class in org.apache.bookkeeper.client
This class is responsible for maintaining a consistent view of what bookies are available by reading Zookeeper (and setting watches on the bookie nodes).
BookieWatcherImpl(ClientConfiguration, EnsemblePlacementPolicy, RegistrationClient, BookieAddressResolver, StatsLogger) - Constructor for class org.apache.bookkeeper.client.BookieWatcherImpl
 
BookKeeper - Class in org.apache.bookkeeper.client
BookKeeper client.
BookKeeper - Interface in org.apache.bookkeeper.client.api
This is the entry point for BookKeeper client side API.
BookKeeper() - Constructor for class org.apache.bookkeeper.client.BookKeeper
Allow to extend BookKeeper for mocking in unit tests.
BookKeeper(String) - Constructor for class org.apache.bookkeeper.client.BookKeeper
Create a bookkeeper client.
BookKeeper(ClientConfiguration) - Constructor for class org.apache.bookkeeper.client.BookKeeper
Create a bookkeeper client using a configuration object.
BookKeeper(ClientConfiguration, ZooKeeper) - Constructor for class org.apache.bookkeeper.client.BookKeeper
Create a bookkeeper client but use the passed in zookeeper client instead of instantiating one.
BookKeeper(ClientConfiguration, ZooKeeper, EventLoopGroup) - Constructor for class org.apache.bookkeeper.client.BookKeeper
Create a bookkeeper client but use the passed in zookeeper client and client event loop group instead of instantiating those.
BookKeeper(ClientConfiguration, ZooKeeper, EventLoopGroup, ByteBufAllocator, StatsLogger, DNSToSwitchMapping, HashedWheelTimer, FeatureProvider) - Constructor for class org.apache.bookkeeper.client.BookKeeper
Constructor for use with the builder.
BookKeeper.Builder - Class in org.apache.bookkeeper.client
BookKeeper Client Builder to build client instances.
BookKeeper.DigestType - Enum in org.apache.bookkeeper.client
There are 3 digest types that can be used for verification.
BookKeeperAdmin - Class in org.apache.bookkeeper.client
Admin client for BookKeeper clusters.
BookKeeperAdmin(String) - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin
Constructor that takes in a ZooKeeper servers connect string so we know how to connect to ZooKeeper to retrieve information about the BookKeeper cluster.
BookKeeperAdmin(BookKeeper) - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin
 
BookKeeperAdmin(BookKeeper, ClientConfiguration) - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin
 
BookKeeperAdmin(BookKeeper, StatsLogger, ClientConfiguration) - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin
Constructor that takes in a BookKeeper instance .
BookKeeperAdmin(ClientConfiguration) - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin
Constructor that takes in a configuration object so we know how to connect to ZooKeeper to retrieve information about the BookKeeper cluster.
BookKeeperAdmin.LedgerEntriesIterable - Class in org.apache.bookkeeper.client
 
BookKeeperAdmin.LedgerEntriesIterator - Class in org.apache.bookkeeper.client
 
BookKeeperAdmin.ResultCallBack - Class in org.apache.bookkeeper.client
This is the class for getting the replication result.
BookKeeperAdmin.SyncObject - Class in org.apache.bookkeeper.client
 
BookKeeperBuilder - Interface in org.apache.bookkeeper.client.api
BookKeeper Client Builder to build client instances.
BookKeeperBuilderImpl - Class in org.apache.bookkeeper.client.impl
Internal builder for BookKeeper client.
BookKeeperBuilderImpl(ClientConfiguration) - Constructor for class org.apache.bookkeeper.client.impl.BookKeeperBuilderImpl
 
BookKeeperClientStats - Interface in org.apache.bookkeeper.client
List of constants for defining client stats names.
BookKeeperClientStatsImpl - Class in org.apache.bookkeeper.client.impl
The default implementation of BookKeeperClientStats.
BookKeeperClientStatsImpl(StatsLogger) - Constructor for class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
BookKeeperConstants - Class in org.apache.bookkeeper.util
This class contains constants used in BookKeeper.
BookKeeperConstants() - Constructor for class org.apache.bookkeeper.util.BookKeeperConstants
 
BookkeeperInternalCallbacks - Class in org.apache.bookkeeper.proto
Declaration of a callback interfaces used in bookkeeper client library but not exposed to the client application.
BookkeeperInternalCallbacks() - Constructor for class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks
 
BookkeeperInternalCallbacks.BatchedReadEntryCallback - Interface in org.apache.bookkeeper.proto
Declaration of a callback implementation for calls from BookieClient objects.
BookkeeperInternalCallbacks.ForceLedgerCallback - Interface in org.apache.bookkeeper.proto
Force callback interface.
BookkeeperInternalCallbacks.FutureGetListOfEntriesOfLedger - Class in org.apache.bookkeeper.proto
Future for GetListOfEntriesOfLedger.
BookkeeperInternalCallbacks.GenericCallback<T> - Interface in org.apache.bookkeeper.proto
A generic callback interface.
BookkeeperInternalCallbacks.GenericCallbackFuture<T> - Class in org.apache.bookkeeper.proto
Generic callback future.
BookkeeperInternalCallbacks.GetBookieInfoCallback - Interface in org.apache.bookkeeper.proto
This is a callback interface for fetching metadata about a bookie.
BookkeeperInternalCallbacks.GetListOfEntriesOfLedgerCallback - Interface in org.apache.bookkeeper.proto
A callback interface for GetListOfEntriesOfLedger command.
BookkeeperInternalCallbacks.LedgerMetadataListener - Interface in org.apache.bookkeeper.proto
Listener on ledger metadata changes.
BookkeeperInternalCallbacks.MultiCallback - Class in org.apache.bookkeeper.proto
This is a multi callback object that waits for all of the multiple async operations to complete.
BookkeeperInternalCallbacks.Processor<T> - Interface in org.apache.bookkeeper.proto
Processor to process a specific element.
BookkeeperInternalCallbacks.ReadEntryCallback - Interface in org.apache.bookkeeper.proto
Declaration of a callback implementation for calls from BookieClient objects.
BookkeeperInternalCallbacks.ReadEntryCallbackCtx - Interface in org.apache.bookkeeper.proto
Declaration of a callback interface for the Last Add Confirmed context of a reader.
BookkeeperInternalCallbacks.ReadEntryListener - Interface in org.apache.bookkeeper.proto
Listener on entries responded.
BookkeeperInternalCallbacks.ReadLacCallback - Interface in org.apache.bookkeeper.proto
A last-add-confirmed (LAC) reader callback interface.
BookkeeperInternalCallbacks.StartTLSCallback - Interface in org.apache.bookkeeper.proto
A callback interface for a STARTTLS command.
BookkeeperInternalCallbacks.TimedGenericCallback<T> - Class in org.apache.bookkeeper.proto
A callback implementation with an internal timer.
BookkeeperInternalCallbacks.WriteCallback - Interface in org.apache.bookkeeper.proto
A writer callback interface.
BookkeeperInternalCallbacks.WriteLacCallback - Interface in org.apache.bookkeeper.proto
A last-add-confirmed (LAC) writer callback interface.
BookKeeperPrincipal - Class in org.apache.bookkeeper.auth
A Principal is the user bound to the connection.
BookKeeperPrincipal(String) - Constructor for class org.apache.bookkeeper.auth.BookKeeperPrincipal
 
BookkeeperProtocol - Class in org.apache.bookkeeper.proto
 
BookkeeperProtocol.AddRequest - Class in org.apache.bookkeeper.proto
Protobuf type AddRequest
BookkeeperProtocol.AddRequest.Builder - Class in org.apache.bookkeeper.proto
Protobuf type AddRequest
BookkeeperProtocol.AddRequest.Flag - Enum in org.apache.bookkeeper.proto
Protobuf enum AddRequest.Flag
BookkeeperProtocol.AddRequestOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.AddResponse - Class in org.apache.bookkeeper.proto
Protobuf type AddResponse
BookkeeperProtocol.AddResponse.Builder - Class in org.apache.bookkeeper.proto
Protobuf type AddResponse
BookkeeperProtocol.AddResponseOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.AuthMessage - Class in org.apache.bookkeeper.proto
Protobuf type AuthMessage
BookkeeperProtocol.AuthMessage.Builder - Class in org.apache.bookkeeper.proto
Protobuf type AuthMessage
BookkeeperProtocol.AuthMessageOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.BKPacketHeader - Class in org.apache.bookkeeper.proto
Packet header for all requests.
BookkeeperProtocol.BKPacketHeader.Builder - Class in org.apache.bookkeeper.proto
Packet header for all requests.
BookkeeperProtocol.BKPacketHeaderOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.ContextPair - Class in org.apache.bookkeeper.proto
Protobuf type ContextPair
BookkeeperProtocol.ContextPair.Builder - Class in org.apache.bookkeeper.proto
Protobuf type ContextPair
BookkeeperProtocol.ContextPairOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.ForceLedgerRequest - Class in org.apache.bookkeeper.proto
Protobuf type ForceLedgerRequest
BookkeeperProtocol.ForceLedgerRequest.Builder - Class in org.apache.bookkeeper.proto
Protobuf type ForceLedgerRequest
BookkeeperProtocol.ForceLedgerRequestOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.ForceLedgerResponse - Class in org.apache.bookkeeper.proto
Protobuf type ForceLedgerResponse
BookkeeperProtocol.ForceLedgerResponse.Builder - Class in org.apache.bookkeeper.proto
Protobuf type ForceLedgerResponse
BookkeeperProtocol.ForceLedgerResponseOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.GetBookieInfoRequest - Class in org.apache.bookkeeper.proto
Protobuf type GetBookieInfoRequest
BookkeeperProtocol.GetBookieInfoRequest.Builder - Class in org.apache.bookkeeper.proto
Protobuf type GetBookieInfoRequest
BookkeeperProtocol.GetBookieInfoRequest.Flags - Enum in org.apache.bookkeeper.proto
Protobuf enum GetBookieInfoRequest.Flags
BookkeeperProtocol.GetBookieInfoRequestOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.GetBookieInfoResponse - Class in org.apache.bookkeeper.proto
Protobuf type GetBookieInfoResponse
BookkeeperProtocol.GetBookieInfoResponse.Builder - Class in org.apache.bookkeeper.proto
Protobuf type GetBookieInfoResponse
BookkeeperProtocol.GetBookieInfoResponseOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.GetListOfEntriesOfLedgerRequest - Class in org.apache.bookkeeper.proto
Protobuf type GetListOfEntriesOfLedgerRequest
BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder - Class in org.apache.bookkeeper.proto
Protobuf type GetListOfEntriesOfLedgerRequest
BookkeeperProtocol.GetListOfEntriesOfLedgerRequestOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.GetListOfEntriesOfLedgerResponse - Class in org.apache.bookkeeper.proto
Protobuf type GetListOfEntriesOfLedgerResponse
BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder - Class in org.apache.bookkeeper.proto
Protobuf type GetListOfEntriesOfLedgerResponse
BookkeeperProtocol.GetListOfEntriesOfLedgerResponseOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.OperationType - Enum in org.apache.bookkeeper.proto
Supported operations by this protocol.
BookkeeperProtocol.ProtocolVersion - Enum in org.apache.bookkeeper.proto
Protocol Versions.
BookkeeperProtocol.ReadLacRequest - Class in org.apache.bookkeeper.proto
Protobuf type ReadLacRequest
BookkeeperProtocol.ReadLacRequest.Builder - Class in org.apache.bookkeeper.proto
Protobuf type ReadLacRequest
BookkeeperProtocol.ReadLacRequestOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.ReadLacResponse - Class in org.apache.bookkeeper.proto
Protobuf type ReadLacResponse
BookkeeperProtocol.ReadLacResponse.Builder - Class in org.apache.bookkeeper.proto
Protobuf type ReadLacResponse
BookkeeperProtocol.ReadLacResponseOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.ReadRequest - Class in org.apache.bookkeeper.proto
Protobuf type ReadRequest
BookkeeperProtocol.ReadRequest.Builder - Class in org.apache.bookkeeper.proto
Protobuf type ReadRequest
BookkeeperProtocol.ReadRequest.Flag - Enum in org.apache.bookkeeper.proto
Protobuf enum ReadRequest.Flag
BookkeeperProtocol.ReadRequestOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.ReadResponse - Class in org.apache.bookkeeper.proto
Protobuf type ReadResponse
BookkeeperProtocol.ReadResponse.Builder - Class in org.apache.bookkeeper.proto
Protobuf type ReadResponse
BookkeeperProtocol.ReadResponseOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.Request - Class in org.apache.bookkeeper.proto
Protobuf type Request
BookkeeperProtocol.Request.Builder - Class in org.apache.bookkeeper.proto
Protobuf type Request
BookkeeperProtocol.RequestOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.Response - Class in org.apache.bookkeeper.proto
Protobuf type Response
BookkeeperProtocol.Response.Builder - Class in org.apache.bookkeeper.proto
Protobuf type Response
BookkeeperProtocol.ResponseOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.StartTLSRequest - Class in org.apache.bookkeeper.proto
Protobuf type StartTLSRequest
BookkeeperProtocol.StartTLSRequest.Builder - Class in org.apache.bookkeeper.proto
Protobuf type StartTLSRequest
BookkeeperProtocol.StartTLSRequestOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.StartTLSResponse - Class in org.apache.bookkeeper.proto
Protobuf type StartTLSResponse
BookkeeperProtocol.StartTLSResponse.Builder - Class in org.apache.bookkeeper.proto
Protobuf type StartTLSResponse
BookkeeperProtocol.StartTLSResponseOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.StatusCode - Enum in org.apache.bookkeeper.proto
Status codes.
BookkeeperProtocol.WriteLacRequest - Class in org.apache.bookkeeper.proto
Protobuf type WriteLacRequest
BookkeeperProtocol.WriteLacRequest.Builder - Class in org.apache.bookkeeper.proto
Protobuf type WriteLacRequest
BookkeeperProtocol.WriteLacRequestOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookkeeperProtocol.WriteLacResponse - Class in org.apache.bookkeeper.proto
Protobuf type WriteLacResponse
BookkeeperProtocol.WriteLacResponse.Builder - Class in org.apache.bookkeeper.proto
Protobuf type WriteLacResponse
BookkeeperProtocol.WriteLacResponseOrBuilder - Interface in org.apache.bookkeeper.proto
 
BookKeeperServerStats - Interface in org.apache.bookkeeper.bookie
A utility class used for managing the stats constants used in server side.
BookkeeperVerifier - Class in org.apache.bookkeeper.verifier
Encapsulates logic for playing and verifying operations against a bookkeeper-like interface.
BookkeeperVerifier(BookkeeperVerifier.BookkeeperDriver, int, int, int, int, int, int, int, int, int, int, long, int, int, double) - Constructor for class org.apache.bookkeeper.verifier.BookkeeperVerifier
 
BookkeeperVerifier.BookkeeperDriver - Interface in org.apache.bookkeeper.verifier
Provides an interface for translating test operations into operations on a cluster.
BookkeeperVerifier.BookkeeperDriver.ReadCallback - Interface in org.apache.bookkeeper.verifier
Callback for reads.
BookkeeperVerifier.EntryInfo - Class in org.apache.bookkeeper.verifier
State required to regenerate an entry.
BookkeeperVerifier.LedgerInfo - Class in org.apache.bookkeeper.verifier
Contains the state required to reconstruct the contents of any entry in the ledger.
BookkeeperVerifier.LedgerInfo.EntryIterator - Class in org.apache.bookkeeper.verifier
 
BookkeeperVerifier.WriteCallback - Class in org.apache.bookkeeper.verifier
 
BookkeeperVerifierMain - Class in org.apache.bookkeeper.verifier
Performs a configurable IO stream against a bookkeeper client while validating results.
BookkeeperVerifierMain() - Constructor for class org.apache.bookkeeper.verifier.BookkeeperVerifierMain
 
BOOLEAN - org.apache.bookkeeper.common.conf.Type
 
BoundedExecutorService - Class in org.apache.bookkeeper.common.util
Implements ExecutorService and allows limiting the number of tasks to be scheduled in the thread's queue.
BoundedExecutorService(ThreadPoolExecutor, int) - Constructor for class org.apache.bookkeeper.common.util.BoundedExecutorService
 
BoundedScheduledExecutorService - Class in org.apache.bookkeeper.common.util
Implements ListeningScheduledExecutorService and allows limiting the number of tasks to be scheduled in the thread's queue.
BoundedScheduledExecutorService(ScheduledThreadPoolExecutor, int) - Constructor for class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
BoundExponentialBackoffRetryPolicy - Class in org.apache.bookkeeper.zookeeper
Retry policy that retries a set number of times with an increasing (up to a maximum bound) backoff time between retries.
BoundExponentialBackoffRetryPolicy(long, long, int) - Constructor for class org.apache.bookkeeper.zookeeper.BoundExponentialBackoffRetryPolicy
 
BroadCastStatsLogger - Class in org.apache.bookkeeper.common.stats
Stats Loggers that broadcast stats to multiple StatsLogger.
BroadCastStatsLogger() - Constructor for class org.apache.bookkeeper.common.stats.BroadCastStatsLogger
 
BroadCastStatsLogger.MasterSlave - Class in org.apache.bookkeeper.common.stats
 
BroadCastStatsLogger.Two - Class in org.apache.bookkeeper.common.stats
 
buffer - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
buffer() - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorImpl
 
buffer(int) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorImpl
 
buffer(int, int) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorImpl
 
Buffer - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
A utility buffer class to be used with native calls.
Buffer(NativeIO, ByteBufAllocator, int) - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
BufferedChannel - Class in org.apache.bookkeeper.bookie
Provides a buffering layer in front of a FileChannel.
BufferedChannel(ByteBufAllocator, FileChannel, int) - Constructor for class org.apache.bookkeeper.bookie.BufferedChannel
 
BufferedChannel(ByteBufAllocator, FileChannel, int, int, long) - Constructor for class org.apache.bookkeeper.bookie.BufferedChannel
 
BufferedChannel(ByteBufAllocator, FileChannel, int, long) - Constructor for class org.apache.bookkeeper.bookie.BufferedChannel
 
BufferedChannelBase - Class in org.apache.bookkeeper.bookie
A BufferedChannelBase adds functionality to an existing file channel, the ability to buffer the input and output data.
BufferedChannelBase(FileChannel) - Constructor for class org.apache.bookkeeper.bookie.BufferedChannelBase
 
BufferedChannelBase.BufferedChannelClosedException - Exception in org.apache.bookkeeper.bookie
 
BufferedChannelClosedException() - Constructor for exception org.apache.bookkeeper.bookie.BufferedChannelBase.BufferedChannelClosedException
 
BufferedLogChannel(ByteBufAllocator, FileChannel, int, int, long, File, long) - Constructor for class org.apache.bookkeeper.bookie.DefaultEntryLogger.BufferedLogChannel
 
BufferedReadChannel - Class in org.apache.bookkeeper.bookie
A Buffered channel without a write buffer.
BufferedReadChannel(FileChannel, int) - Constructor for class org.apache.bookkeeper.bookie.BufferedReadChannel
 
BufferedReadChannel(FileChannel, int, boolean) - Constructor for class org.apache.bookkeeper.bookie.BufferedReadChannel
 
bufferLock - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
bufferPool - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
BufferPool - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
BufferPool used to manage Buffers.
BufferPool(NativeIO, ByteBufAllocator, int, int) - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.BufferPool
 
bufferSize - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
build() - Method in class org.apache.bookkeeper.bookie.Cookie.Builder
 
build() - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
build() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
build() - Method in interface org.apache.bookkeeper.client.api.BookKeeperBuilder
Start and initialize a new BookKeeper client.
build() - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
 
build() - Method in class org.apache.bookkeeper.client.impl.BookKeeperBuilderImpl
 
build() - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
build() - Method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorBuilder
Finalize the configured ByteBufAllocator.
build() - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
build() - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack.Builder
 
build() - Method in class org.apache.bookkeeper.common.conf.ConfigDef.Builder
 
build() - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
 
build() - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup.ConfigKeyGroupBuilder
 
build() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
build() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.Builder
 
build() - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.SchedulerBuilder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
build() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
build() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
build() - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
Build the bookie server.
build() - Method in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
build() - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
build() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
build() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
build() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
build() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
build() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
build() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
build() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
buildAddResponse(BookieProtocol.Request) - Static method in class org.apache.bookkeeper.proto.ResponseBuilder
 
buildAutoRecoveryServer(BookieConfiguration) - Static method in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
buildBatchedReadResponse(ByteBufList, BookieProtocol.BatchedReadRequest) - Static method in class org.apache.bookkeeper.proto.ResponseBuilder
 
buildBookieServer(BookieConfiguration) - Static method in class org.apache.bookkeeper.server.Main
Build the bookie server.
builder() - Static method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
builder() - Static method in class org.apache.bookkeeper.common.conf.ConfigDef
Create a builder to build a config def.
builder(String) - Static method in class org.apache.bookkeeper.common.conf.ConfigKey
Build a config key of name.
builder(String) - Static method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
Create a config key group of name.
builder(BookieConfiguration) - Static method in class org.apache.bookkeeper.server.EmbeddedServer
Create a new builder from given configuration.
Builder() - Constructor for class org.apache.bookkeeper.common.util.OrderedExecutor.Builder
 
Builder() - Constructor for class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
Builder() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
Builder() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
Builder() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
Builder() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
Builder() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
Builder() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
Builder(ClientConfiguration) - Constructor for class org.apache.bookkeeper.client.BookKeeper.Builder
 
buildErrorResponse(int, BookieProtocol.Request) - Static method in class org.apache.bookkeeper.proto.ResponseBuilder
 
buildLegacyBookieServiceInfo(String) - Static method in class org.apache.bookkeeper.discover.BookieServiceInfoUtils
Creates a default legacy bookie info implementation.
buildPartial() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
buildPartial() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
buildReadResponse(ByteBuf, BookieProtocol.Request) - Static method in class org.apache.bookkeeper.proto.ResponseBuilder
 
buildReadResponse(ReferenceCounted) - Method in class org.apache.bookkeeper.proto.BatchedReadEntryProcessor
 
buildReadResponse(ReferenceCounted) - Method in class org.apache.bookkeeper.proto.ReadEntryProcessor
 
buildResponse(BookkeeperProtocol.ReadResponse.Builder, BookkeeperProtocol.StatusCode, Stopwatch) - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
BusyWait - Class in org.apache.bookkeeper.common.collections
Utility class to use "Thread.onSpinWait()" when available.
BYTEBUF_ALLOCATOR_SIZE_INITIAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
BYTEBUF_ALLOCATOR_SIZE_MAX - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
BYTEBUF_ALLOCATOR_SIZE_MIN - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ByteBufAllocatorBuilder - Interface in org.apache.bookkeeper.common.allocator
Builder object to customize a ByteBuf allocator.
ByteBufAllocatorBuilderImpl - Class in org.apache.bookkeeper.common.allocator.impl
Implementation of ByteBufAllocatorBuilder.
ByteBufAllocatorBuilderImpl() - Constructor for class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
ByteBufAllocatorImpl - Class in org.apache.bookkeeper.common.allocator.impl
Implementation of ByteBufAllocator.
ByteBufAllocatorImpl(ByteBufAllocator, ByteBufAllocator, PoolingPolicy, int, OutOfMemoryPolicy, Consumer<OutOfMemoryError>, LeakDetectionPolicy) - Constructor for class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorImpl
 
ByteBufAllocatorImpl(ByteBufAllocator, ByteBufAllocator, PoolingPolicy, int, OutOfMemoryPolicy, Consumer<OutOfMemoryError>, LeakDetectionPolicy, boolean) - Constructor for class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorImpl
 
ByteBufAllocatorWithOomHandler - Interface in org.apache.bookkeeper.common.allocator
A ByteBufAllocatr interface with a OOM handler.
byteBuffer - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
ByteBufList - Class in org.apache.bookkeeper.util
ByteBufList is a holder of a sequence of ByteBuf objects.
ByteBufList.Encoder - Class in org.apache.bookkeeper.util
ByteBufList encoder.
byteBufListToByteString(ByteBufList) - Static method in class org.apache.bookkeeper.proto.ByteStringUtil
Wrap the internal buffers of a ByteBufList into a single ByteString.
byteBufToByteString(ByteBuf) - Static method in class org.apache.bookkeeper.proto.ByteStringUtil
Wrap the internal buffers of a ByteBuf into a single ByteString.
ByteBufVisitor - Class in org.apache.bookkeeper.util
This class visits the possible wrapped child buffers of a Netty ByteBuf for a given offset and length.
ByteBufVisitor.ByteBufVisitorCallback<T> - Interface in org.apache.bookkeeper.util
The callback interface for visiting buffers.
ByteBufVisitor.GetBytesCallbackByteBuf<T> - Class in org.apache.bookkeeper.util
A ByteBuf implementation that can be used as the destination buffer for a ByteBuf.getBytes(int, ByteBuf) for visiting the wrapped child buffers.
bytes2Hex(byte[]) - Static method in class org.apache.bookkeeper.tools.cli.commands.bookie.FormatUtil
 
bytesBefore(byte) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
bytesBefore(int, byte) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
bytesBefore(int, int, byte) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
ByteStringUtil - Class in org.apache.bookkeeper.proto
 
ByteStringUtil() - Constructor for class org.apache.bookkeeper.proto.ByteStringUtil
 

C

CacheableFeatureProvider<T extends Feature> - Class in org.apache.bookkeeper.feature
Cacheable Feature Provider.
CacheableFeatureProvider(String) - Constructor for class org.apache.bookkeeper.feature.CacheableFeatureProvider
 
CacheCallback - Interface in org.apache.bookkeeper.bookie
Interface plugged into caching to receive callback notifications.
CachedDNSToSwitchMapping - Class in org.apache.bookkeeper.net
A cached implementation of DNSToSwitchMapping that takes an raw DNSToSwitchMapping and stores the resolved network location in a cache.
CachedDNSToSwitchMapping(DNSToSwitchMapping) - Constructor for class org.apache.bookkeeper.net.CachedDNSToSwitchMapping
Cache a raw DNS mapping.
CachedFileInfo(long, File, byte[]) - Constructor for class org.apache.bookkeeper.bookie.FileInfoBackingCache.CachedFileInfo
 
cachedNodes - Variable in class org.apache.bookkeeper.util.SubTreeCache
 
cacheHitCount - Variable in class org.apache.bookkeeper.bookie.BufferedReadChannel
 
CachingStatsLogger - Class in org.apache.bookkeeper.stats
A StatsLogger that caches the stats objects created by other StatsLogger.
CachingStatsLogger(StatsLogger) - Constructor for class org.apache.bookkeeper.stats.CachingStatsLogger
 
CachingStatsProvider - Class in org.apache.bookkeeper.stats
A CachingStatsProvider adds the caching functionality to an existing StatsProvider.
CachingStatsProvider(StatsProvider) - Constructor for class org.apache.bookkeeper.stats.CachingStatsProvider
 
calculate(byte[]) - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
calculate(byte[]) - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
calculate(byte[]) - Method in class com.scurrilous.circe.impl.AbstractStatelessIntHash
 
calculate(byte[]) - Method in class com.scurrilous.circe.impl.AbstractStatelessLongHash
 
calculate(byte[]) - Method in class com.scurrilous.circe.impl.IntStatelessLongHash
 
calculate(byte[]) - Method in interface com.scurrilous.circe.StatelessIntHash
Evaluates this hash function for the entire given input array.
calculate(byte[]) - Method in interface com.scurrilous.circe.StatelessLongHash
Evaluates this hash function for the entire given input array.
calculate(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
calculate(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
calculate(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractStatelessIntHash
 
calculate(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractStatelessLongHash
 
calculate(byte[], int, int) - Method in class com.scurrilous.circe.impl.IntStatelessLongHash
 
calculate(byte[], int, int) - Method in interface com.scurrilous.circe.StatelessIntHash
Evaluates this hash function for the given range of the given input array.
calculate(byte[], int, int) - Method in interface com.scurrilous.circe.StatelessLongHash
Evaluates this hash function for the given range of the given input array.
calculate(long, long) - Method in class com.scurrilous.circe.crc.Sse42Crc32C
 
calculate(long, long) - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
calculate(long, long) - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
calculate(long, long) - Method in class com.scurrilous.circe.impl.AbstractStatelessIntHash
 
calculate(long, long) - Method in class com.scurrilous.circe.impl.AbstractStatelessLongHash
 
calculate(long, long) - Method in class com.scurrilous.circe.impl.IntStatelessLongHash
 
calculate(long, long) - Method in interface com.scurrilous.circe.StatelessIntHash
Evaluates this hash function for the memory with the given address and length.
calculate(long, long) - Method in interface com.scurrilous.circe.StatelessLongHash
Evaluates this hash function for the memory with the given address and length.
calculate(ByteBuf) - Method in interface com.scurrilous.circe.checksum.IntHash
 
calculate(ByteBuf) - Method in class com.scurrilous.circe.checksum.Java8IntHash
 
calculate(ByteBuf) - Method in class com.scurrilous.circe.checksum.Java9IntHash
 
calculate(ByteBuf) - Method in class com.scurrilous.circe.checksum.JniIntHash
 
calculate(ByteBuf, int, int) - Method in interface com.scurrilous.circe.checksum.IntHash
 
calculate(ByteBuf, int, int) - Method in class com.scurrilous.circe.checksum.Java8IntHash
 
calculate(ByteBuf, int, int) - Method in class com.scurrilous.circe.checksum.Java9IntHash
 
calculate(ByteBuf, int, int) - Method in class com.scurrilous.circe.checksum.JniIntHash
 
calculate(ByteBuffer) - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
calculate(ByteBuffer) - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
calculate(ByteBuffer) - Method in class com.scurrilous.circe.impl.AbstractStatelessIntHash
 
calculate(ByteBuffer) - Method in class com.scurrilous.circe.impl.AbstractStatelessLongHash
 
calculate(ByteBuffer) - Method in class com.scurrilous.circe.impl.IntStatelessLongHash
 
calculate(ByteBuffer) - Method in interface com.scurrilous.circe.StatelessIntHash
Evaluates this hash function with the remaining contents of the given input buffer.
calculate(ByteBuffer) - Method in interface com.scurrilous.circe.StatelessLongHash
Evaluates this hash function with the remaining contents of the given input buffer.
calculateUnchecked(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractStatelessIntHash
Evaluates this hash function for the given range of the given input array.
calculateUnchecked(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractStatelessLongHash
Evaluates this hash function for the given range of the given input array.
calculateUsageIndex(int, double) - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
Calculate the index for the batch based on the usage between 0 and 1.
call() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.ContextPreservingCallable
 
call() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.TimedCallable
 
call() - Method in interface org.apache.bookkeeper.zookeeper.ZooWorker.ZooCallable
Be compatible with ZooKeeper interface.
callable - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.TimedCallable
 
callableClass - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.TimedCallable
 
callbackExecutor - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
callbackTime - Variable in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
callbackTriggered - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
cancelledAcquire() - Method in class org.apache.bookkeeper.bookie.AbstractLogCompactor.Throttler
 
cancelSpeculativeTask(boolean) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
cancelSpeculativeTask(boolean) - Method in class org.apache.bookkeeper.client.ReadOpBase
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Cancel a previous wait for last add confirmed update.
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
cancelWaitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
cancelWaitForLastAddConfirmedUpdate(Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.FileInfo
 
cancelWaitForLastAddConfirmedUpdate(Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
cancelWaitForLastAddConfirmedUpdate(Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
cancelWaitForLastAddConfirmedUpdate(Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
cancelWatcher(Watcher) - Method in class org.apache.bookkeeper.util.SubTreeCache
Cancel a watcher (noop if not registered or already fired).
CancelWatchLedgerMetadataTask(long) - Constructor for class org.apache.bookkeeper.meta.AbstractZkLedgerManager.CancelWatchLedgerMetadataTask
 
canEqual(Object) - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
canEqual(Object) - Method in class org.apache.bookkeeper.common.conf.validators.ClassValidator
 
canEqual(Object) - Method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
 
canEqual(Object) - Method in class org.apache.bookkeeper.common.net.ServiceURI
 
canEqual(Object) - Method in class org.apache.bookkeeper.common.util.Backoff.Constant
 
canEqual(Object) - Method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
canEqual(Object) - Method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
canEqual(Object) - Method in class org.apache.bookkeeper.meta.LedgerLayout
 
canEqual(Object) - Method in class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
canEqual(Object) - Method in class org.apache.bookkeeper.server.http.service.BookieSanityService.BookieSanity
 
canEqual(Object) - Method in class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService.ReadOnlyState
 
canEqual(Object) - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
canEqual(Object) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
canEqual(Object) - Method in class org.apache.bookkeeper.stats.otel.ScopeContext
 
canEqual(Object) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
canEqual(Object) - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
canEqual(Object) - Method in class org.apache.bookkeeper.versioning.LongVersion
 
canEqual(Object) - Method in class org.apache.bookkeeper.versioning.Versioned
 
canMoveToClosed() - Method in class org.apache.bookkeeper.common.component.Lifecycle
 
canMoveToStarted() - Method in class org.apache.bookkeeper.common.component.Lifecycle
 
canMoveToStopped() - Method in class org.apache.bookkeeper.common.component.Lifecycle
 
capacity() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
capacity() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
capacity() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
capacity() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
capacity() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
capacity() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
capacity() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
capacity(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
category() - Method in annotation type org.apache.bookkeeper.stats.annotations.StatsDoc
The name of the category to group stats together.
category() - Method in class org.apache.bookkeeper.tools.framework.CliCommand
 
category() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
category() - Method in interface org.apache.bookkeeper.tools.framework.Command
Return category of this command belongs to.
CATEGORY_CLIENT - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CATEGORY_INFRA_SERVICE - Static variable in class org.apache.bookkeeper.tools.common.BKCommandCategories
 
CATEGORY_LEDGER_SERVICE - Static variable in class org.apache.bookkeeper.tools.common.BKCommandCategories
 
CATEGORY_SERVER - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
CATEGORY_TABLE_SERVICE - Static variable in class org.apache.bookkeeper.tools.common.BKCommandCategories
 
cb - Variable in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
cb - Variable in class org.apache.bookkeeper.client.ForceLedgerOp
 
cb - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
cb - Variable in class org.apache.bookkeeper.client.LedgerDeleteOp
 
cb - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
cb - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
cb - Variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
cb - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
cb - Variable in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
cb - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
cb - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.TimedGenericCallback
 
cb - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.BatchedReadCompletion
 
cb - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.ForceLedgerCompletion
 
cb - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.GetBookieInfoCompletion
 
cb - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.GetListOfEntriesOfLedgerCompletion
 
cb - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadCompletion
 
cb - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadLacCompletion
 
cb - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.StartTLSCompletion
 
cb - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.WriteLacCompletion
 
CertUtils - Class in org.apache.bookkeeper.util
Certificate parsing utilities.
CHANGED - org.apache.bookkeeper.metastore.MSWatchedEvent.EventType
 
changingEnsemble - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
channel - Variable in class org.apache.bookkeeper.bookie.JournalChannel
 
channel - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler.AuthRequestCallback
 
channel - Variable in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthResponseCallback
 
channel - Variable in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthResponseCallbackLegacy
 
channel - Variable in class org.apache.bookkeeper.proto.BookieNettyServer.BookieSideConnectionPeerContextHandler
 
channel - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
CHANNEL_ADD_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_FORCE_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_READ_LAC_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_READ_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_SCOPE - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_START_TLS_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_TIMEOUT_ADD - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_TIMEOUT_FORCE - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_TIMEOUT_READ - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_TIMEOUT_READ_LAC - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_TIMEOUT_START_TLS_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_TIMEOUT_WRITE_LAC - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CHANNEL_WRITE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
CHANNEL_WRITE_LAC_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
channelActive(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
channelActive(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler
 
channelActive(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.BookieNettyServer.BookieSideConnectionPeerContextHandler
 
channelActive(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.BookieRequestHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.BookieRequestHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
If our channel has disconnected, we just error out the pending entries.
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestDecoder
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseDecoder
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.bookkeeper.proto.BookieRequestHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
Called by netty when a message is received on a channel.
channelRegistered(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.BookieRequestHandler
 
channels - Variable in class org.apache.bookkeeper.proto.BookieClientImpl
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
channelWriteStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
chargeReadAheadCache(int, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
CHECK_ALL_LEDGERS_CTIME - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
CHECK_ALL_LEDGERS_TIME - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
checkAccess(byte[]) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
checkAccess(byte[]) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
checkAccess(byte[]) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorReadOnlyImpl
 
checkAllLedgers() - Method in class org.apache.bookkeeper.replication.AuditorCheckAllLedgersTask
List all the ledgers and check them individually.
CHECKALLLEDGERSCTIME_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
checkAndRecoverLedgerEntries(long, LedgerMetadata, String) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
Check whether the local storage has all the entries as specified in the metadata.
checkAndRecoverLedgers(Map<Long, LedgerMetadata>, String) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
Check each ledger passed.
checkAndRefresh() - Method in class org.apache.bookkeeper.tls.FileModifiedTimeUpdater
 
checkArgument(boolean, Object) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeUtils
 
checkCookies(List<File>) - Method in interface org.apache.bookkeeper.bookie.CookieValidation
 
checkCookies(List<File>) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCookieValidation
 
checkCookies(List<File>) - Method in class org.apache.bookkeeper.bookie.LegacyCookieValidation
 
checkCovered() - Method in interface org.apache.bookkeeper.client.DistributionSchedule.QuorumCoverageSet
check if all quorum in the set have had the action performed for it.
CheckDbLedgersIndexCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.CheckDbLedgersIndexCmd
 
CheckDBLedgersIndexCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to check the DBLedgerStorage ledgers index integrity.
CheckDBLedgersIndexCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.CheckDBLedgersIndexCommand
 
CheckDBLedgersIndexCommand(CheckDBLedgersIndexCommand.CheckLedgersIndexFlags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.CheckDBLedgersIndexCommand
 
CheckDBLedgersIndexCommand.CheckLedgersIndexFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for read log command.
checkDir(File) - Method in class org.apache.bookkeeper.util.DiskChecker
Create the directory if it doesn't exist.
checkDirectoryStructure(File) - Static method in class org.apache.bookkeeper.bookie.BookieImpl
 
checkDiskFull(File) - Method in class org.apache.bookkeeper.util.DiskChecker
Checks the disk space available.
checkEntry(long, long, long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
checkForFaultyBookies() - Method in class org.apache.bookkeeper.client.BookKeeper
 
checkLedger(LedgerHandle, BookkeeperInternalCallbacks.GenericCallback<Set<LedgerFragment>>) - Method in class org.apache.bookkeeper.client.LedgerChecker
Check that all the fragments in the passed in ledger, and report those which are missing.
checkLedger(LedgerHandle, BookkeeperInternalCallbacks.GenericCallback<Set<LedgerFragment>>, long) - Method in class org.apache.bookkeeper.client.LedgerChecker
 
CheckLedgersIndexFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.CheckDBLedgersIndexCommand.CheckLedgersIndexFlags
 
checkOpen(boolean) - Method in class org.apache.bookkeeper.bookie.FileInfo
 
checkpoint() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Flushes all rotated log channels.
checkpoint() - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
checkpoint() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
checkpoint() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
checkpoint(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
checkpoint(CheckpointSource.Checkpoint) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Ask the ledger storage to sync data until the given checkpoint.
checkpoint(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
checkpoint(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
checkpoint(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
checkpoint(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.SyncThread
 
checkpointComplete(CheckpointSource.Checkpoint, boolean) - Method in interface org.apache.bookkeeper.bookie.CheckpointSource
Tell checkpoint source that the checkpoint is completed.
checkpointComplete(CheckpointSource.Checkpoint, boolean) - Method in class org.apache.bookkeeper.bookie.CheckpointSourceList
 
checkpointComplete(CheckpointSource.Checkpoint, boolean) - Method in class org.apache.bookkeeper.bookie.Journal
Telling journal a checkpoint is finished.
checkpointer - Variable in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
Checkpointer - Interface in org.apache.bookkeeper.bookie
The instance that is responsible for checkpointing ledger storage.
checkpointSource - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 
checkpointSource - Variable in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
checkpointSource - Variable in class org.apache.bookkeeper.bookie.SyncThread
 
CheckpointSource - Interface in org.apache.bookkeeper.bookie
Interface to communicate checkpoint progress.
CheckpointSource.Checkpoint - Interface in org.apache.bookkeeper.bookie
A checkpoint presented a time point.
CheckpointSourceList - Class in org.apache.bookkeeper.bookie
A CheckpointSourceList manages a list of CheckpointSources.
CheckpointSourceList(List<? extends CheckpointSource>) - Constructor for class org.apache.bookkeeper.bookie.CheckpointSourceList
 
checkRegNodeAndWaitExpired(String) - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
Check existence of regPath and wait it expired if possible.
checkTimeoutOnPendingOperations() - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
checkTimeoutOnPendingOperations() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
checkTimeoutOnPendingOperations() - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientPool
Check if any ops on any channel needs to be timed out.
checkUnderReplicationForReplicasCheck(long, AsyncCallback.VoidCallback) - Method in class org.apache.bookkeeper.replication.AuditorReplicasCheckTask
 
children - Variable in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
 
children() - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
The list of sub key-groups of this key group.
children(List<String>) - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
The list of sub key-groups of this key group.
children(List<String>) - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup.ConfigKeyGroupBuilder
The list of sub key-groups of this key group.
chooseRandom(String) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Randomly choose one node from scope.
chooseThread() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
chooseThread() - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
 
chooseThread(long) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
skip hashcode generation in this special case.
chooseThread(long) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
 
chooseThread(Object) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
chooseThread(Object) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
 
chooseThreadIdx(long, int) - Static method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
chosenNodes - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
chunkSize - Variable in class org.apache.bookkeeper.bookie.SkipListArena
 
CLASS - org.apache.bookkeeper.common.conf.Type
 
ClassValidator<T> - Class in org.apache.bookkeeper.common.conf.validators
Validator that validates a configuration setting is returning a given type of class.
ClassValidator(Class<T>) - Constructor for class org.apache.bookkeeper.common.conf.validators.ClassValidator
 
clean(long) - Method in interface org.apache.bookkeeper.bookie.GarbageCollector.GarbageCleaner
Clean a specific ledger.
cleanDisconnectAndClose() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
cleanTable(MetastoreTable, int) - Static method in class org.apache.bookkeeper.metastore.MetastoreUtils
Clean the given table.
cleanUpAndRecover() - Method in class org.apache.bookkeeper.bookie.AbstractLogCompactor
Do nothing by default.
cleanUpAndRecover() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor
Delete all previously incomplete compacting logs and recover the index for compacted logs.
CleanupLedgerManager - Class in org.apache.bookkeeper.meta
A ledger manager that cleans up resources upon closing.
CleanupLedgerManager(LedgerManager) - Constructor for class org.apache.bookkeeper.meta.CleanupLedgerManager
 
clear() - Method in class org.apache.bookkeeper.bookie.BufferedChannel
 
clear() - Method in class org.apache.bookkeeper.bookie.BufferedReadChannel
 
clear() - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
clear() - Method in interface org.apache.bookkeeper.bookie.EntryLogMetadataMap
Clear all records from the map.
clear() - Method in class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
clear() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
clear() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage.Batch
 
clear() - Method in class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
 
clear() - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
clear() - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
clear() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
clear() - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
clear() - Method in class org.apache.bookkeeper.stats.codahale.CodahaleOpStatsLogger
 
clear() - Method in interface org.apache.bookkeeper.stats.Counter
Clear this stat.
clear() - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullCounter
 
clear() - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullOpStatsLogger
 
clear() - Method in interface org.apache.bookkeeper.stats.OpStatsLogger
Clear stats for this operation.
clear() - Method in class org.apache.bookkeeper.stats.otel.OtelCounter
 
clear() - Method in class org.apache.bookkeeper.stats.otel.OtelOpStatsLogger
 
clear() - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
clear() - Method in class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
 
clear() - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedDataSketchesStatsLogger
 
clear() - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedLongAdderCounter
 
clear() - Static method in class org.apache.bookkeeper.stats.ThreadRegistry
 
clear() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
clear() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
clear() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
clear() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
clear() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
clear() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
clear() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
clear() - Method in class org.apache.bookkeeper.util.HardLink.LinkStats
 
CLEAR_INTEGCHECK_FLAG - org.apache.bookkeeper.bookie.datainteg.Events
The NEEDS_INTEGRITY_CHECK will be cleared from the ledger storage.
CLEAR_LIMBO_ERROR - org.apache.bookkeeper.bookie.datainteg.Events
An error occurred while clearing the limbo flag for a ledger.
clearAckQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int32 ackQuorumSize = 9;
clearAddRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AddRequest addRequest = 101;
clearAddResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AddResponse addResponse = 101;
clearAuth() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string auth = 5;
clearAuthPluginName() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required string authPluginName = 1;
clearAuthRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AuthMessage authRequest = 102;
clearAuthResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AuthMessage authResponse = 102;
clearAvailabilityOfEntriesOfLedger() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
condensed encoded format representing availability of entries of ledger
clearBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required bytes body = 4;
clearBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
optional bytes body = 4;
clearBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required bytes body = 4;
clearBookieHost() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string bookieHost = 1;
clearBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
optional string bookieId = 1;
clearBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
optional string bookieId = 1;
clearCheckAllLedgersCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
optional int64 checkAllLedgersCTime = 1;
clearCompactingLogId() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
clearCompactingLogId() - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
clearCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 ctime = 10;
clearCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
optional int64 ctime = 2;
clearCToken() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 cToken = 12;
clearCurrentCtx() - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
clearCustomMetadata() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
clearDigestType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional .LedgerMetadataFormat.DigestType digestType = 7;
clearEndpoints() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
clearEnsembleMember() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
repeated string ensembleMember = 1;
clearEnsembleSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int32 ensembleSize = 2;
clearEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required int64 entryId = 2;
clearEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required int64 entryId = 3;
clearEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
entryId will be -1 for reading the LAST_ADD_CONFIRMED entry.
clearEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required int64 entryId = 3;
clearExists() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bool exists = 1;
clearExplicitLac() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
optional bytes explicitLac = 4;
clearExtensions() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string extensions = 6;
clearFenced() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bool fenced = 2;
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
clearFields() - Method in class org.apache.bookkeeper.metastore.Value
 
clearFirstEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
required int64 firstEntryId = 2;
clearFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
optional .AddRequest.Flag flag = 100;
clearFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
optional .ReadRequest.Flag flag = 100;
clearForceLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ForceLedgerRequest forceLedgerRequest = 107;
clearForceLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ForceLedgerResponse forceLedgerResponse = 107;
clearFreeDiskSpace() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
optional int64 freeDiskSpace = 3;
clearGetBookieInfoRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
clearGetBookieInfoResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
clearGetListOfEntriesOfLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
clearGetListOfEntriesOfLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
clearHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
required .BKPacketHeader header = 1;
clearHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
required .BKPacketHeader header = 1;
clearHost() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string host = 3;
clearId() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string id = 1;
clearIndexDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string indexDirs = 5;
clearInstanceId() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string instanceId = 4;
clearJournalDir() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string journalDir = 2;
clearKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string key = 1;
clearKey() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional string key = 1;
clearLac() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required int64 lac = 2;
clearLacBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
lac sent by PutLacRequest
clearLacUpdateTimestamp() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
optional int64 lacUpdateTimestamp = 6;
clearLastEntryBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
Actual last entry on the disk
clearLastEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 lastEntryId = 4;
clearLedgerDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string ledgerDirs = 3;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required int64 ledgerId = 1;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required int64 ledgerId = 2;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
required int64 ledgerId = 1;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
required int64 ledgerId = 2;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
required int64 ledgerId = 1;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
required int64 ledgerId = 2;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
required int64 ledgerId = 1;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
required int64 ledgerId = 2;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
required int64 ledgerId = 1;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required int64 ledgerId = 2;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required int64 ledgerId = 1;
clearLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
required int64 ledgerId = 2;
clearLength() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int64 length = 3;
clearLimbo() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
optional bool limbo = 5;
clearLimbo(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
clearLimboState(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
clearLimboState(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Clear the limbo state of a ledger.
clearLimboState(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
clearLimboState(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
clearLimboState(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
clearMasterKey() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bytes masterKey = 3;
clearMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required bytes masterKey = 3;
clearMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used while fencing a ledger.
clearMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required bytes masterKey = 3;
clearMaxLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
Piggyback LAC
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
clearOperation() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required .OperationType operation = 2;
clearPassword() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional bytes password = 8;
clearPayload() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required bytes payload = 2;
clearPlacementPolicyCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
optional int64 placementPolicyCheckCTime = 1;
clearPort() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required int32 port = 2;
clearPreviousLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used for waiting on last add confirmed update
clearPriority() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
optional uint32 priority = 4 [default = 0];
clearProperties() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
clearProperty(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
clearPropertyDirect(String) - Method in class org.apache.bookkeeper.common.conf.ConcurrentConfiguration
 
clearProtocol() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string protocol = 4;
clearQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int32 quorumSize = 1;
clearReadLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ReadLacRequest readLacRequest = 104;
clearReadLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ReadLacResponse readLacResponse = 104;
clearReadRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
Requests
clearReadResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
Response
clearReplica() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
repeated string replica = 1;
clearReplicasCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
optional int64 replicasCheckCTime = 1;
clearRequestContext() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
clearRequested() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
bitwise OR of Flags
clearSegment() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
clearSnapshot(EntryMemTable.EntrySkipList) - Method in class org.apache.bookkeeper.bookie.EntryMemTable
The passed snapshot was successfully persisted; it can be let go.
clearStartTLSRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .StartTLSRequest startTLSRequest = 106;
clearStartTLSResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .StartTLSResponse startTLSResponse = 106;
clearState() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required .LedgerMetadataFormat.State state = 5 [default = OPEN];
clearStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required .StatusCode status = 1;
clearStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
required .StatusCode status = 1;
clearStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
required .StatusCode status = 1;
clearStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
required .StatusCode status = 1;
clearStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
required .StatusCode status = 1;
clearStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required .StatusCode status = 1;
clearStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
EOK if the underlying request succeeded.
clearStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
required .StatusCode status = 1;
clearStorageStateFlag(LedgerStorage.StorageState) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
clearStorageStateFlag(LedgerStorage.StorageState) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Clear a storage state flag for the storage instance.
clearStorageStateFlag(LedgerStorage.StorageState) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
clearStorageStateFlag(LedgerStorage.StorageState) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
clearStorageStateFlag(LedgerStorage.StorageState) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
clearTimeOut() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used as a timeout (in milliseconds) for the long polling request
clearTotalDiskCapacity() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
optional int64 totalDiskCapacity = 2;
clearTxnId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required uint64 txnId = 3;
clearType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required string type = 1;
clearValue() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string value = 2;
clearValue() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional bytes value = 2;
clearVersion() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required .ProtocolVersion version = 1;
clearVersion() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required int32 version = 2;
clearWriteFlags() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
optional int32 writeFlags = 5;
clearWriteLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .WriteLacRequest writeLacRequest = 103;
clearWriteLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .WriteLacResponse writeLacResponse = 103;
Cli<CliFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.framework
Cli to execute CliSpec.
Cli(CliSpec<CliFlagsT>) - Constructor for class org.apache.bookkeeper.tools.framework.Cli
 
CliCommand<GlobalFlagsT extends CliFlags,​CommandFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.framework
A command that runs a CLI spec.
CliCommand(CliSpec<CommandFlagsT>) - Constructor for class org.apache.bookkeeper.tools.framework.CliCommand
 
CliCommandGroup<GlobalFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.framework
A command group that group commands together.
CliCommandGroup(CliSpec<GlobalFlagsT>) - Constructor for class org.apache.bookkeeper.tools.framework.CliCommandGroup
 
Client - org.apache.bookkeeper.tls.SecurityHandlerFactory.NodeType
 
CLIENT_AUTH_PROVIDER_FACTORY_CLASS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_CHANNEL_WRITE_WAIT - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CLIENT_CONNECT_BOOKIE_UNAVAILABLE_LOG_THROTTLING - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_CONNECT_TIMEOUT_MILLIS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_CONNECT_TIMER - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CLIENT_RECEIVEBUFFER_SIZE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_ROLE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_ROLE_STANDARD - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
This client will act as a standard client.
CLIENT_ROLE_SYSTEM - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
This client will act as a system client, like the Auditor.
CLIENT_SCOPE - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CLIENT_SENDBUFFER_SIZE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_SOCK_KEEPALIVE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_TCP_NODELAY - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_TCP_USER_TIMEOUT_MILLIS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_TLS_KEYSTORE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
CLIENT_TLS_KEYSTORE_PASSWORD_PATH - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
CLIENT_TLS_KEYSTORE_TYPE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
CLIENT_TLS_TRUSTSTORE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
CLIENT_TLS_TRUSTSTORE_PASSWORD_PATH - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
CLIENT_TLS_TRUSTSTORE_TYPE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
CLIENT_WRITEBUFFER_HIGH_WATER_MARK - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
CLIENT_WRITEBUFFER_LOW_WATER_MARK - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
ClientAuthProvider - Interface in org.apache.bookkeeper.auth
Client authentication provider interface.
ClientAuthProvider.Factory - Interface in org.apache.bookkeeper.auth
A factory to create the authentication providers for bookkeeper clients.
ClientCallbackHandler(String) - Constructor for class org.apache.bookkeeper.sasl.SaslClientState.ClientCallbackHandler
 
ClientClosedException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Executing operations on a closed client.
ClientCommand<ClientFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.cli.helpers
This is a mixin class for commands that needs a bookkeeper client.
ClientCommand(CliSpec<ClientFlagsT>) - Constructor for class org.apache.bookkeeper.tools.cli.helpers.ClientCommand
 
clientConf - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
ClientConfiguration - Class in org.apache.bookkeeper.conf
Configuration settings for client side.
ClientConfiguration() - Constructor for class org.apache.bookkeeper.conf.ClientConfiguration
Construct a default client-side configuration.
ClientConfiguration(AbstractConfiguration) - Constructor for class org.apache.bookkeeper.conf.ClientConfiguration
Construct a client-side configuration using a base configuration.
ClientConnectionPeer - Interface in org.apache.bookkeeper.proto
Represents the connection to a Bookie, from the client side.
ClientContext - Interface in org.apache.bookkeeper.client
Collection of client objects used by LedgerHandle to interact with the outside world.
clientCtx - Variable in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
clientCtx - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
clientCtx - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
clientCtx - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
clientCtx - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
clientCtx - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
ClientInternalConf - Class in org.apache.bookkeeper.client
 
clients - Variable in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
ClientSideHandler(ClientAuthProvider.Factory, AtomicLong, ClientConnectionPeer, boolean) - Constructor for class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
clientStats - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
clientsV3Enforced - Variable in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
CliFlags - Class in org.apache.bookkeeper.tools.framework
Default CLI Options.
CliFlags() - Constructor for class org.apache.bookkeeper.tools.framework.CliFlags
 
CliSpec<CliFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.framework
A spec to build CLI.
CliSpec.Builder<CliFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.framework
Builder to build a cli spec.
clone() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
clone() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
clone(ByteBufList) - Static method in class org.apache.bookkeeper.util.ByteBufList
Get a new ByteBufList instance from the pool that is the clone of an already existing instance.
cloneValue(Value, Version, Set<String>) - Static method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
close() - Method in interface org.apache.bookkeeper.auth.BookieAuthProvider
Release resources.
close() - Method in interface org.apache.bookkeeper.auth.BookieAuthProvider.Factory
Release resources.
close() - Method in interface org.apache.bookkeeper.auth.ClientAuthProvider
Release resources.
close() - Method in interface org.apache.bookkeeper.auth.ClientAuthProvider.Factory
Release resources.
close() - Method in interface org.apache.bookkeeper.bookie.BookieFileChannel
Close file channel and release all resources.
close() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
close() - Method in class org.apache.bookkeeper.bookie.BufferedChannel
 
close() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Shutdown method to gracefully stop entry logger.
close() - Method in class org.apache.bookkeeper.bookie.DefaultFileChannel
 
close() - Method in class org.apache.bookkeeper.bookie.DefaultFileChannelProvider
 
close() - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
close() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
close() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
close() - Method in class org.apache.bookkeeper.bookie.EntryMemTable
 
close() - Method in class org.apache.bookkeeper.bookie.EntryMemTableWithParallelFlusher
 
close() - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
close() - Method in class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
close() - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
close() - Method in class org.apache.bookkeeper.bookie.JournalChannel
 
close() - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
close() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
close() - Method in interface org.apache.bookkeeper.bookie.StateManager
Close the manager, release its resources.
close() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.BufferPool
 
close() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
close() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
close() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
close() - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogReader
 
close() - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogWriter
Close any held resources.
close() - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
 
close() - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
close() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
close() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
close() - Method in class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
 
close() - Method in class org.apache.bookkeeper.bookie.storage.ldb.ReadCache
 
close() - Method in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
close() - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
close() - Method in interface org.apache.bookkeeper.client.api.BookKeeper
Close the client and release every resource.
close() - Method in interface org.apache.bookkeeper.client.api.Handle
Close this handle synchronously.
close() - Method in interface org.apache.bookkeeper.client.api.LastConfirmedAndEntry
close() - Method in interface org.apache.bookkeeper.client.api.LedgerEntries
Close to release the resources held by this instance.
close() - Method in interface org.apache.bookkeeper.client.api.LedgerEntry
close() - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Synchronous close the write handle, any adds in flight will return errors.
close() - Method in class org.apache.bookkeeper.client.BookKeeper
Shuts down client.
close() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Gracefully release resources that this client uses.
close() - Method in class org.apache.bookkeeper.client.impl.LastConfirmedAndEntryImpl
close() - Method in class org.apache.bookkeeper.client.impl.LedgerEntriesImpl
 
close() - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
close() - Method in class org.apache.bookkeeper.client.LedgerHandle
Synchronous close the write handle, any adds in flight will return errors.
close() - Method in class org.apache.bookkeeper.client.PendingReadOp.SingleLedgerEntryRequest
 
close() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
close() - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
close() - Method in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
close() - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
close() - Method in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
close() - Method in interface org.apache.bookkeeper.common.component.LifecycleComponent
 
close() - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
close() - Method in interface org.apache.bookkeeper.discover.RegistrationClient
 
close() - Method in interface org.apache.bookkeeper.discover.RegistrationManager
 
close() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
close() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
close() - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
close() - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
close() - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
close() - Method in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
close() - Method in class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
close() - Method in interface org.apache.bookkeeper.meta.LedgerManagerFactory
Uninitialize the factory.
close() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Release all resources held by the ledger underreplication manager.
close() - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
close() - Method in class org.apache.bookkeeper.meta.LongZkLedgerIdGenerator
 
close() - Method in interface org.apache.bookkeeper.meta.MetadataBookieDriver
 
close() - Method in interface org.apache.bookkeeper.meta.MetadataClientDriver
 
close() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
close() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
close() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver
 
close() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerAuditorManager
 
close() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerIdGenerator
 
close() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
close() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
close() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
close() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
close() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataBookieDriver
 
close() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
close() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
close() - Method in class org.apache.bookkeeper.meta.ZkLedgerAuditorManager
 
close() - Method in class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
close() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
close() - Method in class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
close() - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreCursor
 
close() - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
close() - Method in interface org.apache.bookkeeper.metastore.MetaStore
Close the meta store.
close() - Method in interface org.apache.bookkeeper.metastore.MetastoreTable
Close the table.
close() - Method in interface org.apache.bookkeeper.processor.RequestProcessor
Close the request processor.
close() - Method in interface org.apache.bookkeeper.proto.BookieClient
Close the bookie client object.
close() - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
close() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
close() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
Closes the bookie client permanently.
close() - Method in class org.apache.bookkeeper.replication.Auditor
 
close() - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
close() - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
close() - Method in class org.apache.bookkeeper.server.http.BKHttpServiceProvider
 
close() - Method in class org.apache.bookkeeper.streaming.LedgerInputStream
Method close currently doesn't do anything.
close() - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
close() - Method in class org.apache.bookkeeper.util.LocalBookKeeper
 
close() - Method in class org.apache.bookkeeper.util.SubTreeCache.WatchGuard
 
close() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
close(boolean) - Method in class org.apache.bookkeeper.bookie.FileInfo
Close a file info.
close(boolean) - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
close(boolean) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
close(boolean) - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientPool
Close the pool.
close(int) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
close(int) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
close(int) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 
close(BookieFileChannel) - Method in class org.apache.bookkeeper.bookie.DefaultFileChannelProvider
 
close(BookieFileChannel) - Method in interface org.apache.bookkeeper.bookie.FileChannelProvider
Close bookieFileChannel.
close(BookKeeper, LedgerHandle) - Static method in class org.apache.bookkeeper.tools.cli.commands.bookie.SanityTestCommand
 
close(Logger, Closeable) - Static method in class org.apache.bookkeeper.util.IOUtils
Close the Closeable object and ignore any IOException or null pointers.
close(Logger, Closeable...) - Static method in class org.apache.bookkeeper.util.IOUtils
Close the Closeable objects and ignore any IOException or null pointers.
close(T) - Method in interface org.apache.bookkeeper.common.util.SharedResourceManager.Resource
Destroy the given instance.
CLOSE_CHANNEL_ON_RESPONSE_TIMEOUT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
closeAllWithoutFlushing() - Method in class org.apache.bookkeeper.bookie.FileInfoBackingCache
 
closeAsync() - Method in interface org.apache.bookkeeper.client.api.Handle
Asynchronous close the handle.
closeAsync() - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Asynchronous close the write handle, any adds in flight will return errors.
closeAsync() - Method in class org.apache.bookkeeper.client.LedgerHandle
Asynchronous close the write handle, any adds in flight will return errors.
closeComplete(int, LedgerHandle, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.CloseCallback
Callback definition.
closeComplete(int, LedgerHandle, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle.NoopCloseCallback
 
closeComplete(int, LedgerHandle, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.SyncCloseCallback
Close callback method.
closed - Variable in class org.apache.bookkeeper.client.BookKeeper
 
closed() - Method in class org.apache.bookkeeper.common.component.Lifecycle
Returns true if the state is closed.
CLOSED - org.apache.bookkeeper.client.api.LedgerMetadata.State
The ledger is closed.
CLOSED - org.apache.bookkeeper.common.component.Lifecycle.State
 
CLOSED - org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
CLOSED = 3;
CLOSED - org.apache.bookkeeper.proto.PerChannelBookieClient.ConnectionState
 
CLOSED_VALUE - Static variable in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
CLOSED = 3;
closeFileIfNecessary() - Method in class org.apache.bookkeeper.bookie.Journal.ForceWriteRequest
 
closeLedger(long, Consumer<Integer>) - Method in interface org.apache.bookkeeper.verifier.BookkeeperVerifier.BookkeeperDriver
 
closeLedger(long, Consumer<Integer>) - Method in class org.apache.bookkeeper.verifier.DirectBookkeeperDriver
 
closeLock - Variable in class org.apache.bookkeeper.client.BookKeeper
 
closeLock - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
closeRecovered() - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
closeWrite(long, Consumer<Integer>) - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
ClusterInfo() - Constructor for class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
ClusterInfo() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
ClusterInfoCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ClusterInfoCmd
 
ClusterInfoCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
A bookie command to retrieve bookies cluster info.
ClusterInfoCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand
 
ClusterInfoCommand.ClusterInfo - Class in org.apache.bookkeeper.tools.cli.commands.bookies
POJO definition for the cluster info response.
ClusterInfoService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that exposes the current info about the cluster of bookies.
ClusterInfoService(BookKeeperAdmin, LedgerManagerFactory) - Constructor for class org.apache.bookkeeper.server.http.service.ClusterInfoService
 
ClusterInfoService.ClusterInfo - Class in org.apache.bookkeeper.server.http.service
POJO definition for the cluster info response.
clusterMap - Variable in class org.apache.bookkeeper.net.NetworkTopologyImpl
The root cluster map.
CMD_ACTIVE_LEDGERS_ON_ENTRY_LOG_FILE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_AUTORECOVERY - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_BOOKIEFORMAT - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_BOOKIEINFO - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_BOOKIESANITYTEST - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_CHECK_DB_LEDGERS_INDEX - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_CLUSTERINFO - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_CONVERT_TO_DB_STORAGE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_CONVERT_TO_INTERLEAVED_STORAGE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_CREATE_COOKIE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_DECOMMISSIONBOOKIE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_DELETE_COOKIE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_DELETELEDGER - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_ENDPOINTINFO - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_FORCEAUDITCHECKS - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_GENERATE_COOKIE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_GET_COOKIE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_HELP - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_INITBOOKIE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_INITNEWCLUSTER - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_LASTMARK - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_LEDGER - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_LEDGERMETADATA - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_LISTBOOKIES - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_LISTFILESONDISC - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_LISTLEDGERS - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_LISTUNDERREPLICATED - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_LOCALCONSISTENCYCHECK - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_LOSTBOOKIERECOVERYDELAY - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_METAFORMAT - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_NUKEEXISTINGCLUSTER - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_QUERY_AUTORECOVERY_STATUS - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_READ_LEDGER_ENTRIES - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_READJOURNAL - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_READLOG - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_READLOGMETADATA - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_REBUILD_DB_LEDGER_LOCATIONS_INDEX - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_REBUILD_DB_LEDGERS_INDEX - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_RECOVER - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_REGENERATE_INTERLEAVED_STORAGE_INDEX_FILE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_SIMPLETEST - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_TRIGGERAUDIT - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_UPDATE_BOOKIE_IN_LEDGER - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_UPDATE_COOKIE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_UPDATECOOKIE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_UPDATELEDGER - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_WHATISINSTANCEID - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
CMD_WHOISAUDITOR - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
cmdName - Variable in class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
cmdPath() - Method in class org.apache.bookkeeper.tools.framework.Cli
 
coalesce(ByteBufList) - Static method in class org.apache.bookkeeper.util.ByteBufList
 
coarse - org.apache.bookkeeper.stats.codahale.FastTimer.Buckets
 
CodahaleMetricsProvider - Class in org.apache.bookkeeper.stats.codahale
A StatsProvider implemented based on Codahale metrics library.
CodahaleMetricsProvider() - Constructor for class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
CodahaleOpStatsLogger - Class in org.apache.bookkeeper.stats.codahale
 
CodahaleOpStatsLogger(Timer, Timer) - Constructor for class org.apache.bookkeeper.stats.codahale.CodahaleOpStatsLogger
 
CodahaleStatsLogger - Class in org.apache.bookkeeper.stats.codahale
A StatsLogger implemented based on Codahale metrics library.
CodahaleStatsLogger(MetricRegistry, String) - Constructor for class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
 
code - Variable in exception org.apache.bookkeeper.client.api.BKException
 
code - Variable in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.Result
 
Code - Enum in org.apache.bookkeeper.meta.exceptions
Metadata Exception Code.
codeLogger(int) - Static method in exception org.apache.bookkeeper.client.api.BKException
Returns a lazy error code formatter suitable to pass to log functions.
collect(List<CompletableFuture<T>>) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
COLON - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
com.scurrilous.circe - package com.scurrilous.circe
Provides interfaces and minimal support classes for providing and consuming various forms of hash functions.
com.scurrilous.circe.checksum - package com.scurrilous.circe.checksum
 
com.scurrilous.circe.crc - package com.scurrilous.circe.crc
Provides various implementations of cyclic redundancy check (CRC) error-detecting codes.
com.scurrilous.circe.impl - package com.scurrilous.circe.impl
Provides support for implementing new hash providers in the form of abstract base classes and utility classes.
com.scurrilous.circe.params - package com.scurrilous.circe.params
Defines hash parameters classes that describe various commonly-used hash functions.
com.scurrilous.circe.utils - package com.scurrilous.circe.utils
 
Command<GlobalFlagsT extends CliFlags> - Interface in org.apache.bookkeeper.tools.framework
Command of a cli.
CommandGroup<GlobalFlagsT extends CliFlags> - Interface in org.apache.bookkeeper.tools.framework
A command group that group commands together.
CommandHelpers - Class in org.apache.bookkeeper.tools.cli.helpers
Helper classes used by the cli commands.
commands - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
commands() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
CommandUtils - Class in org.apache.bookkeeper.tools.framework
Utils to process a commander.
CommandUtils() - Constructor for class org.apache.bookkeeper.tools.framework.CommandUtils
 
commitEntryMemTableFlush() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
commitEntryMemTableFlush() - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
commitEntryMemTableFlush() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
commitEntryMemTableFlush() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
CommonConfigurationKeys - Interface in org.apache.bookkeeper.net
Common Configuration Keys.
CommonHashes - Class in com.scurrilous.circe
Static methods to obtain commonly-used hash functions.
compact() - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
compact() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Compact storage full range.
compact() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
compact(byte[], byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Compact storage within a specified range.
compact(byte[], byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
compact(EntryLogMetadata) - Method in class org.apache.bookkeeper.bookie.AbstractLogCompactor
Compact entry log file.
compact(EntryLogMetadata) - Method in class org.apache.bookkeeper.bookie.EntryLogCompactor
 
compact(EntryLogMetadata) - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor
 
COMPACT_RUNTIME - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
CompactableLedgerStorage - Interface in org.apache.bookkeeper.bookie
Interface that identifies LedgerStorage implementations using EntryLogger and running periodic entries compaction.
COMPACTED_FILE_PATTERN - Static variable in class org.apache.bookkeeper.util.LedgerDirUtil
 
COMPACTED_SUFFIX - Static variable in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor
 
compactedFile - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
compactedFile(File, int, int) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
compactedLogIdsInDirectory(File) - Static method in class org.apache.bookkeeper.util.LedgerDirUtil
 
compactEntryLog(EntryLogMetadata) - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
Compact an entry log.
compacting - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
COMPACTING_SUFFIX - Static variable in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor
 
compactingFile - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
compactingFile(File, int) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
COMPACTION_ABORT_EXCEPTION - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
Failed to delete files while aborting a compaction operation.
COMPACTION_COMPLETE - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
Compaction has been completed for a log.
COMPACTION_DELETE_FAILURE - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
Failed to delete files while completing a compaction operation.
COMPACTION_LOG_CREATED - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
A new entrylog has been created.
COMPACTION_LOG_RECOVERED - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
A partially compacted log has been recovered.
COMPACTION_MAKE_AVAILABLE - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
A compacted log has been made available for reads.
COMPACTION_MARK_COMPACTED - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
A compaction log has been marked as compacted.
COMPACTION_MAX_OUTSTANDING_REQUESTS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
COMPACTION_RATE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
COMPACTION_RATE_BY_BYTES - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
COMPACTION_RATE_BY_ENTRIES - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
CompactionEntryLog - Interface in org.apache.bookkeeper.bookie.storage
An entrylog to received compacted entries.
compactionLog - Variable in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.FlushCompactionLogPhase
 
compactionLog - Variable in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.UpdateIndexPhase
 
CompactionPhase(String) - Constructor for class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.CompactionPhase
 
CompactionScannerFactory() - Constructor for class org.apache.bookkeeper.bookie.EntryLogCompactor.CompactionScannerFactory
 
compactor - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
COMPARATOR - Static variable in class org.apache.bookkeeper.bookie.EntryKey
Comparator for the key portion.
compare(EnumSet<HashSupport>, EnumSet<HashSupport>) - Static method in enum com.scurrilous.circe.HashSupport
Compares the given sets of hash algorithm support flags for priority order.
compare(EnumSet<HashSupport>, EnumSet<HashSupport>) - Method in class com.scurrilous.circe.HashSupport.SetComparator
 
compare(EntryKey, EntryKey) - Method in class org.apache.bookkeeper.bookie.KeyComparator
 
compare(LogMark) - Method in class org.apache.bookkeeper.bookie.LogMark
 
compare(PendingAddOp, PendingAddOp) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv.PendingOpsComparator
 
compare(Version) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.MetadataVersion
 
compare(Version) - Method in class org.apache.bookkeeper.versioning.LongVersion
 
compare(Version) - Method in interface org.apache.bookkeeper.versioning.Version
 
compareAndSet(long, long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
Change the value for a specific key only if it matches the current value.
compareTo(ByteBuf) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
compareTo(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.EntryMemTable.EntrySkipList
 
compareTo(ConcurrentLongLongPairHashMap.LongPair) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.LongPair
 
CompatibilityException(String) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException.CompatibilityException
 
CompatibilityException(String, Throwable) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException.CompatibilityException
 
complete - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
complete - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
complete - Variable in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
complete() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.CompactionPhase
 
complete() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.FlushCompactionLogPhase
 
complete() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.ScanEntryLogPhase
 
complete() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.UpdateIndexPhase
 
complete(int, BookieId, ByteBuf) - Method in class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
 
complete(int, BookieId, ByteBuf) - Method in class org.apache.bookkeeper.client.PendingReadOp.SingleLedgerEntryRequest
Complete the read request from host.
complete(int, BookieId, ByteBuf, long) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
Complete the read request from host.
complete(int, BookieId, ByteBuf, long) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
complete(int, BookieId, ByteBufList) - Method in class org.apache.bookkeeper.client.BatchedReadOp.BatchedLedgerEntryRequest
 
complete(int, BookieId, ByteBufList) - Method in class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
complete(int, T) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.SyncResult
Deprecated.
 
complete(int, T, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreCallback
 
complete(int, T, Object) - Method in class org.apache.bookkeeper.metastore.MetastoreUtils.MultiMetastoreCallback
 
complete(int, T, Object) - Method in class org.apache.bookkeeper.metastore.MetastoreUtils.SyncMetastoreCallback
 
complete(long, ArrayList<byte[]>) - Method in interface org.apache.bookkeeper.verifier.BookkeeperVerifier.BookkeeperDriver.ReadCallback
 
complete(CompletableFuture<T>, T) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
completeBookieAndCheck(int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.AckSet
Add a bookie response and check if quorum has been met.
completed - Variable in class org.apache.bookkeeper.client.ForceLedgerOp
 
completed - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
completed - Variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
completed - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
completed - Variable in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
completeExceptionally(CompletableFuture<T>, Throwable) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
completeFile - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
CompletionKey(BookkeeperProtocol.OperationType) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionKey
 
CompletionValue(String, Object, long, long, OpStatsLogger, OpStatsLogger) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
ComponentConfiguration - Class in org.apache.bookkeeper.common.conf
Component Configuration.
ComponentConfiguration(CompositeConfiguration, String) - Constructor for class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
ComponentInfoPublisher - Class in org.apache.bookkeeper.common.component
Allows a component to publish information about the services it implements, the endpoints it exposes and other useful information for management tools and client.
ComponentInfoPublisher() - Constructor for class org.apache.bookkeeper.common.component.ComponentInfoPublisher
 
ComponentInfoPublisher.EndpointInfo - Class in org.apache.bookkeeper.common.component
Endpoint information.
componentName - Variable in class org.apache.bookkeeper.common.component.AbstractComponent
 
ComponentShutdownHook(LifecycleComponent, CompletableFuture<Void>) - Constructor for class org.apache.bookkeeper.common.component.ComponentStarter.ComponentShutdownHook
 
ComponentStarter - Class in org.apache.bookkeeper.common.component
Utils to start components.
ComponentStarter() - Constructor for class org.apache.bookkeeper.common.component.ComponentStarter
 
ComponentStarter.ComponentShutdownHook - Class in org.apache.bookkeeper.common.component
 
computeChecksum(ByteBuf) - Static method in class com.scurrilous.circe.checksum.Crc32cIntChecksum
Computes crc32c checksum: if it is able to load crc32c native library then it computes using that native library which is faster as it computes using hardware machine instruction else it computes using crc32c algo.
computeChecksum(ByteBuf, int, int) - Static method in class com.scurrilous.circe.checksum.Crc32cIntChecksum
Computes crc32c checksum: if it is able to load crc32c native library then it computes using that native library which is faster as it computes using hardware machine instruction else it computes using crc32c algo.
computeDigestAndPackageForSending(long, long, long, ByteBuf, byte[], int) - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
Computes the digest for an entry and put bytes together for sending.
computeDigestAndPackageForSendingLac(long) - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
Computes the digest for writeLac for sending.
computeIfAbsent(long, LongFunction<V>) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
computeIfAbsent(long, ConcurrentLongLongHashMap.LongLongFunction) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
computeIfAbsent(K, Function<K, V>) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
concurrencyLevel - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
concurrencyLevel - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
concurrencyLevel - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
concurrencyLevel - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
concurrencyLevel - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
concurrencyLevel - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
concurrencyLevel(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
concurrencyLevel(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
concurrencyLevel(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
concurrencyLevel(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
concurrencyLevel(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
concurrencyLevel(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
ConcurrentConfiguration - Class in org.apache.bookkeeper.common.conf
Configuration view built on concurrent hash map for fast thread-safe access.
ConcurrentConfiguration() - Constructor for class org.apache.bookkeeper.common.conf.ConcurrentConfiguration
 
ConcurrentLongHashMap<V> - Class in org.apache.bookkeeper.util.collections
Map from long to an Object.
ConcurrentLongHashMap() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
Deprecated.
ConcurrentLongHashMap(int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
Deprecated.
ConcurrentLongHashMap(int, int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
Deprecated.
ConcurrentLongHashMap(int, int, float, float, boolean, float, float) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
ConcurrentLongHashMap.Builder<T> - Class in org.apache.bookkeeper.util.collections
Builder of ConcurrentLongHashMap.
ConcurrentLongHashMap.EntryProcessor<V> - Interface in org.apache.bookkeeper.util.collections
An entry processor.
ConcurrentLongHashMap.LongObjectPredicate<V> - Interface in org.apache.bookkeeper.util.collections
Predicate specialization for (long, V) types.
ConcurrentLongHashSet - Class in org.apache.bookkeeper.util.collections
Concurrent hash set for primitive longs.
ConcurrentLongHashSet() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
Deprecated.
ConcurrentLongHashSet(int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
Deprecated.
ConcurrentLongHashSet(int, int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
Deprecated.
ConcurrentLongHashSet(int, int, float, float, boolean, float, float) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
ConcurrentLongHashSet.Builder - Class in org.apache.bookkeeper.util.collections
Builder of ConcurrentLongHashSet.
ConcurrentLongHashSet.ConsumerLong - Interface in org.apache.bookkeeper.util.collections
A consumer of long values.
ConcurrentLongLongHashMap - Class in org.apache.bookkeeper.util.collections
Concurrent hash map from primitive long to long.
ConcurrentLongLongHashMap() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
Deprecated.
ConcurrentLongLongHashMap(int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
Deprecated.
ConcurrentLongLongHashMap(int, int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
Deprecated.
ConcurrentLongLongHashMap(int, int, float, float, boolean, float, float) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
ConcurrentLongLongHashMap.BiConsumerLong - Interface in org.apache.bookkeeper.util.collections
A Long-Long BiConsumer.
ConcurrentLongLongHashMap.Builder - Class in org.apache.bookkeeper.util.collections
Builder of ConcurrentLongLongHashMap.
ConcurrentLongLongHashMap.LongLongFunction - Interface in org.apache.bookkeeper.util.collections
A Long-Long function.
ConcurrentLongLongHashMap.LongLongPredicate - Interface in org.apache.bookkeeper.util.collections
A Long-Long predicate.
ConcurrentLongLongPairHashMap - Class in org.apache.bookkeeper.util.collections
Concurrent hash map where both keys and values are composed of pairs of longs.
ConcurrentLongLongPairHashMap() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
Deprecated.
ConcurrentLongLongPairHashMap(int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
Deprecated.
ConcurrentLongLongPairHashMap(int, int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
Deprecated.
ConcurrentLongLongPairHashMap.BiConsumerLongPair - Interface in org.apache.bookkeeper.util.collections
A BiConsumer Long pair.