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
 
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_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.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
 
bookieAddresss(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
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
Intializes 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
 
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.
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
 

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
 
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;
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
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(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
 
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.
ConcurrentLongLongPairHashMap.Builder - Class in org.apache.bookkeeper.util.collections
Builder of ConcurrentLongLongPairHashMap.
ConcurrentLongLongPairHashMap.LongLongPairFunction - Interface in org.apache.bookkeeper.util.collections
A Long pair function.
ConcurrentLongLongPairHashMap.LongLongPairPredicate - Interface in org.apache.bookkeeper.util.collections
A Long pair predicate.
ConcurrentLongLongPairHashMap.LongPair - Class in org.apache.bookkeeper.util.collections
A pair of long values.
CONCURRENTLY - org.apache.bookkeeper.versioning.Version.Occurred
 
ConcurrentOpenHashMap<K,​V> - Class in org.apache.bookkeeper.util.collections
Concurrent hash map.
ConcurrentOpenHashMap() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
Deprecated.
ConcurrentOpenHashMap(int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
Deprecated.
ConcurrentOpenHashMap(int, int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
Deprecated.
ConcurrentOpenHashMap(int, int, float, float, boolean, float, float) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
ConcurrentOpenHashMap.Builder<K,​V> - Class in org.apache.bookkeeper.util.collections
Builder of ConcurrentOpenHashMap.
ConcurrentOpenHashSet<V> - Class in org.apache.bookkeeper.util.collections
Concurrent hash set.
ConcurrentOpenHashSet() - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
Deprecated.
ConcurrentOpenHashSet(int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
Deprecated.
ConcurrentOpenHashSet(int, int) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
Deprecated.
ConcurrentOpenHashSet(int, int, float, float, boolean, float, float) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
ConcurrentOpenHashSet.Builder<V> - Class in org.apache.bookkeeper.util.collections
Builder of ConcurrentOpenHashSet.
conf - Variable in class org.apache.bookkeeper.bookie.AbstractLogCompactor
 
conf - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
conf - Variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
conf - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 
conf - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
conf - Variable in class org.apache.bookkeeper.bookie.Journal
 
conf - Variable in class org.apache.bookkeeper.client.BookKeeper.Builder
 
conf - Variable in class org.apache.bookkeeper.client.BookKeeper
 
conf - Variable in class org.apache.bookkeeper.common.component.AbstractComponent
 
conf - Variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
conf - Variable in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
conf - Variable in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
conf - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
conf - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
conf - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
conf - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
conf - Variable in class org.apache.bookkeeper.proto.BookieServer
 
conf - Variable in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
conf - Variable in class org.apache.bookkeeper.replication.AuditorTask
 
conf - Variable in class org.apache.bookkeeper.server.http.service.AutoRecoveryStatusService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.ConfigurationService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.DecommissionService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.DeleteLedgerService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.ExpandStorageService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.GCDetailsService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.GetLastLogMarkService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.GetLedgerMetaService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.ListBookieInfoService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.ListBookiesService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.ListDiskFilesService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.ListLedgerService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.ListUnderReplicatedLedgerService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.LostBookieRecoveryDelayService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.ReadLedgerEntryService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.RecoveryBookieService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.TriggerAuditService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.TriggerGCService
 
conf - Variable in class org.apache.bookkeeper.server.http.service.WhoIsAuditorService
 
conf - Variable in class org.apache.bookkeeper.tools.cli.helpers.BookieShellCommand
 
CONF_OPT - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
ConfigDef - Class in org.apache.bookkeeper.common.conf
A definition of a configuration instance.
ConfigDef.Builder - Class in org.apache.bookkeeper.common.conf
Builder to build a configuration definition.
ConfigException - Exception in org.apache.bookkeeper.common.conf
Exception thrown for configuration errors.
ConfigException(String) - Constructor for exception org.apache.bookkeeper.common.conf.ConfigException
Construct a config exception with provided error.
ConfigException(String, Throwable) - Constructor for exception org.apache.bookkeeper.common.conf.ConfigException
Construct a config exception with provided error and reason.
configFile - Variable in class org.apache.bookkeeper.tools.common.BKFlags
 
ConfigKey - Class in org.apache.bookkeeper.common.conf
A configuration key in a configuration.
ConfigKey(boolean, String, Type, String, String, Object, List<String>, Validator, ConfigKeyGroup, int, List<String>, boolean, String, String, String) - Constructor for class org.apache.bookkeeper.common.conf.ConfigKey
 
ConfigKey.ConfigKeyBuilder - Class in org.apache.bookkeeper.common.conf
 
ConfigKeyBuilder() - Constructor for class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
 
ConfigKeyGroup - Class in org.apache.bookkeeper.common.conf
Define a group of configuration settings.
ConfigKeyGroup(String, String, List<String>, int) - Constructor for class org.apache.bookkeeper.common.conf.ConfigKeyGroup
 
ConfigKeyGroup.ConfigKeyGroupBuilder - Class in org.apache.bookkeeper.common.conf
 
ConfigKeyGroupBuilder() - Constructor for class org.apache.bookkeeper.common.conf.ConfigKeyGroup.ConfigKeyGroupBuilder
 
Configurable - Interface in org.apache.bookkeeper.conf
Class that may be configured with a Configuration.
configuration - Variable in class org.apache.bookkeeper.bookie.JournalChannel
 
ConfigurationService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper Configuration related http request.
ConfigurationService(ServerConfiguration) - Constructor for class org.apache.bookkeeper.server.http.service.ConfigurationService
 
confirmPrompt(String) - Static method in class org.apache.bookkeeper.util.IOUtils
Confirm prompt for the console operations.
connect() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
CONNECTED - org.apache.bookkeeper.proto.PerChannelBookieClient.ConnectionState
 
connectIfNeededAndDoOp(BookkeeperInternalCallbacks.GenericCallback<PerChannelBookieClient>) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
CONNECTING - org.apache.bookkeeper.proto.PerChannelBookieClient.ConnectionState
 
CONNECTION_TIMEOUT - Static variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
ConnectionFutureListener(long) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.ConnectionFutureListener
 
connectionPeer - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
connectionPeer - Variable in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler
 
connectionPeer - Variable in class org.apache.bookkeeper.proto.BookieNettyServer.BookieSideConnectionPeerContextHandler
 
ConnectionPeer - Interface in org.apache.bookkeeper.proto
Represents the connection to a BookKeeper client, from the Bookie side.
connectRetryPolicy - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
connectRetryPolicy(RetryPolicy) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
connectString - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
connectString(String) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
console() - Method in class org.apache.bookkeeper.tools.framework.Cli
 
console() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
console(String) - Method in class org.apache.bookkeeper.tools.framework.Cli
 
CONSOLE - Static variable in interface org.apache.bookkeeper.slogger.Slogger
 
ConsoleSlogger - Class in org.apache.bookkeeper.slogger
Simple slogger implementation which writes json to console.
ConsoleSlogger() - Constructor for class org.apache.bookkeeper.slogger.ConsoleSlogger
 
ConsoleSlogger(Class<?>) - Constructor for class org.apache.bookkeeper.slogger.ConsoleSlogger
 
ConsoleSlogger(Class<?>, Iterable<Object>) - Constructor for class org.apache.bookkeeper.slogger.ConsoleSlogger
 
constant(long) - Static method in class org.apache.bookkeeper.common.util.Backoff
Create a stream with constant backoffs.
contains(int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
Whether the set contains the given index.
contains(long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
contains(Node) - Method in interface org.apache.bookkeeper.net.NetworkTopology
Check if the tree contains node node.
contains(Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Check if the tree contains node node.
contains(Node) - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
contains(V) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
containsKey(long) - Method in interface org.apache.bookkeeper.bookie.EntryLogMetadataMap
Checks if record with entryLogId exists into the map.
containsKey(long) - Method in class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
containsKey(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
 
containsKey(long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
containsKey(long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
containsKey(long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
containsKey(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
containsKey(String) - Method in class org.apache.bookkeeper.common.conf.ConcurrentConfiguration
 
containsKey(K) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
containsKey(K) - Method in class org.apache.bookkeeper.util.SnapshotMap
Returns true if this map contains a mapping for the specified key.
containsLedger(long) - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
containsProperties(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
map<string, string> properties = 7;
containsProperties(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
map<string, string> properties = 7;
containsProperties(String) - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
map<string, string> properties = 7;
context - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
ContextPreservingCallable(Callable<T>) - Constructor for class org.apache.bookkeeper.common.util.OrderedExecutor.ContextPreservingCallable
 
ContextPreservingFutureListener(ChannelFutureListener) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.ContextPreservingFutureListener
 
contextPreservingListener(ChannelFutureListener) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
ContextPreservingRunnable(Runnable) - Constructor for class org.apache.bookkeeper.common.util.OrderedExecutor.ContextPreservingRunnable
 
convertBookiesToNodes(Collection<BookieId>) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
convertBookieToNode(BookieId) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
convertStatus(BookkeeperProtocol.StatusCode, int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
ConvertToDbStorageCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ConvertToDbStorageCmd
 
ConvertToDBStorageCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
A command to convert bookie indexes from InterleavedStorage to DbLedgerStorage format.
ConvertToDBStorageCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToDBStorageCommand
 
ConvertToDBStorageCommand(ConvertToDBStorageCommand.CTDBFlags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToDBStorageCommand
 
ConvertToDBStorageCommand.CTDBFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for this command.
ConvertToInterleavedStorageCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ConvertToInterleavedStorageCmd
 
ConvertToInterleavedStorageCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
A command to convert bookie indexes from DbLedgerStorage to InterleavedStorage format.
ConvertToInterleavedStorageCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToInterleavedStorageCommand
 
ConvertToInterleavedStorageCommand(ConvertToInterleavedStorageCommand.CTISFlags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToInterleavedStorageCommand
 
ConvertToInterleavedStorageCommand.CTISFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for this command.
Cookie - Class in org.apache.bookkeeper.bookie
When a bookie starts for the first time it generates a cookie, and stores the cookie in registration manager as well as in the each of the local filesystem directories it uses.
COOKIE_NODE - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
Cookie.Builder - Class in org.apache.bookkeeper.bookie
Cookie builder.
CookieCommand<CookieFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.cli.commands.cookie
This is a mixin for cookie related commands to extends.
CookieCommand(CliSpec<CookieFlagsT>) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.CookieCommand
 
CookieExistException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.CookieExistException
 
CookieExistException(String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.CookieExistException
 
CookieExistException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.CookieExistException
 
CookieExistsException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
cookieFile(String) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.CreateCookieCommand.Flags
 
cookieFile(String) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.UpdateCookieCommand.Flags
 
CookieNotFoundException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
CookieNotFoundException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.CookieNotFoundException
 
CookieNotFoundException(String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.CookieNotFoundException
 
CookieNotFoundException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.CookieNotFoundException
 
CookieValidation - Interface in org.apache.bookkeeper.bookie
Interface for cookie validation.
copy() - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
Make a deep copy of this write set.
copy() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
copy(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
copyFromAvailable(long) - Method in interface org.apache.bookkeeper.bookie.datainteg.EntryCopier.Batch
Copy an entry from a remote bookie and store it locally.
copyFromAvailable(long) - Method in class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl.BatchImpl
 
copyOf(BKStats) - Method in class org.apache.bookkeeper.proto.BKStats
Copy stats from other stats.
copyOf(BKStats.OpStats) - Method in class org.apache.bookkeeper.proto.BKStats.OpStats
Copy stats from other OpStats.
count() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
 
count() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
count() - Method in class org.apache.bookkeeper.bookie.storage.ldb.ReadCache
 
count() - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
countDirs - Variable in class org.apache.bookkeeper.util.HardLink.LinkStats
 
countEmptyDirs - Variable in class org.apache.bookkeeper.util.HardLink.LinkStats
 
counter - Variable in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
Counter - Interface in org.apache.bookkeeper.stats
Simple stats that require only increment and decrement functions on a Long.
counters - Variable in class org.apache.bookkeeper.stats.CachingStatsLogger
 
counters - Variable in class org.apache.bookkeeper.stats.otel.OtelMetricsProvider
 
counters - Variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
countFilesMultLinks - Variable in class org.apache.bookkeeper.util.HardLink.LinkStats
 
countMultLinks - Variable in class org.apache.bookkeeper.util.HardLink.LinkStats
 
countNumOfAvailableNodes(String, Collection<Node>) - Method in interface org.apache.bookkeeper.net.NetworkTopology
Return the number of leaves in scope but not in excludedNodes.
countNumOfAvailableNodes(String, Collection<Node>) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
 
countNumOfAvailableNodes(String, Collection<Node>) - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
countPhysicalFileCopies - Variable in class org.apache.bookkeeper.util.HardLink.LinkStats
 
countSingleLinks - Variable in class org.apache.bookkeeper.util.HardLink.LinkStats
 
coverageSet - Variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
cp - Variable in class org.apache.bookkeeper.bookie.EntryMemTable.EntrySkipList
 
CpuAffinity - Class in org.apache.bookkeeper.common.util.affinity
Utilities for enabling thread to CPU affinity.
CpuAffinityImpl - Class in org.apache.bookkeeper.common.util.affinity.impl
Implementation of CPU Affinity functionality.
CpuAffinityJni - Class in org.apache.bookkeeper.common.util.affinity.impl
JNI wrapper of native functions for CPU affinity.
CRC16 - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-16, used in the ARC and LHA compression utilities.
CRC16_CCITT - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-16/CCITT, used in the Kermit protocol.
CRC16_XMODEM - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-16/XMODEM, used in the XMODEM protocol.
crc32() - Static method in class com.scurrilous.circe.CommonHashes
Returns an incremental stateless hash function implementing the CRC-32 checksum algorithm.
CRC32 - org.apache.bookkeeper.client.api.DigestType
Entries are verified by applied CRC32 algorithm.
CRC32 - org.apache.bookkeeper.client.BookKeeper.DigestType
 
CRC32 - org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
CRC32 = 1;
CRC32 - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-32, used in Ethernet, SATA, PKZIP, ZMODEM, etc.
CRC32_BZIP2 - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-32/BZIP2, used in BZIP2.
CRC32_MPEG2 - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-32/MPEG-2, used in MPEG-2.
CRC32_POSIX - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-32/POSIX, used in the cksum utility.
CRC32_VALUE - Static variable in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
CRC32 = 1;
crc32c() - Static method in class com.scurrilous.circe.CommonHashes
Returns an incremental stateless hash function implementing the CRC-32C checksum algorithm.
CRC32C - org.apache.bookkeeper.client.api.DigestType
Entries are verified by applied CRC32C algorithm.
CRC32C - org.apache.bookkeeper.client.BookKeeper.DigestType
 
CRC32C - org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
CRC32C = 3;
CRC32C - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-32C, used in iSCSI and SCTP.
CRC32C_VALUE - Static variable in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
CRC32C = 3;
CRC32CDigestManager - Class in org.apache.bookkeeper.proto.checksum
 
CRC32CDigestManager(long, boolean, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.proto.checksum.CRC32CDigestManager
 
Crc32cIntChecksum - Class in com.scurrilous.circe.checksum
 
Crc32cIntChecksum() - Constructor for class com.scurrilous.circe.checksum.Crc32cIntChecksum
 
Crc32cSse42Provider - Class in com.scurrilous.circe.checksum
 
Crc32cSse42Provider() - Constructor for class com.scurrilous.circe.checksum.Crc32cSse42Provider
 
CRC32DigestManager - Class in org.apache.bookkeeper.proto.checksum
Digest manager for CRC32 checksum.
CRC32DigestManager(long, boolean, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.proto.checksum.CRC32DigestManager
 
CRC32DigestManager.CRC32Digest - Interface in org.apache.bookkeeper.proto.checksum
Interface that abstracts different implementations of the CRC32 digest.
crc64() - Static method in class com.scurrilous.circe.CommonHashes
Returns an incremental stateless hash function implementing the CRC-64 checksum algorithm.
CRC64 - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-64, used in the ECMA-182 standard for DLT-1 tapes.
CRC64_XZ - Static variable in class com.scurrilous.circe.params.CrcParameters
Parameters for CRC-64/XZ, used in the .xz file format.
CrcParameters - Class in com.scurrilous.circe.params
Hash parameters used to define a cyclic redundancy check (CRC).
CrcParameters(String, int, long, long, long, boolean) - Constructor for class com.scurrilous.circe.params.CrcParameters
Constructs a CrcParameters with the given parameters.
create() - Static method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
create() - Static method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorBuilder
create() - Static method in class org.apache.bookkeeper.common.util.SharedResourceManager
 
create() - Method in interface org.apache.bookkeeper.common.util.SharedResourceManager.Resource
Create a new instance of the resource.
create(byte[], long, LedgerStorage) - Static method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
create(byte, int, long, long) - Static method in class org.apache.bookkeeper.proto.BookieProtocol.AddResponse
 
create(byte, long, long, short, byte[]) - Static method in class org.apache.bookkeeper.proto.BookieProtocol.ReadRequest
 
create(byte, long, long, short, byte[], long, int, long) - Static method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadRequest
 
create(byte, long, long, short, byte[], ByteBuf) - Static method in class org.apache.bookkeeper.proto.BookieProtocol.ParsedAddRequest
 
create(int) - Static method in exception org.apache.bookkeeper.bookie.BookieException
 
create(int) - Static method in exception org.apache.bookkeeper.client.BKException
Create an exception from an error code.
create(long, long) - Static method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
 
create(long, long, long, ByteBuf) - Static method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
 
create(long, LedgerEntry) - Static method in class org.apache.bookkeeper.client.impl.LastConfirmedAndEntryImpl
 
create(ByteBuf, boolean, long, long, BookkeeperInternalCallbacks.WriteCallback, Object, long, OpStatsLogger, Counter) - Static method in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
create(String) - Static method in class org.apache.bookkeeper.common.net.ServiceURI
Create a service uri instance from a uri string.
create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
create(String, byte[], List<ACL>, CreateMode, AsyncCallback.StringCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
create(URI) - Static method in class org.apache.bookkeeper.common.net.ServiceURI
Create a service uri instance from a URI instance.
create(FileChannel, int) - Method in interface org.apache.bookkeeper.bookie.Journal.BufferedChannelBuilder
 
create(Supplier<ScheduledExecutorService>) - Static method in class org.apache.bookkeeper.common.util.SharedResourceManager
 
create(List<LedgerEntry>) - Static method in class org.apache.bookkeeper.client.impl.LedgerEntriesImpl
Create ledger entries.
create(LedgerHandle, ClientContext, List<BookieId>, ByteBuf, EnumSet<WriteFlag>, AsyncCallback.AddCallbackWithLatency, Object) - Static method in class org.apache.bookkeeper.client.PendingAddOp
 
create(MSException.Code) - Static method in exception org.apache.bookkeeper.metastore.MSException
 
create(MSException.Code, String) - Static method in exception org.apache.bookkeeper.metastore.MSException
 
create(MSException.Code, String, Throwable) - Static method in exception org.apache.bookkeeper.metastore.MSException
 
create(BookieId, PerChannelBookieClientPool, SecurityHandlerFactory, boolean) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
create(BookieId, PerChannelBookieClientPool, SecurityHandlerFactory, boolean) - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientFactory
Create a PerChannelBookieClient to address.
create(BookieProtocol.BatchedReadRequest, BookieRequestHandler, BookieRequestProcessor, ExecutorService, boolean, long) - Static method in class org.apache.bookkeeper.proto.BatchedReadEntryProcessor
 
create(BookieProtocol.ParsedAddRequest, BookieRequestHandler, BookieRequestProcessor) - Static method in class org.apache.bookkeeper.proto.WriteEntryProcessor
 
create(BookieProtocol.ReadRequest, BookieRequestHandler, BookieRequestProcessor, ExecutorService, boolean) - Static method in class org.apache.bookkeeper.proto.ReadEntryProcessor
 
CREATE_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
CreateAdvBuilder - Interface in org.apache.bookkeeper.client.api
Builder-style interface to create new ledgers.
createAllocator(ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.BookieResources
 
createBookieNode(BookieId) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
createBookKeeperClient(ServerConfiguration) - Static method in class org.apache.bookkeeper.replication.Auditor
 
createBookKeeperClient(ServerConfiguration, StatsLogger) - Static method in class org.apache.bookkeeper.replication.Auditor
 
createBookKeeperClientThrowUnavailableException(ServerConfiguration) - Static method in class org.apache.bookkeeper.replication.Auditor
 
CreateBuilder - Interface in org.apache.bookkeeper.client.api
Builder-style interface to create new ledgers.
CreateBuilderImpl(BookKeeper) - Constructor for class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
createCacheable(HashParameters, EnumSet<HashSupport>) - Method in class com.scurrilous.circe.checksum.Crc32cSse42Provider
 
createCacheable(CrcParameters, EnumSet<HashSupport>) - Method in class com.scurrilous.circe.crc.StandardCrcProvider
 
createCacheable(P, EnumSet<HashSupport>) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
Called by AbstractHashProvider.getCacheable(P, java.util.EnumSet<com.scurrilous.circe.HashSupport>) to create new cacheable stateless hash functions.
createComplete(int, LedgerHandle, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.CreateCallback
Declaration of callback method.
createComplete(int, LedgerHandle, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.SyncCreateAdvCallback
Create callback implementation for synchronous create call.
createComplete(int, LedgerHandle, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.SyncCreateCallback
Create callback implementation for synchronous create call.
createConnectedZooKeeperClient(String, int, Set<Watcher>, RetryPolicy) - Static method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
CreateCookieCommand - Class in org.apache.bookkeeper.tools.cli.commands.cookie
A command that create cookie.
CreateCookieCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.CreateCookieCommand
 
CreateCookieCommand(PrintStream) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.CreateCookieCommand
 
CreateCookieCommand(CreateCookieCommand.Flags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.CreateCookieCommand
 
CreateCookieCommand.Flags - Class in org.apache.bookkeeper.tools.cli.commands.cookie
Flags to create a cookie for a given bookie.
createdEntryLog(Long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.RecentEntryLogsStatus
 
createDiskChecker(ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.BookieResources
 
createDummyBookieIdForHostname(String) - Static method in class org.apache.bookkeeper.net.BookieSocketAddress
Utility for Placement Policies that need to create a dummy BookieId that represents a given host.
createDummyLocalBookieNode(String) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
createExplicitLACEntry(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
createFullPathOptimistic(ZooKeeper, String, byte[], List<ACL>, CreateMode) - Static method in class org.apache.bookkeeper.util.ZkUtils
Create zookeeper path recursively and optimistically.
createFuture() - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
createHardLink(File, File) - Static method in class org.apache.bookkeeper.util.HardLink
Creates a hardlink.
createHardLinkMult(File, String[], File) - Static method in class org.apache.bookkeeper.util.HardLink
Creates hardlinks from multiple existing files within one parent directory, into one target directory.
createHardLinkMult(File, String[], File, int) - Static method in class org.apache.bookkeeper.util.HardLink
 
createIndexDirsManager(ServerConfiguration, DiskChecker, StatsLogger, LedgerDirsManager) - Static method in class org.apache.bookkeeper.bookie.BookieResources
 
createLedger(int, int, int, BookKeeper.DigestType, byte[]) - Method in class org.apache.bookkeeper.client.BookKeeper
Synchronous call to create ledger.
createLedger(int, int, int, BookKeeper.DigestType, byte[], Map<String, byte[]>) - Method in class org.apache.bookkeeper.client.BookKeeper
Synchronous call to create ledger.
createLedger(int, int, BookKeeper.DigestType, byte[]) - Method in class org.apache.bookkeeper.client.BookKeeper
Synchronous call to create ledger.
createLedger(long, int, int, int, Consumer<Integer>) - Method in interface org.apache.bookkeeper.verifier.BookkeeperVerifier.BookkeeperDriver
 
createLedger(long, int, int, int, Consumer<Integer>) - Method in class org.apache.bookkeeper.verifier.DirectBookkeeperDriver
 
createLedger(BookKeeper.DigestType, byte[]) - Method in class org.apache.bookkeeper.client.BookKeeper
Creates a new ledger.
createLedgerAdv(int, int, int, BookKeeper.DigestType, byte[]) - Method in class org.apache.bookkeeper.client.BookKeeper
Synchronous call to create ledger.
createLedgerAdv(int, int, int, BookKeeper.DigestType, byte[], Map<String, byte[]>) - Method in class org.apache.bookkeeper.client.BookKeeper
Synchronous call to create ledger.
createLedgerAdv(long, int, int, int, BookKeeper.DigestType, byte[], Map<String, byte[]>) - Method in class org.apache.bookkeeper.client.BookKeeper
Synchronously creates a new ledger using the interface which accepts a ledgerId as input.
createLedgerDirsManager(ServerConfiguration, DiskChecker, StatsLogger) - Static method in class org.apache.bookkeeper.bookie.BookieResources
 
createLedgerFenceEntry(Long) - Static method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
createLedgerMetadata(long, LedgerMetadata) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
createLedgerMetadata(long, LedgerMetadata) - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
createLedgerMetadata(long, LedgerMetadata) - Method in interface org.apache.bookkeeper.meta.LedgerManager
Create a new ledger with provided ledger id and metadata.
createLedgerMetadata(long, LedgerMetadata) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
createLedgerMetadata(long, LedgerMetadata) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
createLedgerPrefix(String, String) - Static method in class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
createLedgerStorage(String) - Static method in class org.apache.bookkeeper.bookie.LedgerStorageFactory
 
createLedgerStorage(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, StatsLogger, ByteBufAllocator) - Static method in class org.apache.bookkeeper.bookie.BookieResources
 
createMasterKeyEntry(long, byte[]) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
createMetadataDriver(ServerConfiguration, StatsLogger) - Static method in class org.apache.bookkeeper.bookie.BookieResources
Instantiate the metadata driver for the Bookie.
createMetaStore(String) - Static method in class org.apache.bookkeeper.metastore.MetastoreFactory
 
createNew() - Method in class com.scurrilous.circe.crc.JavaCrc32
 
createNew() - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
createNew() - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
createNew() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
createNew() - Method in interface com.scurrilous.circe.StatefulHash
Returns a new instance of this stateful hash function reset to the initial state.
createNewLMFactory(AbstractConfiguration, LayoutManager, Class<? extends LedgerManagerFactory>) - Static method in class org.apache.bookkeeper.meta.AbstractZkLedgerManagerFactory
Creates the new layout and stores in zookeeper and returns the LedgerManagerFactory instance.
createNewLog(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
createNewLog(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
createNewLog(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
createNewLog(long, String) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
createNewLog(File) - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
createNewLogForCompaction() - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
createNewLogForCompaction() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
flushCurrentLogs method is called during checkpoint, so metadata of the file also should be force written.
createNewLogForCompaction() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
createNewLogForCompaction(File) - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
createOpLogger - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
createParentNode(String) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Creates a parent node to be added to the list of children.
createReadOnly(long, LedgerStorage) - Static method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
createRegistrationManager() - Method in interface org.apache.bookkeeper.meta.MetadataBookieDriver
Create the registration manager used for registering/unregistering bookies.
createRegistrationManager() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver
 
createRegistrationManager() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataBookieDriver
 
createScannableTable(String) - Method in class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
createScannableTable(String) - Method in interface org.apache.bookkeeper.metastore.MetaStore
Create a scannable metastore table.
createServer(File, File, int, int) - Static method in class org.apache.bookkeeper.shims.zk.ZooKeeperServerShimFactory
 
createSingleThreadExecutor(ThreadFactory) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
createSingleThreadExecutor(ThreadFactory) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
 
createStateful() - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
createStateful() - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
createStateful() - Method in class com.scurrilous.circe.impl.IntStatelessLongHash
 
createStateful() - Method in interface com.scurrilous.circe.StatelessHash
Returns a new instance of stateful version of this hash function.
createStateful() - Method in interface com.scurrilous.circe.StatelessIntHash
Returns a new instance of stateful version of this hash function.
createStateful() - Method in interface com.scurrilous.circe.StatelessLongHash
Returns a new instance of stateful version of this hash function.
createStateful(HashParameters) - Static method in class com.scurrilous.circe.Hashes
Creates a stateful hash function using the given parameters.
createStateful(HashParameters) - Method in interface com.scurrilous.circe.HashProvider
Creates a stateful hash function using the given parameters.
createStateful(HashParameters) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
 
createTable(String) - Method in class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
createTable(String) - Method in interface org.apache.bookkeeper.metastore.MetaStore
Create a metastore table.
createTempDir(String, String) - Static method in class org.apache.bookkeeper.util.IOUtils
Create a temp directory with given prefix and suffix.
createTempDir(String, String, File) - Static method in class org.apache.bookkeeper.util.IOUtils
Create a temp directory with given prefix and suffix in the specified dir.
createTempFileAndDeleteOnExit(String, String) - Static method in class org.apache.bookkeeper.util.IOUtils
Create a temp directory with given prefix and suffix.
createZooKeeper() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
CTDBFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToDBStorageCommand.CTDBFlags
 
CTIME_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
CTIME_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
CTISFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToInterleavedStorageCommand.CTISFlags
 
CTOKEN_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
ctx - Variable in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
ctx - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
ctx - Variable in class org.apache.bookkeeper.client.LedgerDeleteOp
 
ctx - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
ctx - Variable in class org.apache.bookkeeper.client.ListenerBasedPendingReadOp
 
ctx - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
ctx - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
ctx - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler.AuthHandshakeCompleteCallback
 
ctx - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler.AuthRequestCallback
 
ctx - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
ctx() - Method in class org.apache.bookkeeper.proto.BookieRequestHandler
 
ctx() - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
ctx() - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
ctx() - Method in interface org.apache.bookkeeper.slogger.Slogger
 
ctx(Class<?>) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
ctx(Class<?>) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
ctx(Class<?>) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
CtxIterator() - Constructor for class org.apache.bookkeeper.slogger.AbstractSlogger.CtxIterator
 
cummulativeMap - Variable in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
CUR_VERSION - Static variable in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
CUR_VERSION - Static variable in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
CUR_VERSION - Static variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
CUR_VERSION - Static variable in class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
current - Variable in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
current - Variable in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
CURRENT_COOKIE_LAYOUT_VERSION - Static variable in class org.apache.bookkeeper.bookie.Cookie
 
CURRENT_DIR - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
CURRENT_HEADER_VERSION - Static variable in class org.apache.bookkeeper.bookie.FileInfo
 
CURRENT_HEADER_VERSION - Static variable in class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
CURRENT_JOURNAL_FORMAT_VERSION - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
CURRENT_METADATA_FORMAT_VERSION - Static variable in class org.apache.bookkeeper.meta.LedgerMetadataSerDe
 
CURRENT_PROTOCOL_VERSION - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Current version of the protocol, which client will use.
CURRENT_STATUS_LAYOUT_VERSION - Static variable in class org.apache.bookkeeper.bookie.BookieStatus
 
currentEnsemble - Variable in class org.apache.bookkeeper.client.ForceLedgerOp
 
currentEnsemble - Variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
currentEnsemble - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
currentEnsemble - Variable in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
currentEntry - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterator
 
currentID - Variable in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo.EntryIterator
 
currentLedgerLength - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
currentNonDurableLastAddConfirmed - Variable in class org.apache.bookkeeper.client.ForceLedgerOp
 
currentSeed - Variable in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo.EntryIterator
 
currentUsage() - Method in class org.apache.bookkeeper.common.util.MemoryLimitController
 
cursor - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager.MSLedgerRangeIterator
Deprecated.
 
customMetadata - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
CUSTOMMETADATA_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 

D

DaemonThreadFactory - Class in org.apache.bookkeeper.util
Daemon thread factory.
DaemonThreadFactory() - Constructor for class org.apache.bookkeeper.util.DaemonThreadFactory
 
DaemonThreadFactory(int) - Constructor for class org.apache.bookkeeper.util.DaemonThreadFactory
 
data - Variable in class org.apache.bookkeeper.client.LedgerEntry
 
data - Variable in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
data - Variable in class org.apache.bookkeeper.proto.BookieProtocol.ParsedAddRequest
 
data - Variable in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
DATA_INTEG_SERVICE_ERROR - org.apache.bookkeeper.bookie.datainteg.Events
An error occurred in the in the data integrity service loop.
DATA_INTEG_SERVICE_INTERRUPTED - org.apache.bookkeeper.bookie.datainteg.Events
Data integrity service thread interrupted.
DATA_INTEG_SERVICE_START - org.apache.bookkeeper.bookie.datainteg.Events
Data integrity service has started It runs at an interval to check if a full integrity check is needed, and if so runs it.
DATA_INTEG_SERVICE_STOP - org.apache.bookkeeper.bookie.datainteg.Events
Data integrity service has been stopped.
DATA_INTEG_SERVICE_UNCAUGHT_ERROR - org.apache.bookkeeper.bookie.datainteg.Events
An exception was thrown on the data integrity service executor and never caught.
DATA_INTEGRITY_CHECKING_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
DATA_INTEGRITY_COOKIE_STAMPING_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
DATA_LOSS - org.apache.bookkeeper.client.LedgerFragment.ReplicateType
 
DATA_NOT_ADHERING_PLACEMENT - org.apache.bookkeeper.client.LedgerFragment.ReplicateType
 
DataFormats - Class in org.apache.bookkeeper.proto
 
DataFormats.AuditorVoteFormat - Class in org.apache.bookkeeper.proto
Debug information for auditor votes
DataFormats.AuditorVoteFormat.Builder - Class in org.apache.bookkeeper.proto
Debug information for auditor votes
DataFormats.AuditorVoteFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.BookieServiceInfoFormat - Class in org.apache.bookkeeper.proto
information about services exposed by a Bookie.
DataFormats.BookieServiceInfoFormat.Builder - Class in org.apache.bookkeeper.proto
information about services exposed by a Bookie.
DataFormats.BookieServiceInfoFormat.Endpoint - Class in org.apache.bookkeeper.proto
Information about an endpoint.
DataFormats.BookieServiceInfoFormat.Endpoint.Builder - Class in org.apache.bookkeeper.proto
Information about an endpoint.
DataFormats.BookieServiceInfoFormat.EndpointOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.BookieServiceInfoFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.CheckAllLedgersFormat - Class in org.apache.bookkeeper.proto
information of checkAllLedgers execution
DataFormats.CheckAllLedgersFormat.Builder - Class in org.apache.bookkeeper.proto
information of checkAllLedgers execution
DataFormats.CheckAllLedgersFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.CookieFormat - Class in org.apache.bookkeeper.proto
Cookie format for storing cookie information
DataFormats.CookieFormat.Builder - Class in org.apache.bookkeeper.proto
Cookie format for storing cookie information
DataFormats.CookieFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.LedgerMetadataFormat - Class in org.apache.bookkeeper.proto
Metadata format for storing ledger information
DataFormats.LedgerMetadataFormat.Builder - Class in org.apache.bookkeeper.proto
Metadata format for storing ledger information
DataFormats.LedgerMetadataFormat.cMetadataMapEntry - Class in org.apache.bookkeeper.proto
Protobuf type LedgerMetadataFormat.cMetadataMapEntry
DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder - Class in org.apache.bookkeeper.proto
Protobuf type LedgerMetadataFormat.cMetadataMapEntry
DataFormats.LedgerMetadataFormat.cMetadataMapEntryOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.LedgerMetadataFormat.DigestType - Enum in org.apache.bookkeeper.proto
Protobuf enum LedgerMetadataFormat.DigestType
DataFormats.LedgerMetadataFormat.Segment - Class in org.apache.bookkeeper.proto
Protobuf type LedgerMetadataFormat.Segment
DataFormats.LedgerMetadataFormat.Segment.Builder - Class in org.apache.bookkeeper.proto
Protobuf type LedgerMetadataFormat.Segment
DataFormats.LedgerMetadataFormat.SegmentOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.LedgerMetadataFormat.State - Enum in org.apache.bookkeeper.proto
Protobuf enum LedgerMetadataFormat.State
DataFormats.LedgerMetadataFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.LedgerRereplicationLayoutFormat - Class in org.apache.bookkeeper.proto
Protobuf type LedgerRereplicationLayoutFormat
DataFormats.LedgerRereplicationLayoutFormat.Builder - Class in org.apache.bookkeeper.proto
Protobuf type LedgerRereplicationLayoutFormat
DataFormats.LedgerRereplicationLayoutFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.LockDataFormat - Class in org.apache.bookkeeper.proto
Debug information for locks
DataFormats.LockDataFormat.Builder - Class in org.apache.bookkeeper.proto
Debug information for locks
DataFormats.LockDataFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.PlacementPolicyCheckFormat - Class in org.apache.bookkeeper.proto
information of PlacementPolicyCheck execution
DataFormats.PlacementPolicyCheckFormat.Builder - Class in org.apache.bookkeeper.proto
information of PlacementPolicyCheck execution
DataFormats.PlacementPolicyCheckFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.ReplicasCheckFormat - Class in org.apache.bookkeeper.proto
information of ReplicasCheck execution
DataFormats.ReplicasCheckFormat.Builder - Class in org.apache.bookkeeper.proto
information of ReplicasCheck execution
DataFormats.ReplicasCheckFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataFormats.UnderreplicatedLedgerFormat - Class in org.apache.bookkeeper.proto
Protobuf type UnderreplicatedLedgerFormat
DataFormats.UnderreplicatedLedgerFormat.Builder - Class in org.apache.bookkeeper.proto
Protobuf type UnderreplicatedLedgerFormat
DataFormats.UnderreplicatedLedgerFormatOrBuilder - Interface in org.apache.bookkeeper.proto
 
DataIntegrityCheck - Interface in org.apache.bookkeeper.bookie.datainteg
The interface for the data integrity check feature.
DataIntegrityCheckImpl - Class in org.apache.bookkeeper.bookie.datainteg
An implementation of the DataIntegrityCheck interface.
DataIntegrityCheckImpl(BookieId, LedgerManager, LedgerStorage, EntryCopier, BookKeeperAdmin, Scheduler) - Constructor for class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
DataIntegrityCheckImpl.LedgerResult - Class in org.apache.bookkeeper.bookie.datainteg
 
DataIntegrityCheckImpl.LedgerResult.State - Enum in org.apache.bookkeeper.bookie.datainteg
 
DataIntegrityCookieValidation - Class in org.apache.bookkeeper.bookie.datainteg
An implementation of the CookieValidation interface that allows for auto-stamping cookies when configured and used in conjunction with the data integrity service.
DataIntegrityCookieValidation(ServerConfiguration, RegistrationManager, DataIntegrityCheck) - Constructor for class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCookieValidation
 
DataIntegrityService - Class in org.apache.bookkeeper.bookie.datainteg
An abstract lifecycle component that can perform data integrity checking.
DataIntegrityService(BookieConfiguration, StatsLogger, DataIntegrityCheck) - Constructor for class org.apache.bookkeeper.bookie.datainteg.DataIntegrityService
 
DataSketchesOpStatsLogger - Class in org.apache.bookkeeper.stats.prometheus
OpStatsLogger implementation that uses DataSketches library to calculate the approximated latency quantiles.
DataSketchesOpStatsLogger(Map<String, String>) - Constructor for class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
DataUnknownException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
DataUnknownException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Operations failed due to ledger data in an unknown state.
DataUnknownException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.DataUnknownException
 
DataUnknownException(String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.DataUnknownException
 
DataUnknownException(String, Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.DataUnknownException
 
DataUnknownException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.DataUnknownException
 
db() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
DbLedgerStorage - Class in org.apache.bookkeeper.bookie.storage.ldb
Implementation of LedgerStorage that uses RocksDB to keep the indexes for entries stored in EntryLogs.
DbLedgerStorage() - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
DbLedgerStorageDataFormats - Class in org.apache.bookkeeper.bookie.storage.ldb
 
DbLedgerStorageDataFormats.LedgerData - Class in org.apache.bookkeeper.bookie.storage.ldb
Ledger metadata stored in the bookie
DbLedgerStorageDataFormats.LedgerData.Builder - Class in org.apache.bookkeeper.bookie.storage.ldb
Ledger metadata stored in the bookie
DbLedgerStorageDataFormats.LedgerDataOrBuilder - Interface in org.apache.bookkeeper.bookie.storage.ldb
 
DbLedgerStorageStats - Class in org.apache.bookkeeper.bookie.storage.ldb
A umbrella class for db ledger storage stats with one instance per ledger directory.
DbLedgerStorageStats(StatsLogger, Supplier<Long>, Supplier<Long>, Supplier<Long>, Supplier<Long>) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
DEAD_REF - Static variable in class org.apache.bookkeeper.bookie.FileInfoBackingCache
 
deallocate() - Method in class org.apache.bookkeeper.util.ByteBufList
 
DEATH_WATCH_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
deathWatcher - Variable in class org.apache.bookkeeper.proto.BookieServer
 
deathWatcher - Variable in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
dec() - Method in class org.apache.bookkeeper.client.SyncCounter
 
dec() - Method in interface org.apache.bookkeeper.stats.Counter
Decrement the value associated with this stat.
dec() - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullCounter
 
dec() - Method in class org.apache.bookkeeper.stats.otel.OtelCounter
 
dec() - Method in class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
 
dec() - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedLongAdderCounter
 
decode(ByteBuf) - Method in interface org.apache.bookkeeper.proto.BookieProtoEncoding.EnDecoder
Decode a packet into an object.
decode(ByteBuf) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEnDeCoderPreV3
 
decode(ByteBuf) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEnDecoderV3
 
decode(ByteBuf) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEnDeCoderPreV3
 
decode(ByteBuf) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEnDecoderV3
 
decommissionBookie(BookieId) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Triggers AuditTask by resetting lostBookieRecoveryDelay and then make sure the ledgers stored in the given decommissioning bookie are properly replicated and they are not underreplicated because of the given bookie.
DecommissionBookieCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.DecommissionBookieCmd
 
DecommissionCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
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.
DecommissionCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.DecommissionCommand
 
DecommissionCommand.DecommissionFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Flags for decommission command.
DecommissionFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.DecommissionCommand.DecommissionFlags
 
DecommissionService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper Decommission related http request.
DecommissionService(ServerConfiguration, BookKeeperAdmin, ExecutorService) - Constructor for class org.apache.bookkeeper.server.http.service.DecommissionService
 
DECORRELATED - org.apache.bookkeeper.common.util.Backoff.Jitter.Type
 
decorrelatedJittered(long, long) - Static method in class org.apache.bookkeeper.common.util.Backoff
Create an infinite backoffs that have jitter with a random distribution between startMs and 3 times the previously selected value, capped at maxMs.
decReads(Consumer<Integer>) - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
Default - org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageFactory.DbConfigType
 
DEFAULT - Static variable in interface org.apache.bookkeeper.bookie.CheckpointSource
 
DEFAULT - Static variable in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
The default key group.
DEFAULT - Static variable in class org.apache.bookkeeper.common.util.Backoff
 
DEFAULT_ARG_COUNT - Static variable in class org.apache.bookkeeper.net.ScriptBasedMapping
Default number of arguments: 100.
DEFAULT_BCBUILDER - Static variable in interface org.apache.bookkeeper.bookie.Journal.BufferedChannelBuilder
 
DEFAULT_ENTRY_FORMATTER - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
DEFAULT_HOST_LEVEL - Static variable in class org.apache.bookkeeper.net.NetworkTopologyImpl
 
DEFAULT_LEDGERID_FORMATTER - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
DEFAULT_LOADER - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
DEFAULT_LOCAL_STREAM_STORAGE_SERVICE_URI - Static variable in class org.apache.bookkeeper.common.net.ServiceURI
The default local bk service uri.
DEFAULT_MAX_BATCH_READ_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
DEFAULT_NETTY_MAX_FRAME_SIZE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
DEFAULT_PROMETHEUS_STATS_HTTP_ADDR - Static variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
DEFAULT_PROMETHEUS_STATS_HTTP_ENABLE - Static variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
DEFAULT_PROMETHEUS_STATS_HTTP_PORT - Static variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
DEFAULT_PROMETHEUS_STATS_LATENCY_ROLLOVER_SECONDS - Static variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
DEFAULT_RACK - Static variable in interface org.apache.bookkeeper.net.NetworkTopology
 
DEFAULT_REGION - Static variable in interface org.apache.bookkeeper.net.NetworkTopology
 
DEFAULT_REGION_AND_RACK - Static variable in interface org.apache.bookkeeper.net.NetworkTopology
 
DEFAULT_ROCKSDB_CONF - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
DEFAULT_UPGRADEDOMAIN - Static variable in interface org.apache.bookkeeper.net.NetworkTopology
 
DEFAULT_ZK_LEDGERS_ROOT_PATH - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
DEFAULT_ZONE - Static variable in interface org.apache.bookkeeper.net.NetworkTopology
 
DEFAULT_ZONE_AND_UPGRADEDOMAIN - Static variable in interface org.apache.bookkeeper.net.NetworkTopology
 
DefaultBookieAddressResolver - Class in org.apache.bookkeeper.client
Resolve BookieIDs to Network addresses.
DefaultBookieAddressResolver(RegistrationClient) - Constructor for class org.apache.bookkeeper.client.DefaultBookieAddressResolver
 
DefaultEnsemblePlacementPolicy - Class in org.apache.bookkeeper.client
Default Ensemble Placement Policy, which picks bookies randomly.
DefaultEnsemblePlacementPolicy() - Constructor for class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
DefaultEntryLogger - Class in org.apache.bookkeeper.bookie
This class manages the writing of the bookkeeper entries.
DefaultEntryLogger(ServerConfiguration) - Constructor for class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
DefaultEntryLogger(ServerConfiguration, LedgerDirsManager) - Constructor for class org.apache.bookkeeper.bookie.DefaultEntryLogger
Create an EntryLogger that stores it's log files in the given directories.
DefaultEntryLogger(ServerConfiguration, LedgerDirsManager, DefaultEntryLogger.EntryLogListener, StatsLogger, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
DefaultEntryLogger.BufferedLogChannel - Class in org.apache.bookkeeper.bookie
 
DefaultEntryLogger.EntryLogListener - Interface in org.apache.bookkeeper.bookie
Entry Log Listener.
DefaultEntryLogger.EntryLookupException - Exception in org.apache.bookkeeper.bookie
Exception type for representing lookup errors.
DefaultEntryLogger.EntryLookupException.InvalidEntryLengthException - Exception in org.apache.bookkeeper.bookie
Represents case where log is present, but encoded entry length header is invalid.
DefaultEntryLogger.EntryLookupException.MissingEntryException - Exception in org.apache.bookkeeper.bookie
Represents case where entry log is present, but does not contain the specified entry.
DefaultEntryLogger.EntryLookupException.MissingLogFileException - Exception in org.apache.bookkeeper.bookie
Represents case where log file is missing.
DefaultEntryLogger.EntryLookupException.WrongEntryException - Exception in org.apache.bookkeeper.bookie
Represents case where the entry at pos is wrong.
DefaultEntryLogger.RecentEntryLogsStatus - Class in org.apache.bookkeeper.bookie
Datastructure which maintains the status of logchannels.
DefaultFileChannel - Class in org.apache.bookkeeper.bookie
Default FileChannel for bookie to read and write.
DefaultFileChannel(File, ServerConfiguration) - Constructor for class org.apache.bookkeeper.bookie.DefaultFileChannel
 
DefaultFileChannelProvider - Class in org.apache.bookkeeper.bookie
A wrapper of FileChannel.
DefaultFileChannelProvider() - Constructor for class org.apache.bookkeeper.bookie.DefaultFileChannelProvider
 
DefaultPerChannelBookieClientPool - Class in org.apache.bookkeeper.proto
Provide a simple round-robin style channel pool.
DefaultPerChannelBookieClientPool(ClientConfiguration, PerChannelBookieClientFactory, BookieId, int) - Constructor for class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
defaultRackSupplier - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DefaultResolver
 
defaultRackSupplier - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DNSResolverDecorator
 
DefaultResolver(Supplier<String>) - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DefaultResolver
 
defaultSize - Variable in class org.apache.bookkeeper.streaming.LedgerInputStream
 
defaultSize - Variable in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
DefaultSpeculativeRequestExecutionPolicy - Class in org.apache.bookkeeper.client
A default implementation of SpeculativeRequestExecutionPolicy.
DefaultSpeculativeRequestExecutionPolicy(int, int, float) - Constructor for class org.apache.bookkeeper.client.DefaultSpeculativeRequestExecutionPolicy
 
defaultValue() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Default value as a string representation.
defaultValue(Object) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
Default value as a string representation.
defaultValue(Object) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Default value as a string representation.
defaultValues() - Static method in class org.apache.bookkeeper.client.ClientInternalConf
 
DEFERRED_SYNC - org.apache.bookkeeper.client.api.WriteFlag
Writes will be acknowledged after writing to the filesystem but not yet been persisted to disks.
DELAY_ENSEMBLE_CHANGE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
delayedWriteFailedBookies - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
delayEnsembleChange - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
delegate() - Method in class org.apache.bookkeeper.common.util.BoundedExecutorService
 
delegate() - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
delegate() - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
delete() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
delete(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand.AdminFlags
 
delete(byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
 
delete(byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
delete(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
delete(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
delete(String, int) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
delete(String, int, AsyncCallback.VoidCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
DELETE_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
DeleteBuilder - Interface in org.apache.bookkeeper.client.api
Builder-style interface to delete exiting ledgers.
DeleteBuilderImpl(BookKeeper) - Constructor for class org.apache.bookkeeper.client.LedgerDeleteOp.DeleteBuilderImpl
 
deleteComplete(int, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.DeleteCallback
Callback definition for delete operations.
deleteComplete(int, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.SyncDeleteCallback
Delete callback implementation for synchronous delete call.
deleteCookie - Variable in class org.apache.bookkeeper.server.http.service.RecoveryBookieService.RecoveryRequestJsonBody
 
deleteCookie(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FormatCommand.Flags
 
deleteCookie(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
DeleteCookieCommand - Class in org.apache.bookkeeper.tools.cli.commands.cookie
A command that deletes cookie.
DeleteCookieCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.DeleteCookieCommand
 
DeleteCookieCommand(PrintStream) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.DeleteCookieCommand
 
DeleteCookieCommand(DeleteCookieCommand.Flags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.DeleteCookieCommand
 
DeleteCookieCommand.Flags - Class in org.apache.bookkeeper.tools.cli.commands.cookie
Flags to delete a cookie for a given bookie.
DELETED_LEDGER_COUNT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
deleteFromRegistrationManager(RegistrationManager, ServerConfiguration, Version) - Method in class org.apache.bookkeeper.bookie.Cookie
Deletes cookie from registration manager.
deleteFromRegistrationManager(RegistrationManager, BookieId, Version) - Method in class org.apache.bookkeeper.bookie.Cookie
Delete cookie from registration manager.
deleteFullPathOptimistic(ZooKeeper, String, int) - Static method in class org.apache.bookkeeper.util.ZkUtils
 
deleteLedger(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
deleteLedger(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
deleteLedger(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
deleteLedger(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
This method is called whenever a ledger is deleted by the BookKeeper Client and we want to remove all relevant data for it stored in the LedgerCache.
deleteLedger(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
deleteLedger(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
deleteLedger(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
deleteLedger(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
deleteLedger(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
deleteLedger(long) - Method in class org.apache.bookkeeper.client.BookKeeper
Synchronous call to delete a ledger.
deleteLedger(long, Consumer<Integer>) - Method in interface org.apache.bookkeeper.verifier.BookkeeperVerifier.BookkeeperDriver
 
deleteLedger(long, Consumer<Integer>) - Method in class org.apache.bookkeeper.verifier.DirectBookkeeperDriver
 
DeleteLedgerCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.DeleteLedgerCmd
 
DeleteLedgerCommand - Class in org.apache.bookkeeper.tools.cli.commands.client
Command to delete a given ledger.
DeleteLedgerCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.DeleteLedgerCommand
 
DeleteLedgerCommand(LedgerIdFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.DeleteLedgerCommand
 
DeleteLedgerCommand.DeleteLedgerFlags - Class in org.apache.bookkeeper.tools.cli.commands.client
Flags for delete ledger command.
DeleteLedgerFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.DeleteLedgerCommand.DeleteLedgerFlags
 
deleteLedgerLayout() - Method in interface org.apache.bookkeeper.meta.LayoutManager
Delete ledger layout.
deleteLedgerLayout() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLayoutManager
 
deleteLedgerLayout() - Method in class org.apache.bookkeeper.meta.ZkLayoutManager
Delete the ledger layout from zookeeper.
DeleteLedgerService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper delete ledger related http request.
DeleteLedgerService(ServerConfiguration) - Constructor for class org.apache.bookkeeper.server.http.service.DeleteLedgerService
 
deleteOpLogger - Variable in class org.apache.bookkeeper.client.LedgerDeleteOp
 
deleteRange(byte[], byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage.Batch
 
deleteWatcher(Watcher<T>) - Method in class org.apache.bookkeeper.common.util.Watchable
Deletes an watcher from the set of watcher of this object.
deleteWatchers() - Method in class org.apache.bookkeeper.common.util.Watchable
Clears the watcher list so that this object no longer has any watchers.
DELIMITER - Static variable in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
dependents() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The list of settings dependents on this setting.
dependents(List<String>) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
The list of settings dependents on this setting.
dependents(List<String>) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The list of settings dependents on this setting.
deprecated() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Whether this setting is deprecated or not.
deprecated(boolean) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
Whether this setting is deprecated or not.
deprecated(boolean) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Whether this setting is deprecated or not.
deprecatedByConfigKey() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The config key that deprecates this key.
deprecatedByConfigKey(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
The config key that deprecates this key.
deprecatedByConfigKey(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The config key that deprecates this key.
deprecatedSince() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The version when this settings was deprecated.
deprecatedSince(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
The version when this settings was deprecated.
deprecatedSince(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The version when this settings was deprecated.
DESC - org.apache.bookkeeper.metastore.MetastoreScannableTable.Order
 
description() - Method in interface org.apache.bookkeeper.bookie.BookieShell.Command
 
description() - Method in class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
description() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Description of the configuration setting.
description() - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
Description of the key group.
description() - Method in class org.apache.bookkeeper.tools.cli.helpers.BookieShellCommand
 
description() - Method in class org.apache.bookkeeper.tools.framework.CliCommand
 
description() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
description() - Method in interface org.apache.bookkeeper.tools.framework.Command
Return description name.
description() - Method in class org.apache.bookkeeper.tools.framework.HelpCommand
 
description(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
Description of the configuration setting.
description(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Description of the configuration setting.
description(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup.ConfigKeyGroupBuilder
Description of the key group.
description(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
Description of the key group.
deserialize(DataInputStream) - Static method in class org.apache.bookkeeper.bookie.EntryLogMetadata
Deserializes EntryLogMetadata.EntryLogMetadataRecyclable from given DataInputStream.
deserializeBookieServiceInfo(BookieId, byte[]) - Static method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
DESIRED_NUM_ZONES_PER_WRITE_QUORUM - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
desiredNumZonesPerWriteQuorum - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
destBookie(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags
 
DESTROY_DELAY_SECONDS - Static variable in class org.apache.bookkeeper.common.util.SharedResourceManager
 
DETECTED_FATAL_SCRUB_ERRORS - Static variable in class org.apache.bookkeeper.bookie.ScrubberStats
 
DETECTED_SCRUB_ERRORS - Static variable in class org.apache.bookkeeper.bookie.ScrubberStats
 
DetectedInconsistency(long, long, Exception) - Constructor for class org.apache.bookkeeper.bookie.LedgerStorage.DetectedInconsistency
 
diff(BKStats) - Method in class org.apache.bookkeeper.proto.BKStats
Diff with base stats.
diff(BKStats.OpStats) - Method in class org.apache.bookkeeper.proto.BKStats.OpStats
Diff with base opstats.
diffEnsemble(List<BookieId>, List<BookieId>) - Static method in class org.apache.bookkeeper.client.EnsembleUtils
 
differBetweenBookies(List<BookieId>, List<BookieId>) - Static method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
DIGEST_ALGORITHM - Static variable in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
DIGEST_TYPE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
DigestManager - Class in org.apache.bookkeeper.proto.checksum
This class takes an entry, attaches a digest to it and packages it with relevant data so that it can be shipped to the bookie.
DigestManager(long, boolean, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.proto.checksum.DigestManager
 
DigestManager.RecoveryData - Class in org.apache.bookkeeper.proto.checksum
A representation of RecoveryData.
DigestMatchException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Digest doesn't match on returned entries.
DigestNotInitializedException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Digest Manager is not initialized (client error).
digestType - Variable in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
digestType - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
DigestType - Enum in org.apache.bookkeeper.client.api
Digest type.
DIGESTTYPE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
dir(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand.ReadJournalFlags
 
DIRECT_IO_ENTRYLOGGER - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
DIRECT_IO_ENTRYLOGGER_MAX_FD_CACHE_TIME_SECONDS - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
DIRECT_IO_ENTRYLOGGER_READBUFFER_SIZE_MB - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
DIRECT_IO_ENTRYLOGGER_TOTAL_READBUFFER_SIZE_MB - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
DIRECT_IO_ENTRYLOGGER_TOTAL_WRITEBUFFER_SIZE_MB - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
DirectBookkeeperDriver - Class in org.apache.bookkeeper.verifier
Driver for a normal Bookkeeper cluster.
DirectBookkeeperDriver(BookKeeper) - Constructor for class org.apache.bookkeeper.verifier.DirectBookkeeperDriver
 
DirectByteBufferAccess - Interface in com.scurrilous.circe.impl
Service used to provide the native memory address of direct byte buffers.
DirectByteBufferAccessLoader - Class in com.scurrilous.circe.impl
Provides access to a singleton DirectByteBufferAccess implementation, if one is available.
DirectCompactionEntryLog - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
DirectCompactionEntryLog.
DirectEntryLogger - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
DirectEntryLogger.
DirectEntryLogger(File, EntryLogIds, NativeIO, ByteBufAllocator, ExecutorService, ExecutorService, long, int, long, long, int, int, int, Slogger, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
DirectEntryLoggerStats - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
 
DirectEntryLoggerStats(StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLoggerStats
 
DirectMemoryCRC32Digest - Class in org.apache.bookkeeper.proto.checksum
Specialized implementation of CRC32 digest that uses reflection on CRC32 class to get access to "updateByteBuffer" method and pass a direct memory pointer.
DirectMemoryCRC32Digest() - Constructor for class org.apache.bookkeeper.proto.checksum.DirectMemoryCRC32Digest
 
DirectReader - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
 
DirectReader(int, String, ByteBufAllocator, NativeIO, int, int, OpStatsLogger) - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
DirectWriter - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
 
DirectWriter(int, String, long, ExecutorService, BufferPool, NativeIO, Slogger) - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
dirsListener - Variable in class org.apache.bookkeeper.bookie.SyncThread
 
dirsMonitor - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
dirsToCleanUp - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
dirSuffix - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
DIRTY_FILENAME - Static variable in class org.apache.bookkeeper.bookie.UncleanShutdownDetectionImpl
 
DISABLE_ALL - Static variable in class org.apache.bookkeeper.feature.SettableFeatureProvider
 
DISABLE_ENSEMBLE_CHANGE_FEATURE_NAME - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
DISABLE_HEALTH_CHECK - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
DISABLE_NODE - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
DISABLE_SERVER_SOCKET_BIND - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
disableCheckpoint() - Method in class org.apache.bookkeeper.bookie.SyncThread
 
disableCpu(int) - Static method in class org.apache.bookkeeper.common.util.affinity.impl.IsolatedProcessors
Instruct Linux to disable a particular CPU.
Disabled - org.apache.bookkeeper.common.allocator.LeakDetectionPolicy
No leak detection and no overhead.
disableDurabilityFeature - Variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
disableEnsembleChangeFeature - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
disableForceGC() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
disableHealthCheck() - Method in interface org.apache.bookkeeper.meta.MetadataBookieDriver
Disable health check.
disableHealthCheck() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
disableHealthCheckPath - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
disableLedgerReplication() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Stop ledger replication.
disableLedgerReplication() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
disableLedgerReplication() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
disallowBookiePlacementInRegionFeatureName - Variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
discardReadBytes() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
discardSomeReadBytes() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
disconnect() - Method in interface org.apache.bookkeeper.proto.ConnectionPeer
Utility function to be used from AuthProviders to drop the connection.
disconnect() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
Disconnects the bookie client.
disconnect(boolean) - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
disconnect(boolean) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
disconnect(boolean) - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientPool
Disconnect the connections in the pool.
DISCONNECTED - org.apache.bookkeeper.proto.PerChannelBookieClient.ConnectionState
 
DiscoveryCommand<DiscoveryFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.cli.helpers
This is a mixin for commands that talks to discovery service.
DiscoveryCommand(CliSpec<DiscoveryFlagsT>) - Constructor for class org.apache.bookkeeper.tools.cli.helpers.DiscoveryCommand
 
DISK_CHECK_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
DISK_USAGE_LWM_THRESHOLD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
DISK_USAGE_THRESHOLD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
DISK_USAGE_WARN_THRESHOLD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
DISK_WEIGHT_BASED_PLACEMENT_ENABLED - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
diskAlmostFull(File) - Method in interface org.apache.bookkeeper.bookie.LedgerDirsManager.LedgerDirsListener
Notified when the disk usage warn threshold is exceeded on the drive.
diskChecker(DiskChecker) - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
 
DiskChecker - Class in org.apache.bookkeeper.util
Class that provides utility functions for checking disk problems.
DiskChecker(float, float) - Constructor for class org.apache.bookkeeper.util.DiskChecker
 
DiskChecker.DiskErrorException - Exception in org.apache.bookkeeper.util
A disk error exception.
DiskChecker.DiskException - Exception in org.apache.bookkeeper.util
A general marker for disk-related exceptions.
DiskChecker.DiskOutOfSpaceException - Exception in org.apache.bookkeeper.util
An out-of-space disk exception.
DiskChecker.DiskWarnThresholdException - Exception in org.apache.bookkeeper.util
A disk warn threshold exception.
DiskErrorException(String) - Constructor for exception org.apache.bookkeeper.util.DiskChecker.DiskErrorException
 
DiskException(String) - Constructor for exception org.apache.bookkeeper.util.DiskChecker.DiskException
 
diskFailed(File) - Method in interface org.apache.bookkeeper.bookie.LedgerDirsManager.LedgerDirsListener
This will be notified on disk failure/disk error.
diskFull(File) - Method in interface org.apache.bookkeeper.bookie.LedgerDirsManager.LedgerDirsListener
This will be notified on disk detected as full.
diskJustWritable(File) - Method in interface org.apache.bookkeeper.bookie.LedgerDirsManager.LedgerDirsListener
This will be notified on disk detected as writable but still in warn threshold.
DiskOutOfSpaceException(String, float) - Constructor for exception org.apache.bookkeeper.util.DiskChecker.DiskOutOfSpaceException
 
DiskPartitionDuplicationException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
DiskPartitionDuplicationException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.DiskPartitionDuplicationException
 
DiskPartitionDuplicationException(String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.DiskPartitionDuplicationException
 
DiskPartitionDuplicationException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.DiskPartitionDuplicationException
 
DiskWarnThresholdException(String, float) - Constructor for exception org.apache.bookkeeper.util.DiskChecker.DiskWarnThresholdException
 
diskWritable(File) - Method in interface org.apache.bookkeeper.bookie.LedgerDirsManager.LedgerDirsListener
This will be notified on disk detected as writable and under warn threshold.
distanceFromLeaves - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
distributionSchedule - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
DistributionSchedule - Interface in org.apache.bookkeeper.client
This interface determins how entries are distributed among bookies.
DistributionSchedule.AckSet - Interface in org.apache.bookkeeper.client
An ack set represents the set of bookies from which a response must be received so that an entry can be considered to be replicated on a quorum.
DistributionSchedule.QuorumCoverageSet - Interface in org.apache.bookkeeper.client
Interface to keep track of which bookies in an ensemble, an action has been performed for.
DistributionSchedule.WriteSet - Interface in org.apache.bookkeeper.client
A write set represents the set of bookies to which a request will be written.
DNS - Class in org.apache.bookkeeper.net
A class that provides direct and reverse lookup functionalities, allowing the querying of specific network interfaces or nameservers.
DNS() - Constructor for class org.apache.bookkeeper.net.DNS
 
dnsResolver - Variable in class org.apache.bookkeeper.client.BookKeeper.Builder
 
dnsResolver - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
dnsResolver(DNSToSwitchMapping) - Method in interface org.apache.bookkeeper.client.api.BookKeeperBuilder
Configure the bookkeeper client to use the provided dns resolver DNSToSwitchMapping.
dnsResolver(DNSToSwitchMapping) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
Configure the bookkeeper client to use the provided dns resolver DNSToSwitchMapping.
dnsResolver(DNSToSwitchMapping) - Method in class org.apache.bookkeeper.client.impl.BookKeeperBuilderImpl
 
DNSResolverDecorator(DNSToSwitchMapping, Supplier<String>, Counter) - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DNSResolverDecorator
 
DNSToSwitchMapping - Interface in org.apache.bookkeeper.net
An interface that must be implemented to allow pluggable DNS-name/IP-address to RackID resolvers.
doAsyncAddEntry(PendingAddOp) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
doAsyncAddEntry(PendingAddOp) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
Overriding part is mostly around setting entryId.
doAsyncCloseInternal(AsyncCallback.CloseCallback, Object, int) - Method in class org.apache.bookkeeper.client.LedgerHandle
Same as public version of asyncClose except that this one takes an additional parameter which is the return code to hand to all the pending add ops.
doAsyncProcessLedgers(MetastoreCursor, BookkeeperInternalCallbacks.Processor<Long>, AsyncCallback.VoidCallback, Object, int, int) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
doCheckpoint(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.SyncThread
 
doClose() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityService
 
doClose() - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
doClose() - Method in class org.apache.bookkeeper.common.component.RxSchedulerLifecycleComponent
 
doClose() - Method in class org.apache.bookkeeper.server.service.AutoRecoveryService
 
doClose() - Method in class org.apache.bookkeeper.server.service.BookieService
 
doClose() - Method in class org.apache.bookkeeper.server.service.HttpService
 
doClose() - Method in class org.apache.bookkeeper.server.service.ScrubberService
 
doClose() - Method in class org.apache.bookkeeper.server.service.StatsProviderService
 
doCompactEntryLogs(double, long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
Compact entry logs if necessary.
doCounterMapCleanup() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger.EntryLogsPerLedgerCounter
 
documentation() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Documentation of the configuration setting.
documentation() - Method in interface org.apache.bookkeeper.common.conf.Validator
Return the documentation for a given validator.
documentation() - Method in class org.apache.bookkeeper.common.conf.validators.ClassValidator
 
documentation() - Method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
 
documentation(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
Documentation of the configuration setting.
documentation(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Documentation of the configuration setting.
doEntryLogMapCleanup() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusServlet
 
doLog(AbstractSlogger.Level, Enum<?>, String, Throwable, List<Object>) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
doLog(AbstractSlogger.Level, Enum<?>, String, Throwable, List<Object>) - Method in class org.apache.bookkeeper.slogger.ConsoleSlogger
 
doLog(AbstractSlogger.Level, Enum<?>, String, Throwable, List<Object>) - Method in class org.apache.bookkeeper.slogger.slf4j.Slf4jSlogger
 
doMain(String[]) - Static method in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
doMain(String[]) - Static method in class org.apache.bookkeeper.server.Main
 
done - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
doneLatch - Variable in class org.apache.bookkeeper.metastore.MetastoreUtils.MultiMetastoreCallback
 
doneLatch - Variable in class org.apache.bookkeeper.metastore.MetastoreUtils.SyncMetastoreCallback
 
doPlacementPolicyCheck(Long, AsyncCallback.VoidCallback, Versioned<LedgerMetadata>) - Method in class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusServlet
 
doRecovery - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
doRegisterBookie() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
doStart() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityService
 
doStart() - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
doStart() - Method in class org.apache.bookkeeper.common.component.RxSchedulerLifecycleComponent
 
doStart() - Method in class org.apache.bookkeeper.server.service.AutoRecoveryService
 
doStart() - Method in class org.apache.bookkeeper.server.service.BookieService
 
doStart() - Method in class org.apache.bookkeeper.server.service.HttpService
 
doStart() - Method in class org.apache.bookkeeper.server.service.ScrubberService
 
doStart() - Method in class org.apache.bookkeeper.server.service.StatsProviderService
 
doStop() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityService
 
doStop() - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
doStop() - Method in class org.apache.bookkeeper.common.component.RxSchedulerLifecycleComponent
 
doStop() - Method in class org.apache.bookkeeper.server.service.AutoRecoveryService
 
doStop() - Method in class org.apache.bookkeeper.server.service.BookieService
 
doStop() - Method in class org.apache.bookkeeper.server.service.HttpService
 
doStop() - Method in class org.apache.bookkeeper.server.service.ScrubberService
 
doStop() - Method in class org.apache.bookkeeper.server.service.StatsProviderService
 
doTransitionToReadOnlyMode() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
doTransitionToWritableMode() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
DOUBLE - org.apache.bookkeeper.common.conf.Type
 
drainPendingAddsAndAdjustLength() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
drainTo(Collection<? super T>) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
drainTo(Collection<? super T>) - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
drainTo(Collection<? super T>) - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
drainTo(Collection<? super T>, int) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
drainTo(Collection<? super T>, int) - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
drainTo(Collection<? super T>, int) - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
driverClass - Variable in class org.apache.bookkeeper.meta.MetadataDrivers.MetadataBookieDriverInfo
 
driverClass - Variable in class org.apache.bookkeeper.meta.MetadataDrivers.MetadataClientDriverInfo
 
driverClassName - Variable in class org.apache.bookkeeper.meta.MetadataDrivers.MetadataBookieDriverInfo
 
driverClassName - Variable in class org.apache.bookkeeper.meta.MetadataDrivers.MetadataClientDriverInfo
 
dryRun(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.RegenerateInterleavedStorageIndexFileCommand.RISIFFlags
 
dryRun(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
DryRunLedgerCache() - Constructor for class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
dstLogId - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
DUMMY - org.apache.bookkeeper.client.api.DigestType
Entries are not verified.
DUMMY - org.apache.bookkeeper.client.BookKeeper.DigestType
 
DUMMY - org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
DUMMY = 4;
DUMMY_VALUE - Static variable in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
DUMMY = 4;
DummyDigestManager - Class in org.apache.bookkeeper.proto.checksum
This class provides a noop digest implementation.
DummyDigestManager(long, boolean, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.proto.checksum.DummyDigestManager
 
dump() - Method in class org.apache.bookkeeper.bookie.EntryMemTable
 
dump(OutputStream) - Method in class org.apache.bookkeeper.stats.codahale.FastSnapshot
 
dumpToFile(String) - Method in class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand.LedgerMetadataFlag
 
dumpTopology() - Method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
Generate a string listing the switch mapping implementation, the mapping for every known node and the number of nodes and unique switches known about -each entry to a separate line.
duplicate() - Method in interface org.apache.bookkeeper.client.api.LedgerEntry
Returns a duplicate of this entry.
duplicate() - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
Returns a duplicate of this entry.
duplicate() - Method in interface org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.CoverageSet
 
duplicate() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackOrRegionDurabilityCoverageSet
 
duplicate() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackQuorumCoverageSet
 
duplicate() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
duplicate(LedgerEntry) - Static method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
 
DuplicateEntryIdException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Duplicated entry id is found when LedgerHandleAdv.addEntry(long, byte[]).
DynamicWeightedRandomSelectionImpl<T> - Class in org.apache.bookkeeper.client
DynamicWeightedRandomSelectionImpl class implements both getNextRandom overloaded methods.
DynamicWeightedRandomSelectionImpl() - Constructor for class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
DynamicWeightedRandomSelectionImpl(int) - Constructor for class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 

E

EBADREQ - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EBADREQ = 404;
EBADREQ - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The error code that indicates an invalid request type.
EBADREQ_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EBADREQ = 404;
EBADVERSION - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EBADVERSION = 503;
EBADVERSION - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The server version is incompatible with the client.
EBADVERSION_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EBADVERSION = 503;
EFENCED - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EFENCED = 504;
EFENCED - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Attempt to write to fenced ledger.
EFENCED_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EFENCED = 504;
eId - Variable in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
EIO - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
IO/access errors 5xx
EIO - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
General error occurred at the server.
EIO_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
IO/access errors 5xx
elapsedMicroSec(long) - Static method in class org.apache.bookkeeper.common.util.MathUtils
Microseconds elapsed since the time specified, the input is nanoTime the only conversion happens when computing the elapsed time.
elapsedMSec(long) - Static method in class org.apache.bookkeeper.common.util.MathUtils
Milliseconds elapsed since the time specified, the input is nanoTime the only conversion happens when computing the elapsed time.
elapsedNanos(long) - Static method in class org.apache.bookkeeper.common.util.MathUtils
Nanoseconds elapsed since the time specified, the input is nanoTime the only conversion happens when computing the elapsed time.
elapsedTimeMs - Variable in class org.apache.bookkeeper.zookeeper.ZooWorker
 
ELECTION_ATTEMPTS - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
element() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
EmbeddedServer - Class in org.apache.bookkeeper.server
An embedded server is a server that run bookie and serving rpc requests.
EmbeddedServer.Builder - Class in org.apache.bookkeeper.server
 
EMPTY - Static variable in class org.apache.bookkeeper.discover.BookieServiceInfo
Default empty implementation.
EMPTY_AVAILABILITYOFENTRIESOFLEDGER - Static variable in class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
EMPTY_BYTE_ARRAY - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
EMPTY_CURSOR - Static variable in interface org.apache.bookkeeper.metastore.MetastoreCursor
 
EMPTY_END_KEY - Static variable in interface org.apache.bookkeeper.metastore.MetastoreScannableTable
 
EMPTY_HEADER - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
EMPTY_LEDGER_KEY - Static variable in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
EMPTY_LIST - Static variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.EnsembleForReplacementWithNoConstraints
 
EMPTY_SET - Static variable in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
EMPTY_START_KEY - Static variable in interface org.apache.bookkeeper.metastore.MetastoreScannableTable
 
EMPTY_VALUE - Static variable in class org.apache.bookkeeper.bookie.EntryMemTable.EntrySkipList
 
emptyResponseReplicas - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
emptyResponsesFromHostsBitSet - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
enable(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ToggleCommand.AutoRecoveryFlags
 
enable(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.health.SwitchOfHealthCheckCommand.HealthCheckFlags
 
ENABLE_BOOKIE_FAILURE_TRACKING - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
ENABLE_BUSY_WAIT - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ENABLE_DIGEST_TYPE_AUTODETECTION - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
ENABLE_HEALTH_CHECK - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ENABLE_LOCAL_TRANSPORT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ENABLE_PARALLEL_RECOVERY_READ - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
ENABLE_STATISTICS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ENABLE_TASK_EXECUTION_STATS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
ENABLE_TASK_EXECUTION_STATS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
enableBookieFailureTracking - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
enableBookieHealthCheck() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enables the bookie health check.
enableBusyWait - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
enableBusyWait - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
enableBusyWait(boolean) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
enableCpu(int) - Static method in class org.apache.bookkeeper.common.util.affinity.impl.IsolatedProcessors
 
enableDigestAutodetection - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
enableForceGC() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
enableForceGC(boolean, boolean) - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
enableHealthCheck() - Method in interface org.apache.bookkeeper.meta.MetadataBookieDriver
Enable health check.
enableHealthCheck() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
enableJdkLinkApi(boolean) - Static method in class org.apache.bookkeeper.util.HardLink
 
enableLedgerReplication() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Resuming ledger replication.
enableLedgerReplication() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
enableLedgerReplication() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
enableMajorCompaction - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
enableMinorCompaction - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
enableParallelRecoveryRead - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
enableRecoveryAdd() - Method in class org.apache.bookkeeper.client.PendingAddOp
Enable the recovery add flag for this operation.
enableReorderReadSequence - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
enableStickyReads - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
enableThreadScopedMetrics - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
enableThreadScopedMetrics - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
enableThreadScopedMetrics(boolean) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
enableValidation - Variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
encode(Object, ByteBufAllocator) - Method in interface org.apache.bookkeeper.proto.BookieProtoEncoding.EnDecoder
Encode a object into channel buffer.
encode(Object, ByteBufAllocator) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEnDeCoderPreV3
 
encode(Object, ByteBufAllocator) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEnDecoderV3
 
encode(Object, ByteBufAllocator) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEnDeCoderPreV3
 
encode(Object, ByteBufAllocator) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEnDecoderV3
 
encodeDirPaths(String[]) - Static method in class org.apache.bookkeeper.bookie.Cookie
 
Encoder() - Constructor for class org.apache.bookkeeper.util.ByteBufList.Encoder
 
ENCODER - Static variable in class org.apache.bookkeeper.util.ByteBufList
Encoder for the ByteBufList that doesn't prepend any size header.
end() - Method in class org.apache.bookkeeper.meta.LedgerManager.LedgerRange
 
endEntryId - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
endEntryToRead - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
Endpoint() - Constructor for class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
Endpoint(String, int, String, String, List<String>, List<String>) - Constructor for class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
EndpointInfo(String, int, String, String, List<String>, List<String>) - Constructor for class org.apache.bookkeeper.common.component.ComponentInfoPublisher.EndpointInfo
 
EndpointInfoCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.EndpointInfoCmd
 
EndpointInfoCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Get endpoint information about a Bookie.
EndpointInfoCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.EndpointInfoCommand
 
EndpointInfoCommand.EndpointInfoFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Flags for this command.
EndpointInfoFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.EndpointInfoCommand.EndpointInfoFlags
 
ENDPOINTS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
endPos(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
ENFORCE_MIN_NUM_FAULT_DOMAINS_FOR_WRITE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ENFORCE_MIN_NUM_RACKS_PER_WRITE_QUORUM - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ENFORCE_STRICT_ZONEAWARE_PLACEMENT - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
enforceDurability - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
enforceDurabilityInReplace - Variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
enforceMinNumFaultDomainsForWrite - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
enforceMinNumRacksPerWriteQuorum - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
enforceStrictZoneawarePlacement - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
ENOENTRY - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
ENOENTRY = 403;
ENOENTRY - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The error code that indicates that the requested entry does not exist.
ENOENTRY_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
ENOENTRY = 403;
ENOLEDGER - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
Server side Errors 4xx
ENOLEDGER - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The error code that indicates that the ledger does not exist.
ENOLEDGER_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
Server side Errors 4xx
enqueueNanos - Variable in class org.apache.bookkeeper.proto.PacketProcessorBase
 
enqueueNanos - Variable in class org.apache.bookkeeper.proto.PacketProcessorBaseV3
 
enqueueTime - Variable in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
ensemble - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
ensemble - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
ensemble - Variable in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
ENSEMBLE_CHANGES - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
ENSEMBLE_NOT_ADHERING_TO_PLACEMENT_POLICY_COUNT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
ENSEMBLE_PLACEMENT_POLICY - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
ENSEMBLE_PLACEMENT_POLICY_ORDER_SLOW_BOOKIES - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
ensembleChangeCounter - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
ensembleChangeLoop(List<BookieId>, Map<Integer, BookieId>) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
EnsembleForReplacementWithNoConstraints() - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.EnsembleForReplacementWithNoConstraints
 
ENSEMBLEMEMBER_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
EnsemblePlacementPolicy - Interface in org.apache.bookkeeper.client
EnsemblePlacementPolicy encapsulates the algorithm that bookkeeper client uses to select a number of bookies from the cluster as an ensemble for storing entries.
EnsemblePlacementPolicy.PlacementPolicyAdherence - Enum in org.apache.bookkeeper.client
enum for PlacementPolicyAdherence.
EnsemblePlacementPolicy.PlacementResult<T> - Class in org.apache.bookkeeper.client
Result of a placement calculation against a placement policy.
ensemblesContainBookie(LedgerMetadata, BookieId) - Static method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
ensembleSize - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
ensembleSize - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
ensembleSize(int) - Method in class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand.Flags
 
ENSEMBLESIZE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
EnsembleUtils - Class in org.apache.bookkeeper.client
 
EnsembleUtils() - Constructor for class org.apache.bookkeeper.client.EnsembleUtils
 
ensure(CompletableFuture<T>, Runnable) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
ENSURE_LEDGER_ERROR - org.apache.bookkeeper.bookie.datainteg.Events
Preboot must create a ledger that the bookie does not have but that metadata says the bookie should have.
ensureWritable(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
ensureWritable(int, boolean) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
entries - Variable in class org.apache.bookkeeper.client.BatchedReadOp.BatchedLedgerEntryRequest
 
entries(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.SanityTestCommand.SanityFlags
 
ENTRIES_PER_PAE - Static variable in class org.apache.bookkeeper.server.http.service.ReadLedgerEntryService
 
entries2Ledgers(Iterator<MetastoreTableItem>) - Static method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
entriesPerPage - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
entriesPerPage - Variable in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
entriesPerPage - Variable in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
entry - Variable in class org.apache.bookkeeper.bookie.EntryLocation
 
entry - Variable in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
entry - Variable in class org.apache.bookkeeper.client.ReadOpBase.ReadContext
 
ENTRY_FORMATTER_CLASS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ENTRY_FORMATTER_OPT - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
ENTRY_ID_PENDING - Static variable in class org.apache.bookkeeper.client.LedgerHandle.LastConfirmedCtx
 
ENTRY_LOCATION_ROCKSDB_CONF - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ENTRY_LOG_FILE_PREALLOCATION_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ENTRY_LOG_PER_LEDGER_COUNTER_LIMITS_MULT_FACTOR - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ENTRY_LOG_PER_LEDGER_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ENTRY_LOG_SIZE_LIMIT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ENTRY_LOG_SIZE_LIMIT_KEY - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ENTRY_PIGGYBACK - org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
ENTRY_PIGGYBACK = 2;
ENTRY_PIGGYBACK_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
ENTRY_PIGGYBACK = 2;
EntryCopier - Interface in org.apache.bookkeeper.bookie.datainteg
Interface for copying entries from other bookies.
EntryCopier.Batch - Interface in org.apache.bookkeeper.bookie.datainteg
An interface for a batch to be copied.
EntryCopierImpl - Class in org.apache.bookkeeper.bookie.datainteg
Implementation for the EntryCopier interface.
EntryCopierImpl(BookieId, BookieClient, LedgerStorage, Ticker) - Constructor for class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl
 
EntryCopierImpl.BatchImpl - Class in org.apache.bookkeeper.bookie.datainteg
 
EntryCopierImpl.SinBin - Class in org.apache.bookkeeper.bookie.datainteg
 
entryExists(long, long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
entryExists(long, long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Whether an entry exists.
entryExists(long, long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
entryExists(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
entryExists(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
entryFormatter - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
entryFormatter - Variable in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand
 
entryFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand.ReadJournalFlags
 
entryFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
entryFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
EntryFormatter - Class in org.apache.bookkeeper.util
Formatter to format an entry.
EntryFormatter() - Constructor for class org.apache.bookkeeper.util.EntryFormatter
 
entryId - Variable in class org.apache.bookkeeper.bookie.EntryKey
 
entryId - Variable in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
entryId - Variable in class org.apache.bookkeeper.client.LedgerEntry
 
entryId - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
entryId - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
entryId - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
entryId - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
entryId - Variable in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
entryId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
ENTRYID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
ENTRYID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
ENTRYID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
ENTRYID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
entryImpl - Variable in class org.apache.bookkeeper.client.PendingReadOp.SingleLedgerEntryRequest
 
entryImpl - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
EntryInfo(long, long) - Constructor for class org.apache.bookkeeper.verifier.BookkeeperVerifier.EntryInfo
 
EntryIterator() - Constructor for class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo.EntryIterator
 
EntryKey - Class in org.apache.bookkeeper.bookie
An EntryKey represents an entry in a ledger, identified by ledgerId and entryId.
EntryKey() - Constructor for class org.apache.bookkeeper.bookie.EntryKey
 
EntryKey(long, long) - Constructor for class org.apache.bookkeeper.bookie.EntryKey
 
EntryKeyValue - Class in org.apache.bookkeeper.bookie
An entry Key/Value.
EntryKeyValue(long, long, byte[]) - Constructor for class org.apache.bookkeeper.bookie.EntryKeyValue
Creates a EntryKeyValue from the start of the specified byte array.
EntryKeyValue(long, long, byte[], int, int) - Constructor for class org.apache.bookkeeper.bookie.EntryKeyValue
Creates a EntryKeyValue from the start of the specified byte array.
entryLength - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
entryListener - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
EntryLocation - Class in org.apache.bookkeeper.bookie
An EntryLocation represents the location where an entry is stored.
EntryLocation - org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageFactory.DbConfigType
 
EntryLocation(long, long, long) - Constructor for class org.apache.bookkeeper.bookie.EntryLocation
 
entryLocationCompact() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
entryLocationCompact() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
entryLocationCompact() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
entryLocationCompact(List<String>) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
entryLocationCompact(List<String>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
EntryLocationIndex - Class in org.apache.bookkeeper.bookie.storage.ldb
Maintains an index of the entry locations in the EntryLogger.
EntryLocationIndex(ServerConfiguration, KeyValueStorageFactory, String, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
EntryLocationIndexStats - Class in org.apache.bookkeeper.bookie.storage.ldb
A umbrella class for ledger metadata index stats.
EntryLocationIndexStats(StatsLogger, Supplier<Long>) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndexStats
 
entrylog(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListFilesOnDiscCommand.LFODFlags
 
ENTRYLOG_IDS_CANDIDATES_SELECTED - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
EntryLog ID candidates selected.
EntryLogCompactor - Class in org.apache.bookkeeper.bookie
This is the basic entry log compactor to compact entry logs.
EntryLogCompactor(ServerConfiguration, EntryLogger, CompactableLedgerStorage, AbstractLogCompactor.LogRemovalListener) - Constructor for class org.apache.bookkeeper.bookie.EntryLogCompactor
 
EntryLogCompactor.CompactionScannerFactory - Class in org.apache.bookkeeper.bookie
A scanner wrapper to check whether a ledger is alive in an entry log file.
entryLogger - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
entryLogger - Variable in class org.apache.bookkeeper.bookie.EntryLogCompactor
 
entryLogger - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
entryLogger - Variable in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
entryLogger - Variable in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor
 
entryLogger - Variable in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand
 
EntryLogger - Interface in org.apache.bookkeeper.bookie.storage
Entry logger.
ENTRYLOGGER_CREATED - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
The entrylogger(EntryLogger) has been created.
ENTRYLOGGER_MISCONFIGURED - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
The entrylogger has been configured in a way that will likely result in errors during operation.
ENTRYLOGGER_SCOPE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
entryLoggerAllocator - Variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
entryLoggerAllocator - Variable in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
EntryLoggerAllocator - Class in org.apache.bookkeeper.bookie
An allocator pre-allocates entry log files.
EntryLoggerAllocator(ServerConfiguration, LedgerDirsManager, DefaultEntryLogger.RecentEntryLogsStatus, long, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
entryLogId - Variable in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
entryLogId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
EntryLogIds - Interface in org.apache.bookkeeper.bookie.storage
Generate unique entry log ids.
EntryLogIdsImpl - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
EntryLogIdsImpl.
EntryLogIdsImpl(LedgerDirsManager, Slogger) - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.EntryLogIdsImpl
 
EntryLogManager - Interface in org.apache.bookkeeper.bookie
 
EntryLogManagerBase - Class in org.apache.bookkeeper.bookie
 
EntryLogManagerBase(ServerConfiguration, LedgerDirsManager, EntryLoggerAllocator, List<DefaultEntryLogger.EntryLogListener>) - Constructor for class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
EntryLogManagerForEntryLogPerLedger - Class in org.apache.bookkeeper.bookie
 
EntryLogManagerForEntryLogPerLedger(ServerConfiguration, LedgerDirsManager, EntryLoggerAllocator, List<DefaultEntryLogger.EntryLogListener>, DefaultEntryLogger.RecentEntryLogsStatus, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
EntryLogManagerForEntryLogPerLedger.BufferedLogChannelWithDirInfo - Class in org.apache.bookkeeper.bookie
 
EntryLogManagerForEntryLogPerLedger.EntryLogAndLockTuple - Class in org.apache.bookkeeper.bookie
 
EntryLogManagerForEntryLogPerLedger.EntryLogsPerLedgerCounter - Class in org.apache.bookkeeper.bookie
 
EntryLogManagerForSingleEntryLog - Class in org.apache.bookkeeper.bookie
 
EntryLogManagerForSingleEntryLog(ServerConfiguration, LedgerDirsManager, EntryLoggerAllocator, List<DefaultEntryLogger.EntryLogListener>, DefaultEntryLogger.RecentEntryLogsStatus) - Constructor for class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
ENTRYLOGMAP_ACCESS_EXPIRYTIME_INSECONDS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
EntryLogMetadata - Class in org.apache.bookkeeper.bookie
Records the total size, remaining size and the set of ledgers that comprise a entry log.
EntryLogMetadata() - Constructor for class org.apache.bookkeeper.bookie.EntryLogMetadata
 
EntryLogMetadata(long) - Constructor for class org.apache.bookkeeper.bookie.EntryLogMetadata
 
EntryLogMetadata.EntryLogMetadataRecyclable - Class in org.apache.bookkeeper.bookie
Recyclable EntryLogMetadata class.
EntryLogMetadataMap - Interface in org.apache.bookkeeper.bookie
Map-store to store Entrylogger metadata.
EntryLogMetadataMapException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
EntryLogMetadataMapException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.EntryLogMetadataMapException
 
entryLogPerLedgerEnabled - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
ENTRYLOGS_PER_LEDGER - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
EntryLogScanner - Interface in org.apache.bookkeeper.bookie.storage
Scan entries in a entry log file.
entryLogsPerLedgerCounter - Variable in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
EntryLogsPerLedgerCounter(StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger.EntryLogsPerLedgerCounter
 
EntryLookupException(String) - Constructor for exception org.apache.bookkeeper.bookie.DefaultEntryLogger.EntryLookupException
 
EntryMemTable - Class in org.apache.bookkeeper.bookie
The EntryMemTable holds in-memory representation to the entries not-yet flushed.
EntryMemTable(ServerConfiguration, CheckpointSource, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.EntryMemTable
Constructor.
EntryMemTable.EntrySkipList - Class in org.apache.bookkeeper.bookie
Entry skip list.
EntryMemTableStats - Class in org.apache.bookkeeper.bookie.stats
A umbrella class for memtable related stats.
EntryMemTableStats(StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.stats.EntryMemTableStats
 
EntryMemTableWithParallelFlusher - Class in org.apache.bookkeeper.bookie
EntryMemTableWithParallelFlusher.
EntryMemTableWithParallelFlusher(ServerConfiguration, CheckpointSource, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.EntryMemTableWithParallelFlusher
 
EntrySkipList(CheckpointSource.Checkpoint) - Constructor for class org.apache.bookkeeper.bookie.EntryMemTable.EntrySkipList
 
EOK - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EOK = 0;
EOK - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The error code that indicates success.
EOK_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EOK = 0;
EQUAL - org.apache.bookkeeper.common.util.Backoff.Jitter.Type
 
equalJittered(long, long) - Static method in class org.apache.bookkeeper.common.util.Backoff
Create infinite backoffs that keep half of the exponential growth, and jitter between 0 and that amount.
equals(Object) - Method in class com.scurrilous.circe.params.CrcParameters
 
equals(Object) - Method in class com.scurrilous.circe.params.SimpleHashParameters
 
equals(Object) - Method in class org.apache.bookkeeper.auth.BookKeeperPrincipal
 
equals(Object) - Method in class org.apache.bookkeeper.bookie.Cookie
 
equals(Object) - Method in class org.apache.bookkeeper.bookie.EntryKey
 
equals(Object) - Method in class org.apache.bookkeeper.bookie.EntryKeyValue
 
equals(Object) - Method in class org.apache.bookkeeper.bookie.EntryMemTable.EntrySkipList
 
equals(Object) - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
equals(Object) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
equals(Object) - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
equals(Object) - Method in class org.apache.bookkeeper.client.PendingAddOp
 
equals(Object) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl.ZoneAwareNodeLocation
 
equals(Object) - Method in class org.apache.bookkeeper.common.collections.RecyclableArrayList
 
equals(Object) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
equals(Object) - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
equals(Object) - Method in class org.apache.bookkeeper.common.conf.validators.ClassValidator
 
equals(Object) - Method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
 
equals(Object) - Method in class org.apache.bookkeeper.common.net.ServiceURI
 
equals(Object) - Method in class org.apache.bookkeeper.common.util.Backoff.Constant
 
equals(Object) - Method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
equals(Object) - Method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
equals(Object) - Method in class org.apache.bookkeeper.meta.LedgerLayout
 
equals(Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.MetadataVersion
 
equals(Object) - Method in class org.apache.bookkeeper.metastore.Value
 
equals(Object) - Method in class org.apache.bookkeeper.net.BookieId
 
equals(Object) - Method in class org.apache.bookkeeper.net.BookieNode
 
equals(Object) - Method in class org.apache.bookkeeper.net.BookieSocketAddress
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
equals(Object) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
equals(Object) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.TxnCompletionKey
 
equals(Object) - Method in class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
equals(Object) - Method in class org.apache.bookkeeper.server.http.service.BookieSanityService.BookieSanity
 
equals(Object) - Method in class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService.ReadOnlyState
 
equals(Object) - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
equals(Object) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
equals(Object) - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
 
equals(Object) - Method in class org.apache.bookkeeper.stats.otel.ScopeContext
 
equals(Object) - Method in class org.apache.bookkeeper.stats.prometheus.ScopeContext
 
equals(Object) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
equals(Object) - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
equals(Object) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
equals(Object) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.LongPair
 
equals(Object) - Method in class org.apache.bookkeeper.versioning.LongVersion
 
equals(Object) - Method in class org.apache.bookkeeper.versioning.Versioned
 
EREADONLY - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EREADONLY = 505;
EREADONLY - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The server is running as read-only mode.
EREADONLY_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EREADONLY = 505;
error(long, LedgerMetadata, Throwable) - Static method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult
 
error(Enum<?>) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
error(Enum<?>) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
error(Enum<?>) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
error(Enum<?>, Throwable) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
error(Enum<?>, Throwable) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
error(Enum<?>, Throwable) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
error(String) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
error(String) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
error(String) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
error(String, Throwable) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
error(String, Throwable) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
error(String, Throwable) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
ERROR - org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult.State
 
ERROR - org.apache.bookkeeper.slogger.AbstractSlogger.Level
 
errorCode - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
errorCounter - Variable in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
errored - Variable in class org.apache.bookkeeper.client.ForceLedgerOp
 
erroredReplicas - Variable in class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
erroredReplicas - Variable in class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
 
erroredReplicas - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.BatchedReadCompletion
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ForceLedgerCompletion
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.GetBookieInfoCompletion
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.GetListOfEntriesOfLedgerCompletion
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadCompletion
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadLacCompletion
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.StartTLSCompletion
 
errorOut() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.WriteLacCompletion
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.BatchedReadCompletion
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ForceLedgerCompletion
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.GetBookieInfoCompletion
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.GetListOfEntriesOfLedgerCompletion
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadCompletion
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadLacCompletion
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.StartTLSCompletion
 
errorOut(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.WriteLacCompletion
 
errorOut(PerChannelBookieClient.CompletionKey) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
errorOut(PerChannelBookieClient.CompletionKey, int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
errorOutAndRunCallback(Runnable) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
errorOutOutstandingEntries(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
Errors out pending entries.
errorOutPendingAdds(int) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
errorOutPendingAdds(int, List<PendingAddOp>) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
errorOutPendingOps(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
Errors out pending ops from per channel bookie client.
ErrorResponse(byte, byte, int, long, long) - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.ErrorResponse
 
ETOOMANYREQUESTS - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
ETOOMANYREQUESTS = 506;
ETOOMANYREQUESTS - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Too many concurrent requests.
ETOOMANYREQUESTS_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
ETOOMANYREQUESTS = 506;
EUA - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EUA = 502;
EUA - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Unauthorized access to ledger.
EUA_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EUA = 502;
EUNKNOWNLEDGERSTATE - org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EUNKNOWNLEDGERSTATE = 507;
EUNKNOWNLEDGERSTATE - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Ledger in unknown state.
EUNKNOWNLEDGERSTATE_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
EUNKNOWNLEDGERSTATE = 507;
evaluateChallenge(byte[]) - Method in class org.apache.bookkeeper.sasl.SaslClientState
 
eventLoopGroup - Variable in class org.apache.bookkeeper.client.BookKeeper.Builder
 
eventLoopGroup - Variable in class org.apache.bookkeeper.client.BookKeeper
 
eventLoopGroup - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
eventLoopGroup - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
eventLoopGroup(EventLoopGroup) - Method in interface org.apache.bookkeeper.client.api.BookKeeperBuilder
Configure the bookkeeper client with a provided Netty EventLoopGroup.
eventLoopGroup(EventLoopGroup) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
Configure the bookkeeper client with a provided EventLoopGroup.
eventLoopGroup(EventLoopGroup) - Method in class org.apache.bookkeeper.client.impl.BookKeeperBuilderImpl
 
EventLoopUtil - Class in org.apache.bookkeeper.util
Utility class to initialize Netty event loops.
Events - Enum in org.apache.bookkeeper.bookie.datainteg
 
Events - Enum in org.apache.bookkeeper.bookie.storage.directentrylogger
Events.
exception(Throwable) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
EXCEPTION_HANDLER - Static variable in exception org.apache.bookkeeper.replication.ReplicationException
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.bookkeeper.proto.BookieRequestHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
Called by netty when an exception happens in one of the netty threads (mostly due to what we do in the netty threads).
ExceptionMessageHelper - Class in org.apache.bookkeeper.common.util
Utility to make it easier to add context to exception messages.
ExceptionMessageHelper(String) - Constructor for class org.apache.bookkeeper.common.util.ExceptionMessageHelper
 
exceptions - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
excludingMissingReplica(String) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand.LURFlags
 
execCommand(String...) - Static method in class org.apache.bookkeeper.util.Shell
Static method to execute a shell command.
execCommand(Map<String, String>, String...) - Static method in class org.apache.bookkeeper.util.Shell
Static method to execute a shell command.
execCommand(Map<String, String>, String[], long) - Static method in class org.apache.bookkeeper.util.Shell
Static method to execute a shell command.
execute() - Method in interface org.apache.bookkeeper.client.api.OpBuilder
Start the operation and return an handle to the result.
execute() - Method in class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
execute() - Method in class org.apache.bookkeeper.client.LedgerDeleteOp.DeleteBuilderImpl
 
execute() - Method in class org.apache.bookkeeper.client.LedgerOpenOp.OpenBuilderImpl
 
execute() - Method in class org.apache.bookkeeper.util.Shell.ShellCommandExecutor
Execute the shell command.
execute(Runnable) - Method in class org.apache.bookkeeper.common.util.BoundedExecutorService
 
execute(Runnable) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
execute(Runnable) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
execute(Runnable) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
execute(Runnable) - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
execute(String...) - Method in class org.apache.bookkeeper.bookie.BookieShell
 
executeOp() - Method in class org.apache.bookkeeper.proto.LongPollReadEntryProcessorV3
 
executeOp() - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
executeOrdered(int, Runnable) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
Schedules a one time action to execute with an ordering guarantee on the key.
executeOrdered(long, Runnable) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
Schedules a one time action to execute with an ordering guarantee on the key.
executeOrdered(Object, Runnable) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
Schedules a one time action to execute with an ordering guarantee on the key.
executeOrdered(Runnable) - Method in class org.apache.bookkeeper.client.LedgerHandle
Execute the callback in the thread pinned to the ledger.
executor - Variable in class org.apache.bookkeeper.bookie.SyncThread
 
executor - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
executor - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
executor - Variable in class org.apache.bookkeeper.server.http.service.DecommissionService
 
executor - Variable in class org.apache.bookkeeper.server.http.service.RecoveryBookieService
 
ExecutorUtils - Class in org.apache.bookkeeper.common.util
Executor/Thread related utils.
ExecutorUtils() - Constructor for class org.apache.bookkeeper.common.util.ExecutorUtils
 
exists(String, boolean) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
exists(String, boolean, AsyncCallback.StatCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
exists(String, Watcher) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
exists(String, Watcher, AsyncCallback.StatCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
EXISTS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
exitCode - Variable in class org.apache.bookkeeper.proto.BookieServer
 
exitCode - Variable in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
exitCode - Variable in exception org.apache.bookkeeper.util.Shell.ExitCodeException
 
ExitCode - Class in org.apache.bookkeeper.bookie
Exit code used to exit bookie server.
ExitCode() - Constructor for class org.apache.bookkeeper.bookie.ExitCode
 
ExitCodeException(int, String) - Constructor for exception org.apache.bookkeeper.util.Shell.ExitCodeException
 
exMsg(String) - Static method in class org.apache.bookkeeper.common.util.ExceptionMessageHelper
 
expandFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
expandFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
expandFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
expandFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
expandFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
expandFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
expandFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
expandFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
expandFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
expandFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
expandFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
expandFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
expandstorage(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand.AdminFlags
 
ExpandStorageService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper expand storage related http request.
ExpandStorageService(ServerConfiguration) - Constructor for class org.apache.bookkeeper.server.http.service.ExpandStorageService
 
expected - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
expectedItems - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
expectedItems - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
expectedItems - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
expectedItems - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
expectedItems - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
expectedItems - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
expectedItems(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
expectedItems(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
expectedItems(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
expectedItems(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
expectedItems(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
expectedItems(int) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
EXPLICIT_LAC_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
explicitLac - Variable in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
EXPLICITLAC_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
explicitLacFlushPolicy - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
ExplicitLacFlushPolicy - Interface in org.apache.bookkeeper.client
 
ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl - Class in org.apache.bookkeeper.client
 
ExplicitLacFlushPolicyImpl(LedgerHandle, ClientContext) - Constructor for class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
explicitLacInterval - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
exponential(long, int, long) - Static method in class org.apache.bookkeeper.common.util.Backoff
Create a stream with exponential backoffs.
EXPONENTIAL - org.apache.bookkeeper.common.util.Backoff.Jitter.Type
 
ExponentialBackoffRetryPolicy - Class in org.apache.bookkeeper.zookeeper
A retry policy implementation that backoff retries exponentially.
ExponentialBackoffRetryPolicy(long, int) - Constructor for class org.apache.bookkeeper.zookeeper.ExponentialBackoffRetryPolicy
 
ExponentialBackOffWithDeadlinePolicy - Class in org.apache.bookkeeper.zookeeper
Backoff time determined based as a multiple of baseBackoffTime.
ExponentialBackOffWithDeadlinePolicy(long, long, int) - Constructor for class org.apache.bookkeeper.zookeeper.ExponentialBackOffWithDeadlinePolicy
 
exponentialJittered(long, long) - Static method in class org.apache.bookkeeper.common.util.Backoff
Create a stream of exponential backoffs with jitters.
extensionRegistry - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEnDeCoderPreV3
 
extensionRegistry - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEnDecoderV3
 
extensionRegistry - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEnDeCoderPreV3
 
extensionRegistry - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEnDecoderV3
 
EXTENSIONS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
EXTRA_SERVER_COMPONENTS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
extractEntryLogMetadataFromIndex(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
extractLedgerCount(ByteBuf) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
extractLedgerMapOffset(ByteBuf) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
extractMetaFromEntryLogs() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
Method to read in all of the entry logs (those that we haven't done so yet), and find the set of ledger ID's that make up each entry log file.
extractVersion(ByteBuf) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 

F

factory - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
factory - Variable in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
fail - Variable in class org.apache.bookkeeper.stats.codahale.CodahaleOpStatsLogger
 
fail(int) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
Fail the request with given result code rc.
fail(int) - Method in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
Fail the request with given result code rc.
FAIL - org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementPolicyAdherence
 
failBookieAndCheck(int, BookieId) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.AckSet
Received failure response from a bookie and check if ack quorum will be broken.
FAILED_CONNECTION_COUNTER - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
FAILED_TLS_HANDSHAKE_COUNTER - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
FAILED_TO_RESOLVE_NETWORK_LOCATION_COUNT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
failedToResolveNetworkLocationCounter - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
failedToResolveNetworkLocationCounter - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DNSResolverDecorator
 
failedToResolveNetworkLocationCounter - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
failureRc - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
FallbackToHeap - org.apache.bookkeeper.common.allocator.OutOfMemoryPolicy
If it's not possible to allocate a buffer from direct memory, fallback to allocate an unpooled buffer from JVM heap.
FALLOC_FL_ZERO_RANGE - Static variable in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
fallocate(int, int, long, long) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
fallocate is a linux-only syscall, so callers must handle the possibility that it does not exist.
fallocate(int, int, long, long) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
fallocate(int, int, long, long) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
fallocate is a linux-only syscall, so callers must handle the possibility that it does not exist.
FALLOCATE_NOT_AVAILABLE - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
Fallocate is not available on this host.
FastCodahaleMetricsProvider - Class in org.apache.bookkeeper.stats.codahale
A StatsProvider implemented based on Codahale metrics library.
FastCodahaleMetricsProvider() - Constructor for class org.apache.bookkeeper.stats.codahale.FastCodahaleMetricsProvider
 
FastCodahaleStatsLogger - Class in org.apache.bookkeeper.stats.codahale
A StatsLogger implemented based on Codahale metrics library.
FastCodahaleStatsLogger(MetricRegistry, String) - Constructor for class org.apache.bookkeeper.stats.codahale.FastCodahaleStatsLogger
 
FastSnapshot - Class in org.apache.bookkeeper.stats.codahale
A snapshot of a FastTimer.
FastSnapshot(FastTimer, long, long, long, long, long[]) - Constructor for class org.apache.bookkeeper.stats.codahale.FastSnapshot
 
FastTimer - Class in org.apache.bookkeeper.stats.codahale
A fast and (nearly) garbage-free Rate and Response Times Timer.
FastTimer() - Constructor for class org.apache.bookkeeper.stats.codahale.FastTimer
Constructs a new timer with default time window (60 seconds) and default time buckets (fine).
FastTimer(int, FastTimer.Buckets) - Constructor for class org.apache.bookkeeper.stats.codahale.FastTimer
Constructs a new timer.
FastTimer.Buckets - Enum in org.apache.bookkeeper.stats.codahale
Defines the response time buckets to use.
fatalError() - Method in interface org.apache.bookkeeper.bookie.LedgerDirsManager.LedgerDirsListener
This will notify the fatal errors.
fc - Variable in class org.apache.bookkeeper.bookie.JournalChannel
 
fd - Variable in class org.apache.bookkeeper.bookie.JournalChannel
 
fd - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
Feature - Interface in org.apache.bookkeeper.feature
This interface represents a feature.
FEATURE_AVAILABILITY_MAX_VALUE - Static variable in interface org.apache.bookkeeper.feature.Feature
 
FEATURE_DISABLE_ENSEMBLE_CHANGE - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
FEATURE_REPP_DISABLE_DURABILITY_ENFORCEMENT - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
featureProvider - Variable in class org.apache.bookkeeper.client.BookKeeper.Builder
 
featureProvider - Variable in class org.apache.bookkeeper.client.BookKeeper
 
featureProvider - Variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
featureProvider(FeatureProvider) - Method in interface org.apache.bookkeeper.client.api.BookKeeperBuilder
Configure the bookkeeper client to use a provided FeatureProvider.
featureProvider(FeatureProvider) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
Feature Provider.
featureProvider(FeatureProvider) - Method in class org.apache.bookkeeper.client.impl.BookKeeperBuilderImpl
 
FeatureProvider - Interface in org.apache.bookkeeper.feature
Provider to provide features.
features - Variable in class org.apache.bookkeeper.feature.CacheableFeatureProvider
 
FENCE_LEDGER - org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
FENCE_LEDGER = 1;
FENCE_LEDGER_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
FENCE_LEDGER = 1;
fenceAndLogInJournal(Journal) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
When we fence a ledger, we need to first set ledger to fenced state in memory and then log the fence entry in Journal so that we can rebuild the state.
fenceAndLogInJournal(Journal) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
fenced - Variable in class org.apache.bookkeeper.bookie.LedgerCache.LedgerIndexMetadata
 
FENCED_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
fenceLedger(long, byte[]) - Method in interface org.apache.bookkeeper.bookie.Bookie
Fences a ledger.
fenceLedger(long, byte[]) - Method in class org.apache.bookkeeper.bookie.BookieImpl
Fences a ledger.
fenceReadEntryStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
fenceReadRequestStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
fenceReadWaitStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
fenceThreadPool - Variable in class org.apache.bookkeeper.proto.ReadEntryProcessor
 
fetchEntry(long) - Method in class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl.BatchImpl
 
fields - Variable in class org.apache.bookkeeper.metastore.Value
 
FILE_PATTERN - Static variable in class org.apache.bookkeeper.util.LedgerDirUtil
 
fileChannel - Variable in class org.apache.bookkeeper.bookie.BufferedChannelBase
 
fileChannelProvider - Variable in class org.apache.bookkeeper.bookie.Journal
 
FileChannelProvider - Interface in org.apache.bookkeeper.bookie
An interface of the FileChannelProvider.
fileExists(File) - Method in interface org.apache.bookkeeper.bookie.BookieFileChannel
Check the given file if exists.
fileExists(File) - Method in class org.apache.bookkeeper.bookie.DefaultFileChannel
 
FileInfo - Class in org.apache.bookkeeper.bookie
This is the file handle for a ledger's index file that maps entry ids to location.
FileInfo(File, byte[], int) - Constructor for class org.apache.bookkeeper.bookie.FileInfo
 
FILEINFO_CACHE_INITIAL_CAPACITY - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
FILEINFO_FORMAT_VERSION_TO_WRITE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
FILEINFO_MAX_IDLE_TIME - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
FileInfo.FileInfoDeletedException - Exception in org.apache.bookkeeper.bookie
 
fileInfoBackingCache - Variable in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
FileInfoBackingCache - Class in org.apache.bookkeeper.bookie
 
FileInfoBackingCache(FileInfoBackingCache.FileLoader, int) - Constructor for class org.apache.bookkeeper.bookie.FileInfoBackingCache
 
FileInfoBackingCache.CachedFileInfo - Class in org.apache.bookkeeper.bookie
 
FileInfoBackingCache.FileLoader - Interface in org.apache.bookkeeper.bookie
 
FileInfoDeletedException() - Constructor for exception org.apache.bookkeeper.bookie.FileInfo.FileInfoDeletedException
 
fileInfos - Variable in class org.apache.bookkeeper.bookie.FileInfoBackingCache
 
fileInfoVersionToWrite - Variable in class org.apache.bookkeeper.bookie.FileInfoBackingCache
 
fileLoader - Variable in class org.apache.bookkeeper.bookie.FileInfoBackingCache
 
FileModifiedTimeUpdater - Class in org.apache.bookkeeper.tls
Holder class to validate file modification.
FileModifiedTimeUpdater(String) - Constructor for class org.apache.bookkeeper.tls.FileModifiedTimeUpdater
 
filename - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
filename(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
fileName - Variable in class org.apache.bookkeeper.tls.FileModifiedTimeUpdater
 
fileName(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand.ReadJournalFlags
 
fileName2LogId(String) - Static method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Convert log filename (hex format with suffix) to logId in long.
FileSystemUpgrade - Class in org.apache.bookkeeper.bookie
Application for upgrading the bookkeeper filesystem between versions.
FileSystemUpgrade() - Constructor for class org.apache.bookkeeper.bookie.FileSystemUpgrade
 
fillInStackTrace() - Method in exception org.apache.bookkeeper.bookie.BookieException.OperationRejectedException
 
finalize() - Method in class com.scurrilous.circe.crc.Sse42Crc32C
 
finalizeAndCleanup() - Method in interface org.apache.bookkeeper.bookie.storage.CompactionEntryLog
Clean up any temporary resources that were used by the compaction process.
finalizeAndCleanup() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
finalizeAndClose() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.WriterWithMetadata
 
finalizeUpgrade(ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.FileSystemUpgrade
 
findLargestGap(List<Integer>) - Static method in class org.apache.bookkeeper.util.LedgerDirUtil
O(nlogn) algorithm to find largest contiguous gap between integers in a passed list.
findNextPositivePowerOfTwo(int) - Static method in class org.apache.bookkeeper.common.util.MathUtils
 
fine - org.apache.bookkeeper.stats.codahale.FastTimer.Buckets
 
finish(int, T, CompletableFuture<? super T>) - Static method in class org.apache.bookkeeper.client.SyncCallbackUtils
Handle the Response Code and transform it to a BKException.
finish(int, T, CompletableFuture<? super T>) - Static method in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks
Handle the Response Code and transform it to a BKException.
finished - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.SyncResult
Deprecated.
 
first - Variable in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
 
first - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.LongPair
 
FIRST_SPECULATIVE_READ_LAC_TIMEOUT - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
FIRST_SPECULATIVE_READ_TIMEOUT - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
firstEntry - Variable in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.RecoveryStats
 
firstEntryId - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterable
 
firstEntryId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
FIRSTENTRYID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
firstError - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
firstError - Variable in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
firstSpeculativeRequestTimeout - Variable in class org.apache.bookkeeper.client.DefaultSpeculativeRequestExecutionPolicy
 
FixedValueFeature - Class in org.apache.bookkeeper.feature
A feature implementation that has a fixed value of availability.
FixedValueFeature(String, boolean) - Constructor for class org.apache.bookkeeper.feature.FixedValueFeature
 
FixedValueFeature(String, int) - Constructor for class org.apache.bookkeeper.feature.FixedValueFeature
 
FLAG_DO_FENCING - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
 
FLAG_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
FLAG_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
FLAG_HIGH_PRIORITY - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
 
FLAG_NONE - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
 
FLAG_RECOVERY_ADD - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
 
flags - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
flags() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
Flags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.FormatCommand.Flags
 
Flags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.ListBookiesCommand.Flags
 
Flags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand.Flags
 
Flags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.CreateCookieCommand.Flags
 
Flags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.DeleteCookieCommand.Flags
 
Flags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand.Flags
 
Flags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.GetCookieCommand.Flags
 
Flags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.UpdateCookieCommand.Flags
 
FLAT_LEDGER_NODE_REGEX - Static variable in class org.apache.bookkeeper.util.StringUtils
 
FlatLedgerManager - Class in org.apache.bookkeeper.meta
Manage all ledgers in a single zk node.
FlatLedgerManager(AbstractConfiguration, ZooKeeper) - Constructor for class org.apache.bookkeeper.meta.FlatLedgerManager
Constructor.
FlatLedgerManagerFactory - Class in org.apache.bookkeeper.meta
Deprecated.
since 4.7.0. The implementation will be still available but not recommended to use.
FlatLedgerManagerFactory() - Constructor for class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
flattenKeyValues(BiConsumer<String, String>) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
flattenKeyValues(Iterator<Object>, BiConsumer<String, String>) - Static method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
FlipBookieIdCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to update ledger command.
FlipBookieIdCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand
 
FlipBookieIdCommand.FlipBookieIdFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for update ledger command.
FlipBookieIdFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand.FlipBookieIdFlags
 
flush() - Method in class org.apache.bookkeeper.bookie.BufferedChannel
Write any data in the buffer to the file and advance the writeBufferPosition.
flush() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
flush() - Method in class org.apache.bookkeeper.bookie.EntryLogCompactor.CompactionScannerFactory
 
flush() - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
flush() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
flush() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
flush() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Flushes all data in the storage.
flush() - Method in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
flush() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
flush() - Method in interface org.apache.bookkeeper.bookie.storage.CompactionEntryLog
Flush any unwritten entries to physical storage.
flush() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
flush() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
flush() - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogWriter
Flush all buffered writes to disk.
flush() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.WriterWithMetadata
 
flush() - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Flush any outstanding writes to disk.
flush() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
flush() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage.Batch
 
flush() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
Flushes all pending changes.
flush() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
flush() - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
flush(SkipListFlusher) - Method in class org.apache.bookkeeper.bookie.EntryMemTable
Flush snapshot and clear it.
flush(SkipListFlusher, CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.EntryMemTable
Flush memtable until checkpoint.
FLUSH_ENTRYLOG_INTERVAL_BYTES - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
FLUSH_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
flushAndForceWrite(boolean) - Method in class org.apache.bookkeeper.bookie.BufferedChannel
calls both flush and forceWrite methods.
flushAndForceWriteIfRegularFlush(boolean) - Method in class org.apache.bookkeeper.bookie.BufferedChannel
calls both flush and forceWrite methods if regular flush is enabled.
FlushCompactionLogPhase(CompactionEntryLog) - Constructor for class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.FlushCompactionLogPhase
 
flushCurrentLogs() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
flushCurrentLogs() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
flushCurrentLogs() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
flushDelay - Variable in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
flushEntriesLocationsIndex() - Method in interface org.apache.bookkeeper.bookie.CompactableLedgerStorage
Flush the entries locations index for the compacted entries.
flushEntriesLocationsIndex() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
flushEntriesLocationsIndex() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
flushEntriesLocationsIndex() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
flushExecutor - Variable in class org.apache.bookkeeper.bookie.EntryMemTableWithParallelFlusher
 
flushHeader() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
flushLedger(boolean) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
flushLedger(boolean) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
flushLedger(boolean) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
flushLedgerEntries(long, List<LedgerEntryPage>) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
flushLedgerHeader(long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
flushLogChannel(DefaultEntryLogger.BufferedLogChannel, boolean) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
flushMutex - Variable in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
flushOneOrMoreLedgers(boolean) - Method in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
flushPendingResponse() - Method in class org.apache.bookkeeper.proto.BookieRequestHandler
 
flushRotatedEntryLog(Long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.RecentEntryLogsStatus
 
flushRotatedLogs() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
flushRotatedLogs() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
if disk of the logChannel is full or if the entrylog limit is reached of if the logchannel is not initialized, then createNewLog.
flushRotatedLogs() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
flushCurrentLogs method is called during checkpoint, so metadata of the file also should be force written.
flushSnapshot(SkipListFlusher, CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.EntryMemTable
Flush snapshot and clear it iff its data is before checkpoint.
flushSnapshot(SkipListFlusher, CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.EntryMemTableWithParallelFlusher
Functionally this overridden flushSnapshot does the same as EntryMemTable's flushSnapshot, but it uses flushExecutor (OrderedExecutor) to process an entry through flusher.
FOLLOW_BOOKIE_ADDRESS_TRACKING - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
force() - Method in interface org.apache.bookkeeper.client.api.ForceableHandle
Enforce durability to the entries written by this handle.
force() - Method in class org.apache.bookkeeper.client.LedgerHandle
Enforce durability to the entries written by this handle.
force(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FormatCommand.Flags
 
force(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.MetaFormatCommand.MetaFormatFlags
 
force(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.NukeExistingClusterCommand.NukeExistingClusterFlags
 
force(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
force(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.client.DeleteLedgerCommand.DeleteLedgerFlags
 
force(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand.AdminFlags
 
FORCE_ALLOW_COMPACTION - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
FORCE_LEDGER - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
FORCE_LEDGER = 10;
FORCE_LEDGER - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
FORCE_LEDGER_REQUEST - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
FORCE_LEDGER_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
FORCE_LEDGER = 10;
FORCE_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
FORCE_READ_ONLY_BOOKIE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ForceableHandle - Interface in org.apache.bookkeeper.client.api
Provide the ability to enforce durability guarantees to the writer.
ForceAuditorChecksCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ForceAuditorChecksCmd
 
forceClose() - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
forceClose() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
forceClose() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
forceCompacting(boolean) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
forceGarbageCollection - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
forceGC() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
forceGC() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Force trigger Garbage Collection.
forceGC() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
forceGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
forceGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
forceGC(boolean, boolean) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
forceGC(boolean, boolean) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Force trigger Garbage Collection with forceMajor or forceMinor parameter.
forceGC(boolean, boolean) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
forceGC(boolean, boolean) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
forceGC(boolean, boolean) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
forceLedger(long, BookkeeperInternalCallbacks.ForceLedgerCallback, Object) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
forceLedger(long, BookkeeperInternalCallbacks.WriteCallback, Object) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
forceLedger(long, BookkeeperInternalCallbacks.WriteCallback, Object) - Method in class org.apache.bookkeeper.bookie.BookieImpl
Force sync given 'ledgerId' entries on the journal to the disk.
forceLedger(long, BookkeeperInternalCallbacks.WriteCallback, Object) - Method in class org.apache.bookkeeper.bookie.Journal
 
forceLedger(BookieId, long, BookkeeperInternalCallbacks.ForceLedgerCallback, Object) - Method in interface org.apache.bookkeeper.proto.BookieClient
Send a force request to the server.
forceLedger(BookieId, long, BookkeeperInternalCallbacks.ForceLedgerCallback, Object) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
forceLedgerComplete(int, long, BookieId, Object) - Method in class org.apache.bookkeeper.client.ForceLedgerOp
 
forceLedgerComplete(int, long, BookieId, Object) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.ForceLedgerCallback
 
ForceLedgerCompletion(PerChannelBookieClient.CompletionKey, BookkeeperInternalCallbacks.ForceLedgerCallback, Object, long) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.ForceLedgerCompletion
 
ForceLedgerOp - Class in org.apache.bookkeeper.client
This represents a request to sync the ledger on every bookie.
ForceLedgerOp(LedgerHandle, BookieClient, List<BookieId>, CompletableFuture<Void>) - Constructor for class org.apache.bookkeeper.client.ForceLedgerOp
 
ForceLedgerProcessorV3 - Class in org.apache.bookkeeper.proto
 
ForceLedgerProcessorV3(BookkeeperProtocol.Request, BookieRequestHandler, BookieRequestProcessor) - Constructor for class org.apache.bookkeeper.proto.ForceLedgerProcessorV3
 
FORCELEDGERREQUEST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
forceLedgerRequestStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
FORCELEDGERRESPONSE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
forceLedgerStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
forceRecovery(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
forceShutdown(long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
Force threads shutdown (cancel active requests) after specified delay, to be used after shutdown() rejects new requests.
forceToReadOnly() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
forceToReadOnly() - Method in interface org.apache.bookkeeper.bookie.StateManager
Turn state to the read only, just flag.
forceToShuttingDown() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
forceToShuttingDown() - Method in interface org.apache.bookkeeper.bookie.StateManager
Turn state to the shutting down progress,just the flag.
forceToUnregistered() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
forceToUnregistered() - Method in interface org.apache.bookkeeper.bookie.StateManager
Turn state to not registered, just the flag.
forceWrite(boolean) - Method in class org.apache.bookkeeper.bookie.BufferedChannel
force a sync operation so that data is persisted to the disk.
forceWrite(boolean) - Method in class org.apache.bookkeeper.bookie.JournalChannel
 
forceWrite(boolean) - Method in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
forceWriteRequests - Variable in class org.apache.bookkeeper.bookie.Journal
 
forceWriteThread - Variable in class org.apache.bookkeeper.bookie.Journal
 
forConfig(ClientConfiguration) - Static method in class org.apache.bookkeeper.client.BookKeeper
 
forEach(BiConsumer<? super K, ? super V>) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
Iterate over all the entries in the map and apply the processor function to each of them.
forEach(BiConsumer<Long, EntryLogMetadata>) - Method in interface org.apache.bookkeeper.bookie.EntryLogMetadataMap
Performs the given action for each entry in this map until all entries have been processed or the action throws an exception.
forEach(BiConsumer<Long, EntryLogMetadata>) - Method in class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
forEach(BiConsumer<Long, EntryLogMetadata>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
EntryLogMetadata life-cycle in supplied action will be transient and it will be recycled as soon as supplied action is completed.
forEach(BiFunction<Long, LedgerMetadata, CompletableFuture<Void>>) - Method in class org.apache.bookkeeper.bookie.datainteg.MetadataAsyncIterator
 
forEach(Consumer<? super V>) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
Iterate over all the elements in the set and apply the provided function.
forEach(WriteCache.EntryConsumer) - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
forEach(ConcurrentLongHashMap.EntryProcessor<V>) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
Iterate over all the entries in the map and apply the processor function to each of them.
forEach(ConcurrentLongHashSet.ConsumerLong) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
forEach(ConcurrentLongLongHashMap.BiConsumerLong) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
forEach(ConcurrentLongLongPairHashMap.BiConsumerLongPair) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
Iterate over all the entries in the map and apply the processor function to each of them.
forEachByte(int, int, ByteProcessor) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
forEachByte(ByteProcessor) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
forEachByteDesc(int, int, ByteProcessor) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
forEachByteDesc(ByteProcessor) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
forKey(long, BiConsumer<Long, EntryLogMetadata>) - Method in interface org.apache.bookkeeper.bookie.EntryLogMetadataMap
Performs the given action for the key.
forKey(long, BiConsumer<Long, EntryLogMetadata>) - Method in class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
forKey(long, BiConsumer<Long, EntryLogMetadata>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
EntryLogMetadata life-cycle in supplied action will be transient and it will be recycled as soon as supplied action is completed.
format() - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Do format boolean.
format() - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
format() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
format(AbstractConfiguration<?>, LayoutManager) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManagerFactory
 
format(AbstractConfiguration<?>, LayoutManager) - Method in interface org.apache.bookkeeper.meta.LedgerManagerFactory
Format the ledger metadata for LedgerManager.
format(AbstractConfiguration<?>, LayoutManager) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
format(AbstractConfiguration<?>, LayoutManager) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
format(ServerConfiguration, boolean, boolean) - Static method in class org.apache.bookkeeper.bookie.BookieImpl
Format the bookie server data.
format(ServerConfiguration, boolean, boolean) - Static method in class org.apache.bookkeeper.client.BookKeeperAdmin
Format the BookKeeper metadata in zookeeper.
FormatCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to format the current server contents.
FormatCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.FormatCommand
 
FormatCommand(FormatCommand.Flags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.FormatCommand
 
FormatCommand.Flags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for format bookie command.
formatEnsemble(List<BookieId>, Set<BookieId>, char) - Static method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
formatEntry(byte[]) - Method in class org.apache.bookkeeper.util.EntryFormatter
Format an entry into a readable format.
formatEntry(byte[]) - Method in class org.apache.bookkeeper.util.HexDumpEntryFormatter
 
formatEntry(byte[]) - Method in class org.apache.bookkeeper.util.StringEntryFormatter
 
formatEntry(long, ByteBuf, boolean, LedgerIdFormatter, EntryFormatter) - Static method in class org.apache.bookkeeper.tools.cli.commands.bookie.FormatUtil
Format the message into a readable format.
formatEntry(InputStream) - Method in class org.apache.bookkeeper.util.EntryFormatter
Format an entry from a string into a readable format.
formatEntry(InputStream) - Method in class org.apache.bookkeeper.util.HexDumpEntryFormatter
 
formatEntry(InputStream) - Method in class org.apache.bookkeeper.util.StringEntryFormatter
 
formatLedgerId(long) - Method in class org.apache.bookkeeper.util.LedgerIdFormatter
Formats the LedgerId according to the type of the Formatter and return it in String format.
formatLedgerId(long) - Method in class org.apache.bookkeeper.util.LedgerIdFormatter.HexLedgerIdFormatter
 
formatLedgerId(long) - Method in class org.apache.bookkeeper.util.LedgerIdFormatter.LongLedgerIdFormatter
 
formatLedgerId(long) - Method in class org.apache.bookkeeper.util.LedgerIdFormatter.UUIDLedgerIdFormatter
 
FormatUtil - Class in org.apache.bookkeeper.tools.cli.commands.bookie
.Provide to format message.
FormatUtil() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.FormatUtil
 
formatVersion - Variable in class org.apache.bookkeeper.bookie.JournalChannel
 
forName(String, Class<T>) - Static method in class org.apache.bookkeeper.common.util.ReflectionUtils
Returns the Class object object associated with the class or interface with the given string name, which is a subclass of xface.
forNumber(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
 
forNumber(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
 
forNumber(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
 
forNumber(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
 
forNumber(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
 
forNumber(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
 
forNumber(int) - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
 
forNumber(int) - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
 
fragmentStartId - Variable in class org.apache.bookkeeper.client.LedgerFragmentReplicator.SingleFragmentCallback
 
free() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
Free the memory that backs this buffer.
free(long) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
free(long) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
free(long) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 
FREE_DISK_SPACE - org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
FREE_DISK_SPACE = 2;
FREE_DISK_SPACE_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
FREE_DISK_SPACE = 2;
FREEDISKSPACE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
from(LedgerMetadata) - Static method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
fromApiDigestType(DigestType) - Static method in enum org.apache.bookkeeper.client.BookKeeper.DigestType
 
fromConfig(ClientConfiguration) - Static method in class org.apache.bookkeeper.client.ClientInternalConf
 
fromConfigAndFeatureProvider(ClientConfiguration, FeatureProvider) - Static method in class org.apache.bookkeeper.client.ClientInternalConf
 
fromJson(String, Class<T>) - Static method in class org.apache.bookkeeper.common.util.JsonUtil
 
fromKeeperException(String, KeeperException) - Static method in exception org.apache.bookkeeper.replication.ReplicationException
 
fsync(int) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
fsync(int) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
fsync(int) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 
FULL - org.apache.bookkeeper.client.BookieInfoReader.State
 
FULL_CHECK_COMPLETE - org.apache.bookkeeper.bookie.datainteg.Events
The full check has completed.
FULL_CHECK_END - org.apache.bookkeeper.bookie.datainteg.Events
The full check has completed.
FULL_CHECK_ERROR - org.apache.bookkeeper.bookie.datainteg.Events
An error occurred during the full check, but not while processing ledgers.
FULL_CHECK_INIT - org.apache.bookkeeper.bookie.datainteg.Events
Initialized the full check.
FULL_CHECK_START - org.apache.bookkeeper.bookie.datainteg.Events
Start iterating through the ledger that should be on this bookie.
FUNC - Static variable in class org.apache.bookkeeper.bookie.LastAddConfirmedUpdateNotification
 
future - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
future() - Method in class org.apache.bookkeeper.client.ReadOpBase
 
FutureEventListener<T> - Interface in org.apache.bookkeeper.common.concurrent
Provide similar interface (as twitter future) over java future.
FutureGetListOfEntriesOfLedger(long) - Constructor for class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.FutureGetListOfEntriesOfLedger
 
FutureReadLastConfirmed() - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.FutureReadLastConfirmed
 
FutureReadLastConfirmedAndEntry() - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.FutureReadLastConfirmedAndEntry
 
FutureUtils - Class in org.apache.bookkeeper.common.concurrent
Future related utils.

G

garbageCleaner - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
GarbageCollectionStatus - Class in org.apache.bookkeeper.bookie
This is the garbage collection thread status.
GarbageCollectionStatus(boolean, boolean, boolean, long, long, long, long) - Constructor for class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
GarbageCollectionStatus.GarbageCollectionStatusBuilder - Class in org.apache.bookkeeper.bookie
 
GarbageCollectionStatusBuilder() - Constructor for class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
garbageCollector - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
GarbageCollector - Interface in org.apache.bookkeeper.bookie
This is the garbage collector interface, garbage collector implementers need to extends this class to remove the deleted ledgers.
GarbageCollector.GarbageCleaner - Interface in org.apache.bookkeeper.bookie
A interface used to define customised garbage cleaner.
GarbageCollectorStats - Class in org.apache.bookkeeper.bookie.stats
A umbrella class for gc stats.
GarbageCollectorStats(StatsLogger, Supplier<Integer>, Supplier<Long>, Supplier<Integer>) - Constructor for class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
GarbageCollectorThread - Class in org.apache.bookkeeper.bookie
This is the garbage collector thread that runs in the background to remove any entry log files that no longer contains any active ledger.
GarbageCollectorThread(ServerConfiguration, LedgerManager, LedgerDirsManager, CompactableLedgerStorage, EntryLogger, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.GarbageCollectorThread
Create a garbage collector thread.
GarbageCollectorThread(ServerConfiguration, LedgerManager, LedgerDirsManager, CompactableLedgerStorage, EntryLogger, StatsLogger, ScheduledExecutorService) - Constructor for class org.apache.bookkeeper.bookie.GarbageCollectorThread
Create a garbage collector thread.
Gauge<T extends java.lang.Number> - Interface in org.apache.bookkeeper.stats
A guage is a value that has only one value at a specific point in time.
gauges - Variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
gc(GarbageCollector.GarbageCleaner) - Method in interface org.apache.bookkeeper.bookie.GarbageCollector
Do the garbage collector work.
gc(GarbageCollector.GarbageCleaner) - Method in class org.apache.bookkeeper.bookie.ScanAndCompareGarbageCollector
 
GC_ENTRYLOG_METADATA_CACHE_PATH - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
GC_ENTRYLOGMETADATA_CACHE_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
GC_OVERREPLICATED_LEDGER_MAX_CONCURRENT_REQUESTS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
GC_OVERREPLICATED_LEDGER_WAIT_TIME - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
GC_WAIT_TIME - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
GCDetailsService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle get garbage collection details service.
GCDetailsService(ServerConfiguration, BookieServer) - Constructor for class org.apache.bookkeeper.server.http.service.GCDetailsService
 
gcThread - Variable in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
gcWaitTime - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
genDigest(String, byte[]) - Static method in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
generateCookie(ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.Cookie
Generate cookie from the given configuration.
GenerateCookieCommand - Class in org.apache.bookkeeper.tools.cli.commands.cookie
A command that generate cookie.
GenerateCookieCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand
 
GenerateCookieCommand(PrintStream) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand
 
GenerateCookieCommand(GenerateCookieCommand.Flags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand
 
GenerateCookieCommand.Flags - Class in org.apache.bookkeeper.tools.cli.commands.cookie
Flags to generate a cookie for a given bookie.
generateLedgerId - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
generateLedgerId(BookkeeperInternalCallbacks.GenericCallback<Long>) - Method in interface org.apache.bookkeeper.meta.LedgerIdGenerator
Generate a global unique ledger id.
generateLedgerId(BookkeeperInternalCallbacks.GenericCallback<Long>) - Method in class org.apache.bookkeeper.meta.LongZkLedgerIdGenerator
 
generateLedgerId(BookkeeperInternalCallbacks.GenericCallback<Long>) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerIdGenerator
 
generateLedgerId(BookkeeperInternalCallbacks.GenericCallback<Long>) - Method in class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
generateLedgerIdAndCreateLedger(LedgerMetadataBuilder) - Method in class org.apache.bookkeeper.client.LedgerCreateOp
 
generateLedgerIdImpl(BookkeeperInternalCallbacks.GenericCallback<Long>, ZooKeeper, String, List<ACL>) - Static method in class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
generateMasterKey(byte[]) - Static method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
generateWriteSet(List<Integer>, int, int, int) - Static method in class org.apache.bookkeeper.bookie.datainteg.WriteSets
 
GenericCallbackFuture() - Constructor for class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.GenericCallbackFuture
 
get() - Static method in class org.apache.bookkeeper.bookie.EntryLogMetadata.EntryLogMetadataRecyclable
 
get() - Static method in class org.apache.bookkeeper.bookie.storage.ldb.LongWrapper
 
get() - Static method in class org.apache.bookkeeper.common.util.affinity.impl.IsolatedProcessors
 
get() - Method in class org.apache.bookkeeper.proto.SimpleBookieServiceInfoProvider
 
get() - Method in interface org.apache.bookkeeper.stats.Counter
Get the value associated with this stat.
get() - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullCounter
 
get() - Method in class org.apache.bookkeeper.stats.otel.OtelCounter
 
get() - Method in class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
 
get() - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedLongAdderCounter
 
get() - Static method in class org.apache.bookkeeper.stats.Stats
 
get() - Static method in class org.apache.bookkeeper.stats.ThreadRegistry
 
get() - Static method in class org.apache.bookkeeper.util.ByteBufList
 
get() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo.EntryIterator
 
get(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.LostBookieRecoveryDelayCommand.LBRDFlags
 
get(byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Get the value associated with the given key.
get(byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
get(byte[], byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Get the value associated with the given key.
get(byte[], byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
get(int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
Get the index at index i.
get(int) - Static method in enum org.apache.bookkeeper.metastore.MSException.Code
Get the Code value for a particular integer error code.
get(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
get(long) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.LongWrapper
 
get(long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
get(long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
get(long, long) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.LongPairWrapper
 
get(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.ReadCache
 
get(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
get(long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
get(HashParameters, EnumSet<HashSupport>) - Method in class com.scurrilous.circe.checksum.Crc32cSse42Provider
 
get(HashParameters, EnumSet<HashSupport>, Callable<Hash>) - Method in interface com.scurrilous.circe.impl.HashCache
Requests a cached hash function with the given parameters and required support flags.
get(CrcParameters, EnumSet<HashSupport>) - Method in class com.scurrilous.circe.crc.StandardCrcProvider
 
get(ByteBuf) - Static method in class org.apache.bookkeeper.util.ByteBufList
Get a new ByteBufList from the pool and assign 1 buffer to it.
get(ByteBuf, ByteBuf) - Static method in class org.apache.bookkeeper.util.ByteBufList
Get a new ByteBufList from the pool and assign 2 buffers to it.
get(String, Set<String>, MetastoreCallback<Versioned<Value>>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
get(String, Set<String>, MetastoreCallback<Versioned<Value>>, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreTable
Get specified fields of a key.
get(String, MetastoreCallback<Versioned<Value>>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
get(String, MetastoreCallback<Versioned<Value>>, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreTable
Get all fields of a key.
get(String, MetastoreWatcher, MetastoreCallback<Versioned<Value>>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
get(String, MetastoreWatcher, MetastoreCallback<Versioned<Value>>, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreTable
Get all fields of a key.
get(K) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
get(SharedResourceManager.Resource<T>) - Method in class org.apache.bookkeeper.common.util.SharedResourceManager
 
get(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting value from the provided conf.
get(P, EnumSet<HashSupport>) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
Requests a hash function using the given parameters and support flags.
GET_BOOKIE_INFO - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
GET_BOOKIE_INFO = 8;
GET_BOOKIE_INFO - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
GET_BOOKIE_INFO - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
 
GET_BOOKIE_INFO_INTERVAL_SECONDS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
GET_BOOKIE_INFO_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
GET_BOOKIE_INFO_REQUEST - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
GET_BOOKIE_INFO_RETRY_INTERVAL_SECONDS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
GET_BOOKIE_INFO_TIMEOUT_SECS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
GET_BOOKIE_INFO_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
GET_BOOKIE_INFO = 8;
GET_LIST_OF_ENTRIES_OF_LEDGER - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
GET_LIST_OF_ENTRIES_OF_LEDGER = 11;
GET_LIST_OF_ENTRIES_OF_LEDGER - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
GET_LIST_OF_ENTRIES_OF_LEDGER_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
GET_LIST_OF_ENTRIES_OF_LEDGER_REQUEST - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
GET_LIST_OF_ENTRIES_OF_LEDGER_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
GET_LIST_OF_ENTRIES_OF_LEDGER = 11;
getAckQuorumSize() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the ack quorum size of this ledger.
getAckQuorumSize() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getAckQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int32 ackQuorumSize = 9;
getAckQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional int32 ackQuorumSize = 9;
getAckQuorumSize() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional int32 ackQuorumSize = 9;
getAckSet() - Method in interface org.apache.bookkeeper.client.DistributionSchedule
Returns an ackset object, responses should be checked against this.
getAckSet() - Method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
getACL(String, Stat) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getACL(String, Stat, AsyncCallback.ACLCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getACLs(AbstractConfiguration) - Static method in class org.apache.bookkeeper.util.ZkUtils
Compute ZooKeeper ACLs using actual configuration.
getActiveEntryLogCountGauge() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getActiveEntryLogSpaceBytesGauge() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getActiveLedgerCountGauge() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getActiveLedgersInRange(long, long) - Method in interface org.apache.bookkeeper.bookie.CompactableLedgerStorage
Get an iterator over a range of ledger ids stored in the bookie.
getActiveLedgersInRange(long, long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
getActiveLedgersInRange(long, long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getActiveLedgersInRange(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getActiveLedgersInRange(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
getActiveLedgersInRange(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getAddBytesStats() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getAddEntryBlockedStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getAddEntryQuorumTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the timeout for top-level add request.
getAddEntryRejectedCounter() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getAddEntryStats() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getAddEntryStats() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLoggerStats
 
getAddEntryStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getAddEntryStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getAddEntryTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the timeout for add request.
getAddOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getAddOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getAddOpUrCounter() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getAddOpUrCounter() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getAddr() - Method in class org.apache.bookkeeper.net.BookieNode
 
getAddRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AddRequest addRequest = 101;
getAddRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .AddRequest addRequest = 101;
getAddRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .AddRequest addRequest = 101;
getAddRequestBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AddRequest addRequest = 101;
getAddRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AddRequest addRequest = 101;
getAddRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .AddRequest addRequest = 101;
getAddRequestOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .AddRequest addRequest = 101;
getAddRequestStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getAddResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AddResponse addResponse = 101;
getAddResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .AddResponse addResponse = 101;
getAddResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .AddResponse addResponse = 101;
getAddResponseBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AddResponse addResponse = 101;
getAddResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AddResponse addResponse = 101;
getAddResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .AddResponse addResponse = 101;
getAddResponseOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .AddResponse addResponse = 101;
getAddress(int) - Method in class org.apache.bookkeeper.client.LedgerFragment
Gets the failedBookie address.
getAddress(ByteBuffer) - Method in interface com.scurrilous.circe.impl.DirectByteBufferAccess
Returns the native memory address of the given direct byte buffer, or 0 if the buffer is not direct or if obtaining the address is not supported.
getAddress(ByteBuffer) - Static method in class com.scurrilous.circe.impl.DirectByteBufferAccessLoader
Returns the native memory address of the given direct byte buffer, or 0 if the buffer is not direct or if obtaining the address is not supported.
getAddresses() - Method in class org.apache.bookkeeper.client.LedgerFragment
 
getAddsBlocked() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getAddsInProgress() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getAddsSemaphore() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
getAdheringToPolicy() - Method in class org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementResult
 
getAdvertisedAddress() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the configured advertised address for the bookie.
getAllBookies() - Method in interface org.apache.bookkeeper.client.BookieWatcher
 
getAllBookies() - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
 
getAllBookies() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Get a list of all bookies including the not available ones.
getAllBookies() - Method in interface org.apache.bookkeeper.discover.RegistrationClient
Get the list of all bookies identifiers.
getAllBookies() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
getAllChannels() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
getAllDirectories(ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.FileSystemUpgrade
 
getAllEnsembles() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns all the ensembles of this ledger.
getAllEnsembles() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getAllLedgerDirs() - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Get all ledger dirs configured.
getAllocator() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getAllocator() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
getAllocatorLeakDetectionPolicy() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Return the configured leak detection policy for the allocator.
getAllocatorOutOfMemoryPolicy() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
 
getAllocatorPoolingConcurrency() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
 
getAllocatorPoolingPolicy() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
 
getAllowEphemeralPorts() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Is the bookie allowed to use an ephemeral port (port 0) as its server port.
getAllowLoopback() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Is the bookie allowed to use a loopback interface as its primary interface(i.e.
getAllowStorageExpansion() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Return whether we should allow addition of ledger/index dirs to an existing bookie.
getAnyKey() - Method in class org.apache.bookkeeper.util.collections.SynchronizedHashMultiMap
 
getAttributes() - Method in class org.apache.bookkeeper.stats.otel.ScopeContext
 
getAuditBookiesTime() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getAuditor() - Method in class org.apache.bookkeeper.replication.AuditorElector
 
getAuditor() - Method in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
getAuditorAcquireConcurrentOpenLedgerOperationsTimeoutMSec() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the acquire concurrent open ledger operations timeout.
getAuditorId() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
getAuditorId() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
getAuditorLedgerVerificationPercentage() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get what percentage of a ledger (fragment)'s entries will be verified.
getAuditorMaxNumberOfConcurrentOpenLedgerOperations() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the semaphore limit value of getting ledger from zookeeper in auto recovery.
getAuditorPeriodicBookieCheckInterval() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the interval between auditor bookie check runs.
getAuditorPeriodicCheckInterval() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the regularity at which the auditor checks all ledgers.
getAuditorPeriodicPlacementPolicyCheckInterval() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the regularity at which the auditor does placement policy check of all ledgers, which are closed.
getAuditorPeriodicReplicasCheckInterval() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the interval at which the auditor does replicas check of all ledgers.
getAuditTask() - Method in class org.apache.bookkeeper.replication.Auditor
 
getAuth() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher.EndpointInfo
 
getAuth() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
getAuth(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string auth = 5;
getAuth(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
repeated string auth = 5;
getAuth(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
repeated string auth = 5;
getAuthBytes(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string auth = 5;
getAuthBytes(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
repeated string auth = 5;
getAuthBytes(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
repeated string auth = 5;
getAuthCount() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string auth = 5;
getAuthCount() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
repeated string auth = 5;
getAuthCount() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
repeated string auth = 5;
getAuthList() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string auth = 5;
getAuthList() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
repeated string auth = 5;
getAuthList() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
repeated string auth = 5;
getAuthMessage() - Method in class org.apache.bookkeeper.proto.BookieProtocol.AuthRequest
 
getAuthMessage() - Method in class org.apache.bookkeeper.proto.BookieProtocol.AuthResponse
 
getAuthorizedId() - Method in interface org.apache.bookkeeper.proto.ConnectionPeer
Returns the user which is bound to the connection.
getAuthorizedRoles() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the authorized roles.
getAuthPluginName() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required string authPluginName = 1;
getAuthPluginName() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
required string authPluginName = 1;
getAuthPluginName() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessageOrBuilder
required string authPluginName = 1;
getAuthPluginNameBytes() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required string authPluginName = 1;
getAuthPluginNameBytes() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
required string authPluginName = 1;
getAuthPluginNameBytes() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessageOrBuilder
required string authPluginName = 1;
getAuthProvider() - Method in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
getAuthRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AuthMessage authRequest = 102;
getAuthRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .AuthMessage authRequest = 102;
getAuthRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .AuthMessage authRequest = 102;
getAuthRequestBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AuthMessage authRequest = 102;
getAuthRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AuthMessage authRequest = 102;
getAuthRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .AuthMessage authRequest = 102;
getAuthRequestOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .AuthMessage authRequest = 102;
getAuthResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AuthMessage authResponse = 102;
getAuthResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .AuthMessage authResponse = 102;
getAuthResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .AuthMessage authResponse = 102;
getAuthResponseBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AuthMessage authResponse = 102;
getAuthResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AuthMessage authResponse = 102;
getAuthResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .AuthMessage authResponse = 102;
getAuthResponseOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .AuthMessage authResponse = 102;
getAutoRecoveryServer() - Method in class org.apache.bookkeeper.server.service.AutoRecoveryService
 
getAutoRecoveryService() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getAvailabilityOfEntriesOfLedger() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
condensed encoded format representing availability of entries of ledger
getAvailabilityOfEntriesOfLedger() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
condensed encoded format representing availability of entries of ledger
getAvailabilityOfEntriesOfLedger() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponseOrBuilder
condensed encoded format representing availability of entries of ledger
getAvailableBookies() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Get a list of the available bookies.
getAvailableBookies() - Method in class org.apache.bookkeeper.replication.Auditor
 
getAvailableBookies() - Method in class org.apache.bookkeeper.replication.AuditorTask
 
getAvgLatency() - Method in class org.apache.bookkeeper.proto.BKStats.OpStatData
 
getAvgLatencyMillis() - Method in class org.apache.bookkeeper.stats.OpStatsData
 
getBasePath(String) - Static method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getBCProviderFromClassPath() - Static method in class org.apache.bookkeeper.tls.TLSContextFactory
Get Bouncy Castle provider from classpath, and call Security.addProvider.
getBigDecimal(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getBigDecimal(String, BigDecimal) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getBigInteger(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getBigInteger(String, BigInteger) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getBkStats() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
getBlacklistedChannels() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
getBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required bytes body = 4;
getBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
required bytes body = 4;
getBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
required bytes body = 4;
getBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
optional bytes body = 4;
getBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
optional bytes body = 4;
getBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
optional bytes body = 4;
getBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required bytes body = 4;
getBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
required bytes body = 4;
getBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequestOrBuilder
required bytes body = 4;
getBookie() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
This is the Bookie instance that is used to handle all read and write requests.
getBookie() - Method in class org.apache.bookkeeper.proto.BookieServer
 
getBookieAddress() - Method in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
getBookieAddress(ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.BookieImpl
Return the configured address of the bookie.
getBookieAddressResolver() - Method in interface org.apache.bookkeeper.client.BookieWatcher
 
getBookieAddressResolver() - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
 
getBookieAddressResolver() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getBookieAddressResolver() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
getBookieAddressResolver() - Method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
 
getBookieAddressResolverEnabled() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Whether to enable BookieAddressResolver.
getBookieAuthProviderFactoryClass() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the bookie authentication provider factory class name.
getBookieClient() - Method in class org.apache.bookkeeper.client.BookKeeper
Get the BookieClient, currently used for doing bookie recovery.
getBookieClient() - Method in interface org.apache.bookkeeper.client.ClientContext
 
getBookieDriver(String) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Retrieve the bookie driver for scheme.
getBookieDriver(URI) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Retrieve the bookie driver for uri.
getBookieDrivers() - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
 
getBookieErrorThresholdPerInterval() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the error threshold for a bookie to be quarantined.
getBookieFailureHistory(BookieId) - Method in interface org.apache.bookkeeper.client.BookiesHealthInfo
Return the failure history for a bookie.
getBookieFailureHistoryExpirationMSec() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the bookie failure tracking expiration timeout.
getBookieHealthCheckIntervalSeconds() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the bookie health check interval in seconds.
getBookieHost() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string bookieHost = 1;
getBookieHost() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
required string bookieHost = 1;
getBookieHost() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
required string bookieHost = 1;
getBookieHostBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string bookieHost = 1;
getBookieHostBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
required string bookieHost = 1;
getBookieHostBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
required string bookieHost = 1;
getBookieId() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the configured BookieId for the bookie.
getBookieId() - Method in exception org.apache.bookkeeper.proto.BookieAddressResolver.BookieIdNotResolvedException
 
getBookieId() - Method in class org.apache.bookkeeper.proto.BookieServer
 
getBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
optional string bookieId = 1;
getBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
optional string bookieId = 1;
getBookieId() - Method in interface org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormatOrBuilder
optional string bookieId = 1;
getBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
optional string bookieId = 1;
getBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
optional string bookieId = 1;
getBookieId() - Method in interface org.apache.bookkeeper.proto.DataFormats.LockDataFormatOrBuilder
optional string bookieId = 1;
getBookieId(CookieFlagsT) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.CookieCommand
 
getBookieId(ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.BookieImpl
 
getBookieIdBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
optional string bookieId = 1;
getBookieIdBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
optional string bookieId = 1;
getBookieIdBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormatOrBuilder
optional string bookieId = 1;
getBookieIdBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
optional string bookieId = 1;
getBookieIdBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
optional string bookieId = 1;
getBookieIdBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.LockDataFormatOrBuilder
optional string bookieId = 1;
getBookieIndex() - Method in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
getBookieInfo() - Method in class org.apache.bookkeeper.client.BookieInfoReader
 
getBookieInfo() - Method in class org.apache.bookkeeper.client.BookKeeper
Retrieves BookieInfo from all the bookies in the cluster.
getBookieInfo(long, BookkeeperInternalCallbacks.GetBookieInfoCallback, Object) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
getBookieInfo(BookieId, long, BookkeeperInternalCallbacks.GetBookieInfoCallback, Object) - Method in interface org.apache.bookkeeper.proto.BookieClient
Read information about the bookie, from the bookie.
getBookieInfo(BookieId, long, BookkeeperInternalCallbacks.GetBookieInfoCallback, Object) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
getBookieInfoComplete(int, BookieInfoReader.BookieInfo, Object) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.GetBookieInfoCallback
 
GetBookieInfoCompletion(PerChannelBookieClient.CompletionKey, BookkeeperInternalCallbacks.GetBookieInfoCallback, Object) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.GetBookieInfoCompletion
 
GetBookieInfoProcessorV3 - Class in org.apache.bookkeeper.proto
A processor class for v3 bookie metadata packets.
GetBookieInfoProcessorV3(BookkeeperProtocol.Request, BookieRequestHandler, BookieRequestProcessor) - Constructor for class org.apache.bookkeeper.proto.GetBookieInfoProcessorV3
 
GETBOOKIEINFOREQUEST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
getBookieInfoRequestStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
GETBOOKIEINFORESPONSE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
getBookieInfoStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
getBookieInfoTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Return the timeout value for getBookieInfo request.
getBookieInfoTimeoutNanos - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
getBookieMaxWeightMultipleForWeightBasedPlacement() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Returns the max multiple to use for nodes with very high weight.
getBookiePendingRequests(BookieId) - Method in interface org.apache.bookkeeper.client.BookiesHealthInfo
Returns pending requests to a bookie.
getBookiePort() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get bookie port that bookie server listen on.
getBookieQuarantineRatio() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the bookie quarantine ratio.
getBookieQuarantineTimeSeconds() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the time for which a bookie will be quarantined.
getBookieRecoveryDigestType() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get digest type used in bookkeeper admin.
getBookieRecoveryPasswd() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get passwd used in bookkeeper admin.
getBookieRequestProcessor() - Method in class org.apache.bookkeeper.proto.BookieServer
 
getBookies() - Method in interface org.apache.bookkeeper.client.BookieWatcher
 
getBookies() - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
 
getBookieService() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getBookieServiceInfo(BookieId) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
getBookieServiceInfo(BookieId) - Method in interface org.apache.bookkeeper.discover.RegistrationClient
Get detailed information about the services exposed by a Bookie.
getBookieServiceInfo(BookieId) - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
getBookiesHealthInfo() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the health info for bookies for this ledger.
getBookiesIndexes() - Method in class org.apache.bookkeeper.client.LedgerFragment
Gets the failedBookie index.
getBookiesInThisLedger(LedgerMetadata) - Static method in class org.apache.bookkeeper.client.LedgerMetadataUtils
 
getBookieSocketAddrStringRepresentation(BookieId, BookieAddressResolver) - Static method in class org.apache.bookkeeper.tools.cli.helpers.CommandHelpers
 
getBookieToLedgerIndex() - Method in class org.apache.bookkeeper.replication.BookieLedgerIndexer
Generating bookie vs its ledgers map by reading all the ledgers in each bookie and parsing its metadata.
getBookieToLedgersMapCreationTime() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getBookieWatcher() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getBookieWatcher() - Method in interface org.apache.bookkeeper.client.ClientContext
 
getBookKeeper(ServerConfiguration) - Method in class org.apache.bookkeeper.replication.AuditorTask
Get BookKeeper client according to configuration.
getBookKeeperAdmin(BookKeeper) - Method in class org.apache.bookkeeper.replication.AuditorTask
Get BookKeeper admin according to bookKeeper client.
getBoolean(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getBoolean(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getBoolean(String, boolean) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getBoolean(String, Boolean) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getBoolean(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting from the configuration conf as a Boolean value.
getBooleanVariableOrDefault(ServerConfiguration, String, boolean) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getBoundedExecutor(ExecutorService) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
getBoundedExecutor(ExecutorService) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
 
getBucket(long) - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
Figure out which percentile bucket an event of a given duration belongs into.
getBucketBound(int) - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
Returns the upper bucket bound (inclusive) of a given bucket.
getBucketValue(int) - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
Returns the average value of a given bucket (the mean between its lower and upper bound).
getBuffer() - Method in class org.apache.bookkeeper.bookie.EntryKeyValue
 
getBuffer() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.EntryInfo
 
getBuffer(int) - Method in class org.apache.bookkeeper.util.ByteBufList
Get access to a particular buffer in the list.
getBufferedChannel() - Method in class org.apache.bookkeeper.bookie.JournalChannel
 
getBufferedChannelBuilder() - Method in class org.apache.bookkeeper.bookie.Journal
 
getByte() - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
 
getByte() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
getByte() - Method in interface com.scurrilous.circe.StatefulHash
Returns the first byte of the output of this hash function.
getByte(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getByte(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getByte(String, byte) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getByte(String, Byte) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getByteBufAllocator() - Method in interface org.apache.bookkeeper.client.ClientContext
 
getBytes() - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
 
getBytes() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
getBytes() - Method in interface com.scurrilous.circe.StatefulHash
Returns a new byte array containing the output of this hash function.
getBytes(byte[]) - Method in class org.apache.bookkeeper.util.ByteBufList
Write bytes from the current ByteBufList into a byte array.
getBytes(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
 
getBytes(byte[], int, int) - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
getBytes(byte[], int, int) - Method in interface com.scurrilous.circe.StatefulHash
Writes the output of this hash function into the given byte array at the given offset.
getBytes(int, byte[]) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getBytes(int, byte[], int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getBytes(int, ByteBuf) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getBytes(int, ByteBuf, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getBytes(int, ByteBuf, int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getBytes(int, OutputStream, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getBytes(int, ByteBuffer) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getBytes(int, FileChannel, long, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getBytes(int, GatheringByteChannel, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
GetBytesCallbackByteBuf(ByteBufVisitor.InternalContext<T>) - Constructor for class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getCache() - Static method in class com.scurrilous.circe.impl.HashCacheLoader
Returns the single hash function cache.
getCacheable(P, EnumSet<HashSupport>) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
Called by implementations that support caching of stateless hash functions when a cached instance is desired.
getCacheAsMap() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
getCachedOrReadMetadata(String) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
getCachedReadersServedClosedCounter() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLoggerStats
 
getCause() - Method in exception org.apache.bookkeeper.conf.UncheckedConfigurationException
Returns the cause of this exception.
getCeil(byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Get the entry whose key is bigger or equal the supplied key.
getCeil(byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
getChannelForLogId(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
getChannelWriteStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getChar(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getCharSequence(int, int, Charset) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getCheckAllLedgersCTime() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Getter for the CheckAllLedgers last executed ctime.
getCheckAllLedgersCTime() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
getCheckAllLedgersCTime() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getCheckAllLedgersCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
optional int64 checkAllLedgersCTime = 1;
getCheckAllLedgersCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
optional int64 checkAllLedgersCTime = 1;
getCheckAllLedgersCTime() - Method in interface org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormatOrBuilder
optional int64 checkAllLedgersCTime = 1;
getCheckAllLedgersTime() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getChildren() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
 
getChildren(String) - Method in class org.apache.bookkeeper.util.SubTreeCache
Returns children of node.
getChildren(String, boolean) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getChildren(String, boolean, AsyncCallback.Children2Callback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getChildren(String, boolean, AsyncCallback.ChildrenCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getChildren(String, boolean, Stat) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getChildren(String, Watcher) - Method in interface org.apache.bookkeeper.util.SubTreeCache.TreeProvider
 
getChildren(String, Watcher) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getChildren(String, Watcher, AsyncCallback.Children2Callback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getChildren(String, Watcher, AsyncCallback.ChildrenCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getChildren(String, Watcher, Stat) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getChildrenInSingleNode(ZooKeeper, String, long) - Static method in class org.apache.bookkeeper.util.ZkUtils
Sync get all children under single zk node.
getChildrenInSingleNode(ZooKeeper, String, BookkeeperInternalCallbacks.GenericCallback<List<String>>) - Static method in class org.apache.bookkeeper.util.ZkUtils
Async get direct children under single node.
getClass(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting from the configuration conf as a Class value.
getClass(Configuration, Class<T>) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting from the configuration conf as a Class value.
getClass(Configuration, String, Class<?>, ClassLoader) - Static method in class org.apache.bookkeeper.common.util.ReflectionUtils
Get the value of the name property as a Class.
getClass(Configuration, String, Class<? extends T>, Class<T>, ClassLoader) - Static method in class org.apache.bookkeeper.common.util.ReflectionUtils
Get the value of the name property as a Class implementing the interface specified by xface.
getClientAuthProviderFactoryClass() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the client authentication provider factory class name.
getClientChannelWriteWaitLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getClientChannelWriteWaitLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getClientConnectBookieUnavailableLogThrottlingMs() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the log frequency when a bookie is unavailable, in milliseconds.
getClientConnectTimeoutMillis() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get client netty connect timeout in millis.
getClientCtx() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getClientDriver(String) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Retrieve the client driver for scheme.
getClientDriver(URI) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Retrieve the client driver for uri.
getClientDrivers() - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
 
getClientEventLoopGroup(ClientConfiguration, ThreadFactory) - Static method in class org.apache.bookkeeper.util.EventLoopUtil
 
getClientReceiveBufferSize() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get client netty channel receive buffer size.
getClientRole() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the role of the client.
getClientSendBufferSize() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get client netty channel send buffer size.
getClientSockKeepalive() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
get socket keepalive.
getClientStats() - Method in interface org.apache.bookkeeper.client.ClientContext
 
getClientTcpNoDelay() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Is tcp connection no delay.
getClientWriteBufferHighWaterMark() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get client netty channel write buffer high water mark.
getClientWriteBufferLowWaterMark() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get client netty channel write buffer low water mark.
getCloseChannelOnResponseTimeout() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configures action in case if server timed out sending response to the client.
getCloseLock() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getCloseReaderCounter() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLoggerStats
 
getClusterInstanceId() - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Return the cluster instance id.
getClusterInstanceId() - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
getClusterInstanceId() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
getCmdPath(CliSpec<CliFlagsT>) - Static method in class org.apache.bookkeeper.tools.framework.Cli
 
getCode() - Method in exception org.apache.bookkeeper.bookie.BookieException
 
getCode() - Method in exception org.apache.bookkeeper.client.api.BKException
Get the return code for the exception.
getCode() - Method in enum org.apache.bookkeeper.meta.exceptions.Code
 
getCode() - Method in exception org.apache.bookkeeper.meta.exceptions.MetadataException
 
getCode() - Method in enum org.apache.bookkeeper.metastore.MSException.Code
Get the int value for a particular Code.
getCode() - Method in exception org.apache.bookkeeper.metastore.MSException
 
getColumnFamilyDescriptors() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
getCommand(String) - Method in class org.apache.bookkeeper.tools.framework.Cli
 
getCommandMap() - Method in class org.apache.bookkeeper.tools.framework.Cli
 
getCompactionMaxOutstandingRequests() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the maximum number of entries which can be compacted without flushing.
getCompactionRate() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
getCompactionRateByBytes() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the rate of compaction adds.
getCompactionRateByEntries() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the rate of compaction adds.
getCompletedTasksCount() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
getComponent(int) - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
getConf() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getConf() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
getConf() - Method in interface org.apache.bookkeeper.client.ClientContext
 
getConf() - Method in class org.apache.bookkeeper.common.component.AbstractComponent
 
getConf() - Method in interface org.apache.bookkeeper.conf.Configurable
Return the configuration used by this object.
getConf() - Method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
 
getConf() - Method in class org.apache.bookkeeper.net.ScriptBasedMapping
 
getConfiguration() - Method in interface org.apache.bookkeeper.sasl.JAASCredentialsContainer
 
getConfiguration() - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
getConfiguration() - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
getConfirmedLAC() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
getConnectionPeer() - Method in class org.apache.bookkeeper.proto.BookieNettyServer.BookieSideConnectionPeerContextHandler
 
GetCookieCommand - Class in org.apache.bookkeeper.tools.cli.commands.cookie
A command that deletes cookie.
GetCookieCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.GetCookieCommand
 
GetCookieCommand(PrintStream) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.GetCookieCommand
 
GetCookieCommand(GetCookieCommand.Flags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.GetCookieCommand
 
GetCookieCommand.Flags - Class in org.apache.bookkeeper.tools.cli.commands.cookie
Flags to delete a cookie for a given bookie.
getCookiePath(BookieId) - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
Returns the CookiePath of the bookie in the ZooKeeper.
getCopyOfCurrentLogs() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
getCount() - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
Returns the all-time count of events this timer has seen.
getCount(boolean) - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
getCounter(String) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
 
getCounter(String) - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
 
getCounter(String) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
 
getCounter(String) - Method in class org.apache.bookkeeper.stats.NullStatsLogger
 
getCounter(String) - Method in class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
getCounter(String) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
getCounter(String) - Method in interface org.apache.bookkeeper.stats.StatsLogger
 
getCounterMap() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger.EntryLogsPerLedgerCounter
 
getCoverageSet() - Method in interface org.apache.bookkeeper.client.DistributionSchedule
 
getCoverageSet() - Method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
getCpusOnSameCore(int) - Method in class org.apache.bookkeeper.common.util.affinity.impl.ProcessorsInfo
Given one cpu id, return all CPUs that are sharing the same core.
getCreateOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getCreateOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getCtime() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the creation timestamp of this ledger.
getCtime() - Method in class org.apache.bookkeeper.client.LedgerHandle
Returns the ledger creation time.
getCtime() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getCtime() - Method in class org.apache.bookkeeper.meta.UnderreplicatedLedger
 
getCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 ctime = 10;
getCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional int64 ctime = 10;
getCtime() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional int64 ctime = 10;
getCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
optional int64 ctime = 2;
getCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
optional int64 ctime = 2;
getCtime() - Method in interface org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormatOrBuilder
optional int64 ctime = 2;
getCToken() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Get the unique creator token of the Ledger.
getCToken() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getCToken() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 cToken = 12;
getCToken() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional int64 cToken = 12;
getCToken() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional int64 cToken = 12;
getCurMark() - Method in class org.apache.bookkeeper.bookie.Journal.LastLogMark
 
getCurrentAuditor() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
getCurrentAuditor() - Method in interface org.apache.bookkeeper.meta.LedgerAuditorManager
Return the information regarding the current auditor.
getCurrentAuditor() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerAuditorManager
 
getCurrentAuditor() - Method in class org.apache.bookkeeper.meta.ZkLedgerAuditorManager
 
getCurrentAuditor() - Method in class org.apache.bookkeeper.replication.AuditorElector
 
getCurrentDirectories(File[]) - Static method in class org.apache.bookkeeper.bookie.BookieImpl
 
getCurrentDirectory(File) - Static method in class org.apache.bookkeeper.bookie.BookieImpl
 
getCurrentEnsemble() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the current ensemble from the ensemble list.
getCurrentEnsemble() - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
getCurrentEnsemble(LedgerMetadata) - Static method in class org.apache.bookkeeper.client.LedgerMetadataUtils
 
getCurrentFuturePromiseSize() - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
getCurrentLogForLedger(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
getCurrentLogForLedger(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
getCurrentLogForLedger(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
getCurrentLogForLedgerForAddEntry(long, int, boolean) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
getCurrentLogForLedgerForAddEntry(long, int, boolean) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
getCurrentLogForLedgerForAddEntry(long, int, boolean) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
getCurrentLogId() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
getCurrentLogIfPresent(long) - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
getCurrentLogIfPresent(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
getCurrentLogIfPresent(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
getCurrentLogWithDirInfoForLedger(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
getCurrentVersion() - Method in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
getCurrentVersion() - Method in interface org.apache.bookkeeper.meta.LedgerManagerFactory
Return current factory version.
getCurrentVersion() - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
getCurrentVersion() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
getCurrentVersion() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
getCustomMetadata() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the custom metadata stored with the ledgers.
getCustomMetadata() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get this ledger's customMetadata map.
getCustomMetadata() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getCustomMetadata(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadata(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadata(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataBuilderList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataCount() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataCount() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataCount() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataList() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataOrBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataOrBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataOrBuilder(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataOrBuilderList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataOrBuilderList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getCustomMetadataOrBuilderList() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
getData() - Method in class org.apache.bookkeeper.auth.AuthToken
 
getData() - Method in class org.apache.bookkeeper.bookie.SkipListArena.MemorySlice
 
getData() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
getData() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ParsedAddRequest
 
getData() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
getData(String, boolean, AsyncCallback.DataCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getData(String, boolean, Stat) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getData(String, Watcher, AsyncCallback.DataCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getData(String, Watcher, Stat) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getDataIntegrityService() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getDatanodesInRack(String) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Given a string representation of a rack, return its children.
getDbLedgerStorageStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getDBPath() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Get storage path.
getDBPath() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
getDeathWatchInterval() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get bookie death watch interval.
getDefaultFaultDomain() - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
getDefaultHost(String) - Static method in class org.apache.bookkeeper.net.DNS
Returns the default (first) host name associated by the default nameserver with the address bound to the specified network interface.
getDefaultHost(String, String) - Static method in class org.apache.bookkeeper.net.DNS
Returns the default (first) host name associated by the provided nameserver with the address bound to the specified network interface.
getDefaultInstance() - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
getDefaultInstance() - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
getDefaultInstanceForType() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
getDefaultIP(String) - Static method in class org.apache.bookkeeper.net.DNS
Returns the first available IP address associated with the provided network interface or the local host IP if "default" is given.
getDefaultRack() - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
getDefaultRocksDBConf() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get default rocksdb conf.
getDefaultValue() - Method in interface org.apache.bookkeeper.stats.Gauge
 
getDelay - Variable in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
getDelayEnsembleChange() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Whether to delay ensemble change or not?
getDeletedLedgerCounter() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getDeleteOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getDeleteOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.AutoRecoveryCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieFormatCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieInfoCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieSanityTestCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.CheckDbLedgersIndexCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ClusterInfoCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ConvertToDbStorageCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ConvertToInterleavedStorageCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.DecommissionBookieCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.DeleteLedgerCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.EndpointInfoCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ForceAuditorChecksCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.HelpCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.InitBookieCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.InitNewCluster
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.LastMarkCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.LedgerCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.LedgerMetadataCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListActiveLedgersCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListBookiesCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListDiskFilesCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListLedgersCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListUnderreplicatedCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.LocalConsistencyCheck
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.LostBookieRecoveryDelayCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.MetaFormatCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.NukeExistingCluster
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.QueryAutoRecoveryStatusCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadJournalCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLedgerEntriesCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLogCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLogMetadataCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgerLocationsIndexCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgersIndexCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.RecoverCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.RegenerateInterleavedStorageIndexFile
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.SimpleTestCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.TriggerAuditCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateBookieInLedgerCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateCookieCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateLedgerCmd
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.WhatIsInstanceId
 
getDescription() - Method in class org.apache.bookkeeper.bookie.BookieShell.WhoIsAuditorCmd
 
getDescription() - Method in enum org.apache.bookkeeper.metastore.MSException.Code
Get the description for a particular Code.
getDescriptor() - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats
 
getDescriptor() - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
getDescriptor() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
getDescriptor() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
getDescriptor() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
 
getDescriptor() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
getDescriptor() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
getDescriptor() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
getDescriptor() - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
getDescriptor() - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
getDescriptor() - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
getDescriptorForType() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
getDescriptorForType() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
getDescriptorForType() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
getDescriptorForType() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
 
getDescriptorForType() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
getDescriptorForType() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
getDescriptorForType() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
getDescriptorForType() - Method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
getDescriptorForType() - Method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
getDescriptorForType() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
getDesiredNumZonesPerWriteQuorum() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the desired number of zones per write quorum in ZoneAwarePlacementPolicy.
getDigestManager() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the DigestManager.
getDigestType() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the digest type used by this ledger.
getDigestType() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getDigestType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional .LedgerMetadataFormat.DigestType digestType = 7;
getDigestType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional .LedgerMetadataFormat.DigestType digestType = 7;
getDigestType() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional .LedgerMetadataFormat.DigestType digestType = 7;
getDirForNextEntryLog(List<File>) - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
getDirForNextEntryLog(List<File>) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
getDirForNextEntryLog(List<File>) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
getDirsAboveUsableThresholdSize(long, boolean) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
 
getDisableEnsembleChangeFeatureName() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the name of the dynamic feature that disables ensemble change.
getDiskChecker() - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
 
getDiskChecker() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getDiskCheckInterval() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the disk checker interval.
getDiskLowWaterMarkUsageThreshold() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Returns disk free space low water mark threshold.
getDiskUsages() - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Get disk usages map.
getDiskUsageThreshold() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Returns disk free space threshold.
getDiskUsageThreshold() - Method in class org.apache.bookkeeper.util.DiskChecker
 
getDiskUsageWarnThreshold() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Returns the warning threshold for disk usage.
getDiskUsageWarnThreshold() - Method in class org.apache.bookkeeper.util.DiskChecker
 
getDiskWeightBasedPlacementEnabled() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Return whether disk weight based placement policy is enabled.
getDistance(Node, Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Return the distance between two nodes.
getDistributionSchedule() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the Distribution Schedule.
getDouble(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getDouble(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getDouble(String, double) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getDouble(String, Double) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getDouble(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting from the configuration conf as a Double value.
getDstLogId() - Method in interface org.apache.bookkeeper.bookie.storage.CompactionEntryLog
Get the log ID of the entrylog to which compacted entries are being written.
getDstLogId() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
getEnableBookieAddressTracking() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Whether to enable bookie address changes tracking.
getEnableBookieFailureTracking() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Whether to enable bookie failure tracking.
getEnableDigestTypeAutodetection() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get autodetection of digest type.
getEnableParallelRecoveryRead() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Whether to enable parallel reading in recovery read.
getEnableTaskExecutionStats() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Whether to enable recording task execution stats.
getEnableTaskExecutionStats() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Whether to enable recording task execution stats.
getEndpoints() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher
 
getEndpoints() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo
Unmodifieable structure with the list of exposed endpoints.
getEndpoints(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpoints(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpoints(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsBuilderList() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsCount() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsCount() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsCount() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsList() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsList() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsList() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsOrBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsOrBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsOrBuilder(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsOrBuilderList() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsOrBuilderList() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEndpointsOrBuilderList() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
getEnforceMinNumFaultDomainsForWrite() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the flag to enforce minimum number of fault domains for write.
getEnforceMinNumRacksPerWriteQuorum() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the flag which enforces the minimum number of racks per write quorum.
getEnforceStrictZoneawarePlacement() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the flag to enforce strict zoneaware placement.
getEnsemble() - Method in class org.apache.bookkeeper.client.LedgerFragment
Gets the ensemble of fragment.
getEnsembleAckSet() - Method in interface org.apache.bookkeeper.client.DistributionSchedule
Returns an ackset object useful to wait for all bookies in the ensemble, responses should be checked against this.
getEnsembleAckSet() - Method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
getEnsembleAt(long) - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the ensemble at the given entryId.
getEnsembleAt(long) - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getEnsembleBookieDistributionCounter(String) - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getEnsembleBookieDistributionCounter(String) - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getEnsembleChangeCounter() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getEnsembleChangeCounter() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getEnsembleMember(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
repeated string ensembleMember = 1;
getEnsembleMember(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
repeated string ensembleMember = 1;
getEnsembleMember(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.SegmentOrBuilder
repeated string ensembleMember = 1;
getEnsembleMemberBytes(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
repeated string ensembleMember = 1;
getEnsembleMemberBytes(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
repeated string ensembleMember = 1;
getEnsembleMemberBytes(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.SegmentOrBuilder
repeated string ensembleMember = 1;
getEnsembleMemberCount() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
repeated string ensembleMember = 1;
getEnsembleMemberCount() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
repeated string ensembleMember = 1;
getEnsembleMemberCount() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.SegmentOrBuilder
repeated string ensembleMember = 1;
getEnsembleMemberList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
repeated string ensembleMember = 1;
getEnsembleMemberList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
repeated string ensembleMember = 1;
getEnsembleMemberList() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.SegmentOrBuilder
repeated string ensembleMember = 1;
getEnsemblePlacementPolicy() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get Ensemble Placement Policy Class.
getEnsemblePlacementPolicySlowBookies() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Whether to order slow bookies in placement policy.
getEnsembleSet(long) - Method in interface org.apache.bookkeeper.client.DistributionSchedule
Return the set of bookies indices to send the messages to the whole ensemble.
getEnsembleSet(long) - Method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
getEnsembleSize() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the ensemble size of this ledger.
getEnsembleSize() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getEnsembleSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int32 ensembleSize = 2;
getEnsembleSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
required int32 ensembleSize = 2;
getEnsembleSize() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
required int32 ensembleSize = 2;
getEntries(LedgerEntryPage.EntryVisitor) - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
Iterates over non-empty entry mappings.
getEntriesCountGauge() - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndexStats
 
getEntriesIterator() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getEntriesIterator(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
getEntriesIterator(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
getEntriesIterator(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
getEntriesStripedToTheBookie(int, long, long) - Method in interface org.apache.bookkeeper.client.DistributionSchedule
Get the bitset representing the entries from entry 'startEntryId' to 'lastEntryId', that would be striped to the bookie with index - bookieIndex.
getEntriesStripedToTheBookie(int, long, long) - Method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
getEntry() - Method in exception org.apache.bookkeeper.bookie.Bookie.NoEntryException
 
getEntry() - Method in class org.apache.bookkeeper.bookie.EntryLocation
 
getEntry() - Method in interface org.apache.bookkeeper.client.api.LastConfirmedAndEntry
Gets wanted LedgerEntry.
getEntry() - Method in class org.apache.bookkeeper.client.impl.LastConfirmedAndEntryImpl
Gets wanted LedgerEntry.
getEntry() - Method in class org.apache.bookkeeper.client.LedgerEntry
Returns the content of the entry.
getEntry(long) - Method in interface org.apache.bookkeeper.client.api.LedgerEntries
Gets a specific LedgerEntry by entryId.
getEntry(long) - Method in class org.apache.bookkeeper.client.impl.LedgerEntriesImpl
Gets a specific LedgerEntry by entryId.
getEntry(long, long) - Method in class org.apache.bookkeeper.bookie.EntryMemTable
Find the entry with given key.
getEntry(long, long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
getEntry(long, long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Read an entry from storage.
getEntry(long, long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getEntry(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getEntry(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getEntryBuffer() - Method in interface org.apache.bookkeeper.client.api.LedgerEntry
Return the internal ByteBuf that contains the entry payload.
getEntryBuffer() - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
Return the internal ByteBuf that contains the entry payload.
getEntryBuffer() - Method in class org.apache.bookkeeper.client.LedgerEntry
Return the internal buffer that contains the entry payload.
getEntryBytes() - Method in interface org.apache.bookkeeper.client.api.LedgerEntry
Returns the content of the entry as a byte array.
getEntryBytes() - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
Returns the content of the entry as a byte array.
getEntryFormatterClass() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get entry formatter class.
getEntryId() - Method in class org.apache.bookkeeper.bookie.EntryKey
 
getEntryId() - Method in class org.apache.bookkeeper.bookie.LedgerStorage.DetectedInconsistency
 
getEntryId() - Method in interface org.apache.bookkeeper.client.api.LedgerEntry
The id of the entry.
getEntryId() - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
The id of the entry.
getEntryId() - Method in class org.apache.bookkeeper.client.LedgerEntry
 
getEntryId() - Method in class org.apache.bookkeeper.client.PendingAddOp
 
getEntryId() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
getEntryId() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
getEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required int64 entryId = 2;
getEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
required int64 entryId = 2;
getEntryId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
required int64 entryId = 2;
getEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required int64 entryId = 3;
getEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
required int64 entryId = 3;
getEntryId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponseOrBuilder
required int64 entryId = 3;
getEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
entryId will be -1 for reading the LAST_ADD_CONFIRMED entry.
getEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
entryId will be -1 for reading the LAST_ADD_CONFIRMED entry.
getEntryId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
entryId will be -1 for reading the LAST_ADD_CONFIRMED entry.
getEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required int64 entryId = 3;
getEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
required int64 entryId = 3;
getEntryId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
required int64 entryId = 3;
getEntryID() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.EntryInfo
 
getEntryInputStream() - Method in class org.apache.bookkeeper.client.LedgerEntry
Returns the content of the entry.
getEntryKey() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getEntryLocationDBPath() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
getEntryLocationDBPath() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getEntryLocationDBPath() - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
getEntryLocationDBPath() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getEntryLocationIndex() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getEntryLocationRocksdbConf() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get entry Location rocksdb conf.
getEntryLogger() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
getEntryLogger() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getEntryLogger() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getEntryLoggerAllocator() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
get EntryLoggerAllocator, Just for tests.
getEntryLogId() - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
getEntryLogManager() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
getEntrylogMapAccessExpiryTimeInSeconds() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
getEntryLogMetadata(long) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Retrieve metadata for the given entrylog ID.
getEntryLogMetadata(long, AbstractLogCompactor.Throttler) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
getEntryLogMetadata(long, AbstractLogCompactor.Throttler) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
getEntryLogMetadata(long, AbstractLogCompactor.Throttler) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Retrieve metadata for the given entrylog ID.
getEntryLogMetaMap() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
getEntryLogPerLedgerCounterLimitsMultFactor() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
getEntryLogSizeLimit() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get entry logger size limitation.
getEntryLogsSet() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Returns a set with the ids of all the entry log files.
getEntryLogWithDirInfo() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger.EntryLogAndLockTuple
 
getEntryNioBuffer() - Method in interface org.apache.bookkeeper.client.api.LedgerEntry
Exposes this entry's data as an NIO ByteBuffer.
getEntryNioBuffer() - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
Exposes this entry's data as an NIO ByteBuffer.
getEntryOffset(long, long) - Method in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
getEntryOffset(long, long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
getEntryOffset(long, long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
getEntryOffset(long, long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
getErrno() - Method in exception org.apache.bookkeeper.common.util.nativeio.NativeIOException
 
getErrorBookies() - Method in class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl.SinBin
 
getErrorCode() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
getEvictedLedgersCounter() - Method in class org.apache.bookkeeper.bookie.stats.IndexPersistenceMgrStats
 
getException() - Method in class org.apache.bookkeeper.bookie.LedgerStorage.DetectedInconsistency
 
getExceptionCode(Throwable) - Static method in exception org.apache.bookkeeper.client.BKException
Extract an exception code from an BKException, or default to unexpected exception if throwable is not a BKException.
getExceptionCode(Throwable, int) - Static method in exception org.apache.bookkeeper.client.BKException
Extract an exception code from an BKException, or use a default if it's another type.
getExecString() - Method in class org.apache.bookkeeper.util.Shell
Return an array containing the command name & its parameters.
getExecString() - Method in class org.apache.bookkeeper.util.Shell.ShellCommandExecutor
 
getExecutor() - Method in class org.apache.bookkeeper.bookie.SyncThread
 
getExists() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bool exists = 1;
getExists() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
required bool exists = 1;
getExists() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
required bool exists = 1;
getExitCode() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
getExitCode() - Method in class org.apache.bookkeeper.bookie.BookieImpl
Returns exit code - cause of failure.
getExitCode() - Method in class org.apache.bookkeeper.proto.BookieServer
 
getExitCode() - Method in exception org.apache.bookkeeper.util.Shell.ExitCodeException
 
getExitCode() - Method in class org.apache.bookkeeper.util.Shell
Get the exit code.
getExplicitLac() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
getExplicitLac() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
getExplicitLac() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
getExplicitLac() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
optional bytes explicitLac = 4;
getExplicitLac() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
optional bytes explicitLac = 4;
getExplicitLac() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
optional bytes explicitLac = 4;
getExplicitLac() - Method in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
getExplicitLac(long) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
getExplicitLac(long) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getExplicitLac(long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
getExplicitLac(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
getExplicitLac(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
getExplicitLac(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
getExplicitLac(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
getExplicitLac(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
getExplicitLac(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getExplicitLac(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getExplicitLac(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getExplictLacInterval() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the configured interval between explicit LACs to bookies.
getExtensions() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher.EndpointInfo
 
getExtensions() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
getExtensions(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string extensions = 6;
getExtensions(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
repeated string extensions = 6;
getExtensions(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
repeated string extensions = 6;
getExtensionsBytes(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string extensions = 6;
getExtensionsBytes(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
repeated string extensions = 6;
getExtensionsBytes(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
repeated string extensions = 6;
getExtensionsCount() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string extensions = 6;
getExtensionsCount() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
repeated string extensions = 6;
getExtensionsCount() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
repeated string extensions = 6;
getExtensionsList() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string extensions = 6;
getExtensionsList() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
repeated string extensions = 6;
getExtensionsList() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
repeated string extensions = 6;
getExtraServerComponents() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the extra list of server lifecycle components to enable on a bookie server.
getFailedBookies() - Method in interface org.apache.bookkeeper.client.DistributionSchedule.AckSet
Return the list of bookies that already failed.
getFailedTasksCount() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
getFaultyBookies() - Method in interface org.apache.bookkeeper.proto.BookieClient
Get the list of bookies which have exhibited more error responses than a configured threshold.
getFaultyBookies() - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
getFD() - Method in interface org.apache.bookkeeper.bookie.BookieFileChannel
Get the file descriptor of the opened file.
getFD() - Method in class org.apache.bookkeeper.bookie.DefaultFileChannel
 
getFeature(String) - Method in class org.apache.bookkeeper.feature.CacheableFeatureProvider
 
getFeature(String) - Method in interface org.apache.bookkeeper.feature.FeatureProvider
Return the feature with given name.
getFeature(String, Feature) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
 
getFenced() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bool fenced = 2;
getFenced() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
required bool fenced = 2;
getFenced() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
required bool fenced = 2;
getFenceReadEntryStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getFenceReadRequestStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getFenceReadWaitStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getField(String) - Method in class org.apache.bookkeeper.metastore.Value
 
getFields() - Method in class org.apache.bookkeeper.metastore.Value
 
getFieldsMap() - Method in class org.apache.bookkeeper.metastore.Value
 
getFifteenMinuteRate() - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
 
getFileChannel() - Method in interface org.apache.bookkeeper.bookie.BookieFileChannel
An interface for get the FileChannel from the provider.
getFileChannel() - Method in class org.apache.bookkeeper.bookie.DefaultFileChannel
 
getFileChannelPosition() - Method in class org.apache.bookkeeper.bookie.BufferedChannel
Get the position of the file channel's write pointer.
getFileInfo(Long, byte[]) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
Get the FileInfo and increase reference count.
getFileInfoCacheInitialCapacity() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the minimum total size for the internal file info cache tables.
getFileInfoFormatVersionToWrite() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get fileinfo format version to write.
getFileInfoMaxIdleTime() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the max idle time allowed for a open file info existed in file info cache.
getFileName() - Method in class org.apache.bookkeeper.tls.FileModifiedTimeUpdater
 
getFirst() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LongPairWrapper
 
getFirstEntry() - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.RecoveryStats
 
getFirstEntry() - Method in interface org.apache.bookkeeper.bookie.LedgerCache.PageEntries
 
getFirstEntry() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getFirstEntryId() - Method in class org.apache.bookkeeper.client.LedgerFragment
 
getFirstEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
required int64 firstEntryId = 2;
getFirstEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
required int64 firstEntryId = 2;
getFirstEntryId() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.SegmentOrBuilder
required int64 firstEntryId = 2;
getFirstEntryPosition() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getFirstError() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
getFirstHalf(String) - Static method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Divide networklocation string into two parts by last separator, and get the first part here.
getFirstSpeculativeReadLACTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the period of time after which the first speculative read last add confirmed and entry should be triggered.
getFirstSpeculativeReadTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the first speculative read timeout.
getFirstStoredEntryId() - Method in class org.apache.bookkeeper.client.LedgerFragment
Gets the first stored entry id of the fragment in failed bookies.
getFirstStoredEntryId(int) - Method in class org.apache.bookkeeper.client.LedgerFragment
Get the first stored entry id of the fragment in the given failed bookies.
getFiveMinuteRate() - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
 
getFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
optional .AddRequest.Flag flag = 100;
getFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
optional .AddRequest.Flag flag = 100;
getFlag() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
optional .AddRequest.Flag flag = 100;
getFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
optional .ReadRequest.Flag flag = 100;
getFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
optional .ReadRequest.Flag flag = 100;
getFlag() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
optional .ReadRequest.Flag flag = 100;
getFlags() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
getFlags(int) - Static method in class org.apache.bookkeeper.proto.BookieProtocol.PacketHeader
 
getFloat(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getFloat(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getFloat(String, float) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getFloat(String, Float) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getFloor(byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Get the entry whose key is the biggest and it's lesser than the supplied key.
getFloor(byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
getFlushBytesCounter() - Method in class org.apache.bookkeeper.bookie.stats.EntryMemTableStats
 
getFlushedLogIds() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
getFlushedLogIds() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
getFlushedLogIds() - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Get the log ids for the set of logs which have been completely flushed to disk.
getFlushEmptyQueueCounter() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getFlushEntryLogStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getFlushInterval() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get flush interval.
getFlushIntervalInBytes() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set entry log flush interval in bytes.
getFlushLedgerIndexStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getFlushLocationIndexStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getFlushMaxOutstandingBytesCounter() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getFlushMaxWaitCounter() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getFlushSizeStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getFlushStats() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLoggerStats
 
getFlushStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getForceLedgerOps() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getForceLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ForceLedgerRequest forceLedgerRequest = 107;
getForceLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .ForceLedgerRequest forceLedgerRequest = 107;
getForceLedgerRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .ForceLedgerRequest forceLedgerRequest = 107;
getForceLedgerRequestBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ForceLedgerRequest forceLedgerRequest = 107;
getForceLedgerRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ForceLedgerRequest forceLedgerRequest = 107;
getForceLedgerRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .ForceLedgerRequest forceLedgerRequest = 107;
getForceLedgerRequestOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .ForceLedgerRequest forceLedgerRequest = 107;
getForceLedgerRequestStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getForceLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ForceLedgerResponse forceLedgerResponse = 107;
getForceLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .ForceLedgerResponse forceLedgerResponse = 107;
getForceLedgerResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .ForceLedgerResponse forceLedgerResponse = 107;
getForceLedgerResponseBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ForceLedgerResponse forceLedgerResponse = 107;
getForceLedgerResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ForceLedgerResponse forceLedgerResponse = 107;
getForceLedgerResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .ForceLedgerResponse forceLedgerResponse = 107;
getForceLedgerResponseOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .ForceLedgerResponse forceLedgerResponse = 107;
getForceLedgerStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getForceOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getForceOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getForceWriteBatchBytesStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getForceWriteBatchEntriesStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getForceWriteGroupingCountStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getForceWriteQueueSize() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getForEntry(long) - Method in class org.apache.bookkeeper.bookie.datainteg.WriteSets
 
getFormatVersion() - Method in class org.apache.bookkeeper.bookie.JournalChannel
 
getFreeDiskSpace() - Method in class org.apache.bookkeeper.client.BookieInfoReader.BookieInfo
 
getFreeDiskSpace() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
optional int64 freeDiskSpace = 3;
getFreeDiskSpace() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
optional int64 freeDiskSpace = 3;
getFreeDiskSpace() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponseOrBuilder
optional int64 freeDiskSpace = 3;
getFreeDiskSpace(BookieId) - Method in class org.apache.bookkeeper.client.BookieInfoReader
Method to allow tests to block until bookie info is available.
getFreeSpace() - Method in class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
getFromChannels(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
getFullFilledLedgerDirs() - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
 
getFwEnqueueTimeStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getGarbageCollectionStatus() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
getGarbageCollectionStatus() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
getGarbageCollectionStatus() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Get Garbage Collection status.
getGarbageCollectionStatus() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getGarbageCollectionStatus() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getGarbageCollectionStatus() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getGcEntryLogMetadataCachePath() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get directory to persist Entrylog metadata if gcPersistentEntrylogMetadataMapEnabled is true.
getGcOverreplicatedLedgerMaxConcurrentRequests() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Max number of concurrent requests in garbage collection of overreplicated ledgers.
getGcOverreplicatedLedgerWaitTimeMillis() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get wait time in millis for garbage collection of overreplicated ledgers.
getGcThreadRuntime() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getGcWaitTime() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get Garbage collection wait time.
getGetBookieInfoIntervalSeconds() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the time interval between successive calls for bookie get info.
getGetBookieInfoRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
getGetBookieInfoRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
getGetBookieInfoRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
getGetBookieInfoRequestBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
getGetBookieInfoRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
getGetBookieInfoRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
getGetBookieInfoRequestOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
getGetBookieInfoRequestStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getGetBookieInfoResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
getGetBookieInfoResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
getGetBookieInfoResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
getGetBookieInfoResponseBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
getGetBookieInfoResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
getGetBookieInfoResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
getGetBookieInfoResponseOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
getGetBookieInfoRetryIntervalSeconds() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the time interval between retries on unsuccessful bookie info request.
getGetBookieInfoStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getGetEntryStats() - Method in class org.apache.bookkeeper.bookie.stats.EntryMemTableStats
 
getGetListOfEntriesOfLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
getGetListOfEntriesOfLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
getGetListOfEntriesOfLedgerRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
getGetListOfEntriesOfLedgerRequestBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
getGetListOfEntriesOfLedgerRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
getGetListOfEntriesOfLedgerRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
getGetListOfEntriesOfLedgerRequestOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
getGetListOfEntriesOfLedgerRequestStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getGetListOfEntriesOfLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
getGetListOfEntriesOfLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
getGetListOfEntriesOfLedgerResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
getGetListOfEntriesOfLedgerResponseBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
getGetListOfEntriesOfLedgerResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
getGetListOfEntriesOfLedgerResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
getGetListOfEntriesOfLedgerResponseOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
getGetListOfEntriesOfLedgerStats() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getGetListOfEntriesOfLedgerStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getGroups() - Method in class org.apache.bookkeeper.common.conf.ConfigDef
 
getHandle() - Method in class org.apache.bookkeeper.bookie.LastAddConfirmedUpdateNotification
 
getHandle(long, byte[]) - Method in interface org.apache.bookkeeper.bookie.HandleFactory
 
getHandle(long, byte[]) - Method in class org.apache.bookkeeper.bookie.HandleFactoryImpl
 
getHandlerName() - Method in interface org.apache.bookkeeper.tls.SecurityHandlerFactory
 
getHandlerName() - Method in class org.apache.bookkeeper.tls.TLSContextFactory
 
getHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
required .BKPacketHeader header = 1;
getHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
required .BKPacketHeader header = 1;
getHeader() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
required .BKPacketHeader header = 1;
getHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
required .BKPacketHeader header = 1;
getHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
required .BKPacketHeader header = 1;
getHeader() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
required .BKPacketHeader header = 1;
getHeader() - Method in class org.apache.bookkeeper.proto.PacketProcessorBaseV3
Build a header with protocol version 3 and the operation type same as what was in the request.
getHeaderBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
required .BKPacketHeader header = 1;
getHeaderBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
required .BKPacketHeader header = 1;
getHeaderOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
required .BKPacketHeader header = 1;
getHeaderOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
required .BKPacketHeader header = 1;
getHeaderOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
required .BKPacketHeader header = 1;
getHeaderOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
required .BKPacketHeader header = 1;
getHeaderOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
required .BKPacketHeader header = 1;
getHeaderOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
required .BKPacketHeader header = 1;
getHighPriorityThreadPool() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
The threadpool used to execute high priority requests.
getHost() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher.EndpointInfo
 
getHost() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
getHost() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string host = 3;
getHost() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required string host = 3;
getHost() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required string host = 3;
getHostBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string host = 3;
getHostBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required string host = 3;
getHostBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required string host = 3;
getHostName() - Method in class org.apache.bookkeeper.net.BookieSocketAddress
 
getHostnameVerificationEnabled() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Whether hostname verification enabled?
getHosts(String) - Static method in class org.apache.bookkeeper.net.DNS
Returns all the host names associated by the default nameserver with the address bound to the specified network interface.
getHosts(String, String) - Static method in class org.apache.bookkeeper.net.DNS
Returns all the host names associated by the provided nameserver with the address bound to the specified network interface.
getHttpServerHost() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the http server host.
getHttpServerKeystorePassword() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the http server keyStore password.
getHttpServerKeystorePath() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the http server keystore path.
getHttpServerPort() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the http server port.
getHttpServerTrustStorePassword() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the http server trustStore password.
getHttpServerTrustStorePath() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the http server trustStore path.
getHttpService() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getHybridHierarchicalLedgerPath(long) - Static method in class org.apache.bookkeeper.util.StringUtils
 
getId() - Method in interface org.apache.bookkeeper.client.api.Handle
Get the id of the current ledger.
getId() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the id of the current ledger.
getId() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher.EndpointInfo
 
getId() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
getId() - Method in class org.apache.bookkeeper.net.BookieId
 
getId() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string id = 1;
getId() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required string id = 1;
getId() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required string id = 1;
getIdBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string id = 1;
getIdBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required string id = 1;
getIdBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required string id = 1;
getIgnoreExtraServerComponentsStartupFailures() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Return the flag whether to ignore startup failures on loading server components specified at ServerConfiguration.getExtraServerComponents().
getIgnoreLocalNodeInPlacementPolicy() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Whether to ignore localnode in placementpolicy.
getIllegalStateDeleteCounter() - Method in class org.apache.bookkeeper.bookie.stats.IndexInMemPageMgrStats
 
getIllegalStateResetCounter() - Method in class org.apache.bookkeeper.bookie.stats.IndexInMemPageMgrStats
 
getIncrementalInt(HashParameters) - Static method in class com.scurrilous.circe.Hashes
Requests an incremental, stateless, int-width hash function with the given parameters.
getIncrementalInt(HashParameters) - Method in interface com.scurrilous.circe.HashProvider
Requests an incremental, stateless, int-width hash function with the given parameters.
getIncrementalInt(HashParameters) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
 
getIncrementalLong(HashParameters) - Static method in class com.scurrilous.circe.Hashes
Requests an incremental, stateless, long-width hash function with the given parameters.
getIncrementalLong(HashParameters) - Method in interface com.scurrilous.circe.HashProvider
Requests an incremental, stateless, long-width hash function with the given parameters.
getIncrementalLong(HashParameters) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
 
getIndexDirNames() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get dir name to store index files.
getIndexDirPathsFromCookie() - Method in class org.apache.bookkeeper.bookie.Cookie
 
getIndexDirs() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get index dir to store ledger index files.
getIndexDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string indexDirs = 5;
getIndexDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
optional string indexDirs = 5;
getIndexDirs() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
optional string indexDirs = 5;
getIndexDirsBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string indexDirs = 5;
getIndexDirsBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
optional string indexDirs = 5;
getIndexDirsBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
optional string indexDirs = 5;
getIndexDirsManager() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getIndexDirsManager() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getIndexEntries(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
Return iterable for index entries for ledgerId.
getIndexEntrySize() - Static method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getIndexPageManager() - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
getIndexPersistenceManager() - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
getInFlightReadEntryNumInLedgerChecker() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get in flight read entry number when ledger checker.
getInstance() - Static method in class org.apache.bookkeeper.proto.BKStats
 
getInstanceId() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string instanceId = 4;
getInstanceId() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
optional string instanceId = 4;
getInstanceId() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
optional string instanceId = 4;
getInstanceIdBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string instanceId = 4;
getInstanceIdBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
optional string instanceId = 4;
getInstanceIdBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
optional string instanceId = 4;
getInt() - Method in class com.scurrilous.circe.crc.JavaCrc32
 
getInt() - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
getInt() - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
getInt() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
getInt() - Method in interface com.scurrilous.circe.StatefulHash
Returns the first four bytes of the output of this hash function as a little-endian int.
getInt(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getInt(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getInt(String, int) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getInt(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting from the configuration conf as a Integer value.
getInteger(String, Integer) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getInterfaceClass() - Method in class org.apache.bookkeeper.common.conf.validators.ClassValidator
 
getIntLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getIPs(String) - Static method in class org.apache.bookkeeper.net.DNS
Like DNS.getIPs(String, boolean), but returns all IPs associated with the given interface and its subinterfaces.
getIPs(String, boolean) - Static method in class org.apache.bookkeeper.net.DNS
Returns all the IPs associated with the provided interface, if any, in textual form.
getIsForceGCAllowWhenNoSpace() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether force compaction is allowed when disk full or almost full.
getIsThrottleByBytes() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether use bytes to throttle garbage collector compaction or not.
getIterator() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
getJournalAdaptiveGroupWrites() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Should we group journal force writes.
getJournalAddEntryStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalAlignmentSize() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
All the journal writes and commits should be aligned to given size.
getJournalBufferedEntriesThreshold() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Maximum entries to buffer to impose on a journal write to achieve grouping.
getJournalBufferedWritesThreshold() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Maximum bytes to buffer to impose on a journal write to achieve grouping.
getJournalChannelProvider() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
getJournalCreationStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalDir() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string journalDir = 2;
getJournalDir() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
required string journalDir = 2;
getJournalDir() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
required string journalDir = 2;
getJournalDirBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string journalDir = 2;
getJournalDirBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
required string journalDir = 2;
getJournalDirBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
required string journalDir = 2;
getJournalDirectory() - Method in class org.apache.bookkeeper.bookie.Journal
 
getJournalDirName() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Deprecated.
getJournalDirNames() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get dir names to store journal files.
getJournalDirNameWithoutDefault() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get dir name to store journal files.
getJournalDirs() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get dirs to store journal files.
getJournalDirsGauge() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getJournalFlushStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalFlushWhenQueueEmpty() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Should we flush the journal when queue is empty.
getJournalForceLedgerStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalFormatVersionToWrite() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get journal format version to write.
getJournalMaxGroupWaitMSec() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Maximum latency to impose on a journal write to achieve grouping.
getJournalMaxMemorySizeMb() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the max amount of memory that can be used by the journal.
getJournalMemoryMaxStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalMemoryUsedStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalPageCacheFlushIntervalMSec() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get journal pageCache flush interval.
getJournalPreAllocSizeMB() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
How much space should we pre-allocate at a time in the journal.
getJournalProcessTimeStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalQueueLength() - Method in class org.apache.bookkeeper.bookie.Journal
Get the length of journal entries queue.
getJournalQueueMaxQueueSizeGauge() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getJournalQueueSize() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalQueueSize() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get size of journal queue.
getJournalQueueStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalRemovePagesFromCache() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Should we remove pages from page cache after force write.
getJournalReuseFiles() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get reuse journal files.
getJournals() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getJournalStats() - Method in class org.apache.bookkeeper.bookie.Journal
 
getJournalSyncData() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Should the data be fsynced on journal before acknowledgment.
getJournalSyncStats() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalWriteBufferSizeKB() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Size of the write buffers used for the journal.
getJournalWriteBytes() - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
getJournalWriteData() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Should the data be written to journal before acknowledgment.
getKey() - Method in class org.apache.bookkeeper.metastore.MetastoreTableItem
Get the key of the table item.
getKey() - Method in class org.apache.bookkeeper.metastore.MSWatchedEvent
 
getKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string key = 1;
getKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
required string key = 1;
getKey() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPairOrBuilder
required string key = 1;
getKey() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional string key = 1;
getKey() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
optional string key = 1;
getKey() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntryOrBuilder
optional string key = 1;
getKeyBytes() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string key = 1;
getKeyBytes() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
required string key = 1;
getKeyBytes() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPairOrBuilder
required string key = 1;
getKeyBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional string key = 1;
getKeyBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
optional string key = 1;
getKeyBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntryOrBuilder
optional string key = 1;
getKeyName(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getKeys() - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getKeys() - Method in class org.apache.bookkeeper.common.conf.ConcurrentConfiguration
 
getKeys() - Method in class org.apache.bookkeeper.common.conf.ConfigDef
 
getKeys(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getLabels() - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
getLabels() - Method in class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
 
getLabels() - Method in class org.apache.bookkeeper.stats.prometheus.SimpleGauge
 
getLac() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required int64 lac = 2;
getLac() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
required int64 lac = 2;
getLac() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequestOrBuilder
required int64 lac = 2;
getLacBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
lac sent by PutLacRequest
getLacBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
lac sent by PutLacRequest
getLacBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponseOrBuilder
lac sent by PutLacRequest
getLacComplete(int, long) - Method in interface org.apache.bookkeeper.client.PendingReadLacOp.LacCallback
 
getLacUpdateHitsCounter() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getLacUpdateHitsCounter() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getLacUpdateMissesCounter() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getLacUpdateMissesCounter() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getLacUpdateTimestamp() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
optional int64 lacUpdateTimestamp = 6;
getLacUpdateTimestamp() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
optional int64 lacUpdateTimestamp = 6;
getLacUpdateTimestamp() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
optional int64 lacUpdateTimestamp = 6;
getLacUpdateTimestamp() - Method in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
getLastAddConfirmed() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
getLastAddConfirmed() - Method in class org.apache.bookkeeper.bookie.LastAddConfirmedUpdateNotification
 
getLastAddConfirmed() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
getLastAddConfirmed() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
getLastAddConfirmed() - Method in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
getLastAddConfirmed() - Method in interface org.apache.bookkeeper.client.api.LastConfirmedAndEntry
Gets LastAddConfirmed entryId.
getLastAddConfirmed() - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Get the last confirmed entry id on this ledger.
getLastAddConfirmed() - Method in class org.apache.bookkeeper.client.impl.LastConfirmedAndEntryImpl
Gets LastAddConfirmed entryId.
getLastAddConfirmed() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the last confirmed entry id on this ledger.
getLastAddConfirmed() - Method in class org.apache.bookkeeper.client.ReadOpBase.ReadContext
 
getLastAddConfirmed() - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.ReadEntryCallbackCtx
 
getLastAddConfirmed() - Method in class org.apache.bookkeeper.proto.checksum.DigestManager.RecoveryData
 
getLastAddConfirmed() - Method in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
getLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
getLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
getLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
getLastAddConfirmed(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
getLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
getLastAddConfirmed(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Get last add confirmed.
getLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getLastAddPushed() - Method in interface org.apache.bookkeeper.client.api.WriteHandle
Get the entry id of the last entry that has been enqueued for addition (but may not have possibly been persisted to the ledger).
getLastAddPushed() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the entry id of the last entry that has been enqueued for addition (but may not have possibly been persisted to the ledger).
getlastConfirmed() - Method in class org.apache.bookkeeper.client.LedgerHandle.LastConfirmedCtx
 
getLastEnsembleKey(LedgerMetadata) - Static method in class org.apache.bookkeeper.client.LedgerMetadataUtils
 
getLastEnsembleValue(LedgerMetadata) - Static method in class org.apache.bookkeeper.client.LedgerMetadataUtils
 
getLastEntry() - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.RecoveryStats
 
getLastEntry() - Method in interface org.apache.bookkeeper.bookie.LedgerCache.PageEntries
 
getLastEntry() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getLastEntry(long) - Method in class org.apache.bookkeeper.bookie.EntryMemTable
Find the last entry with the given ledger key.
getLastEntry(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
getLastEntry(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
getLastEntry(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
getLastEntry(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getLastEntry(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getLastEntry(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
getLastEntryBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
Actual last entry on the disk
getLastEntryBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
Actual last entry on the disk
getLastEntryBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponseOrBuilder
Actual last entry on the disk
getLastEntryId() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the last entry id of this ledger.
getLastEntryId() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getLastEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 lastEntryId = 4;
getLastEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional int64 lastEntryId = 4;
getLastEntryId() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional int64 lastEntryId = 4;
getLastEntryIDCompleted() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
getLastEntryInLedger(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getLastEntryInLedger(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
getLastEntryInMem(long) - Method in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
getLastHalf(String) - Static method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Divide networklocation string into two parts by last separator, and get the second part here.
getLastKnownEntryId() - Method in class org.apache.bookkeeper.client.LedgerFragment
 
getLastLogin() - Method in class org.apache.bookkeeper.sasl.TGTRefreshThread
 
getLastLogMark() - Method in class org.apache.bookkeeper.bookie.Journal
 
GetLastLogMarkService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper get last log mark related http request.
GetLastLogMarkService(ServerConfiguration) - Constructor for class org.apache.bookkeeper.server.http.service.GetLastLogMarkService
 
getLastMajorCompactionTime() - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
getLastMinorCompactionTime() - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
getLastModifiedTime() - Method in class org.apache.bookkeeper.tls.FileModifiedTimeUpdater
 
getLastPresentTime() - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology.NodeStatus
 
getLastStoredEntryId() - Method in class org.apache.bookkeeper.client.LedgerFragment
Gets the last stored entry id of the fragment in failed bookie.
getLastStoredEntryId(int) - Method in class org.apache.bookkeeper.client.LedgerFragment
Get the last stored entry id of the fragment in the given failed bookie.
getLatencyHist() - Method in class org.apache.bookkeeper.proto.BKStats.OpStatData
 
getLayoutFormatVersion() - Method in class org.apache.bookkeeper.meta.LedgerLayout
 
getLayoutManager() - Method in interface org.apache.bookkeeper.meta.MetadataBookieDriver
Return the layout manager.
getLayoutManager() - Method in interface org.apache.bookkeeper.meta.MetadataClientDriver
Return the layout manager.
getLayoutManager() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver
 
getLayoutManager() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
getLeaf(int, Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Get leafIndex leaf of this subtree if it is not in the excludedNode.
getLeastUnflushedLogId() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
getLeastUnflushedLogId() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.RecentEntryLogsStatus
 
getLeaves(String) - Method in interface org.apache.bookkeeper.net.NetworkTopology
Returns the nodes under a location.
getLeaves(String) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
 
getLeaves(String) - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
getLedger() - Method in exception org.apache.bookkeeper.bookie.Bookie.NoEntryException
 
getLedger() - Method in class org.apache.bookkeeper.bookie.EntryLocation
 
getLedger() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getLedgerCache() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
getLedgerDirNames() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get dir names to store ledger data.
getLedgerDirPathsFromCookie() - Method in class org.apache.bookkeeper.bookie.Cookie
 
getLedgerDirs() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get dirs that stores ledger data.
getLedgerDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string ledgerDirs = 3;
getLedgerDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
required string ledgerDirs = 3;
getLedgerDirs() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
required string ledgerDirs = 3;
getLedgerDirsBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string ledgerDirs = 3;
getLedgerDirsBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
required string ledgerDirs = 3;
getLedgerDirsBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
required string ledgerDirs = 3;
getLedgerDirsManager() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getLedgerDirsManager() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
getLedgerDirsManager() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getLedgerDirWithoutDefault() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get dir names to store ledger data.
getLedgerEntryPage(long, long) - Method in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
Get the ledger entry page for a given pageEntry.
getLedgerEntryPageFromCache(long, long, boolean) - Method in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
getLedgerForEntry(ByteBuf, byte[]) - Method in class org.apache.bookkeeper.bookie.BookieImpl
Retrieve the ledger descriptor for the ledger which entry should be added to.
getLedgerId() - Method in exception org.apache.bookkeeper.bookie.Bookie.NoLedgerException
 
getLedgerId() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult
 
getLedgerId() - Method in class org.apache.bookkeeper.bookie.EntryKey
 
getLedgerId() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
getLedgerId() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
getLedgerId() - Method in class org.apache.bookkeeper.bookie.LedgerStorage.DetectedInconsistency
 
getLedgerId() - Method in interface org.apache.bookkeeper.client.api.LedgerEntry
The id of the ledger which contains the entry.
getLedgerId() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the id of this ledger.
getLedgerId() - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
The id of the ledger which contains the entry.
getLedgerId() - Method in class org.apache.bookkeeper.client.LedgerEntry
 
getLedgerId() - Method in class org.apache.bookkeeper.client.LedgerFragment
 
getLedgerId() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getLedgerId() - Method in class org.apache.bookkeeper.meta.UnderreplicatedLedger
 
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
required int64 ledgerId = 1;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
required int64 ledgerId = 2;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponseOrBuilder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
required int64 ledgerId = 1;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequestOrBuilder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
required int64 ledgerId = 2;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponseOrBuilder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
required int64 ledgerId = 1;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequestOrBuilder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
required int64 ledgerId = 2;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponseOrBuilder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
required int64 ledgerId = 1;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequestOrBuilder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
required int64 ledgerId = 2;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponseOrBuilder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
required int64 ledgerId = 1;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
required int64 ledgerId = 2;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
required int64 ledgerId = 1;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequestOrBuilder
required int64 ledgerId = 1;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
required int64 ledgerId = 2;
getLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
required int64 ledgerId = 2;
getLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponseOrBuilder
required int64 ledgerId = 2;
getLedgerId(String) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
Get ledger id from its znode ledger path.
getLedgerId(String) - Method in class org.apache.bookkeeper.meta.FlatLedgerManager
 
getLedgerId(String) - Method in class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
getLedgerId(String) - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManager
 
getLedgerId(String) - Method in class org.apache.bookkeeper.meta.LongHierarchicalLedgerManager
 
getLedgerId(String...) - Method in class org.apache.bookkeeper.meta.AbstractHierarchicalLedgerManager
 
getLedgerIdAssigned() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.BufferedLogChannel
 
getLedgerIdFormatterClass() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get ledger id formatter class.
getLedgerIdGenerator() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getLedgerKey() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the Ledger's key/password.
getLedgerManager() - Method in class org.apache.bookkeeper.client.BookKeeper
Returns ref to speculative read counter, needed in PendingReadOp.
getLedgerManager() - Method in interface org.apache.bookkeeper.client.ClientContext
 
getLedgerManagerFactory() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getLedgerManagerFactory() - Method in interface org.apache.bookkeeper.meta.MetadataBookieDriver
Return the ledger manager factory used for accessing ledger metadata.
getLedgerManagerFactory() - Method in interface org.apache.bookkeeper.meta.MetadataClientDriver
Return the ledger manager factory used for accessing ledger metadata.
getLedgerManagerFactory() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver
 
getLedgerManagerFactory() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
getLedgerManagerFactory() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getLedgerManagerFactoryClass() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get ledger manager factory class.
getLedgerManagerFactoryClassName() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get Ledger Manager Factory Class Name.
getLedgerManagerLayoutStringFromFactoryClass() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get layout string ("null" if unconfigured).
getLedgerManagerType() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
getLedgerMetadata() - Method in interface org.apache.bookkeeper.client.api.Handle
Returns the metadata of this ledger.
getLedgerMetadata() - Method in class org.apache.bookkeeper.client.LedgerHandle
Returns the metadata of this ledger.
getLedgerMetadata() - Method in class org.apache.bookkeeper.client.LedgerRecoveryOp.RecoveryReadOp
 
getLedgerMetadata() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
getLedgerMetadata() - Method in class org.apache.bookkeeper.client.ReadOpBase
 
getLedgerMetadata(long) - Method in interface org.apache.bookkeeper.client.api.BookKeeper
Get ledger metadata of a given ledger id.
getLedgerMetadata(long) - Method in class org.apache.bookkeeper.client.BookKeeper
 
getLedgerMetadata(LedgerHandle) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
getLedgerMetadataFormatVersion() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get Ledger metadata format version.
getLedgerMetadataRocksdbConf() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get ledger metadata rocksdb conf.
GetLedgerMetaService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper get ledger metadata related http request.
GetLedgerMetaService(ServerConfiguration, LedgerManagerFactory) - Constructor for class org.apache.bookkeeper.server.http.service.GetLedgerMetaService
 
getLedgerName(long) - Static method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
getLedgerParentNodeRegex() - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
regex expression for name of top level parent znode for ledgers (in HierarchicalLedgerManager) or znode of a ledger (in FlatLedgerManager).
getLedgerParentNodeRegex() - Method in class org.apache.bookkeeper.meta.FlatLedgerManager
 
getLedgerParentNodeRegex() - Method in class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
getLedgerParentNodeRegex() - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManager
 
getLedgerParentNodeRegex() - Method in class org.apache.bookkeeper.meta.LongHierarchicalLedgerManager
 
getLedgerPath(long) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
Get the znode path that is used to store ledger metadata.
getLedgerPath(long) - Method in class org.apache.bookkeeper.meta.FlatLedgerManager
 
getLedgerPath(long) - Method in class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
getLedgerPath(long) - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManager
 
getLedgerPath(long) - Method in class org.apache.bookkeeper.meta.LongHierarchicalLedgerManager
 
getLedgerRanges(long) - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
getLedgerRanges(long) - Method in class org.apache.bookkeeper.meta.FlatLedgerManager
 
getLedgerRanges(long) - Method in class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
getLedgerRanges(long) - Method in interface org.apache.bookkeeper.meta.LedgerManager
Loop to scan a range of metadata from metadata storage.
getLedgerRanges(long) - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManager
 
getLedgerRanges(long) - Method in class org.apache.bookkeeper.meta.LongHierarchicalLedgerManager
 
getLedgerRanges(long) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
getLedgerRanges(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
getLedgers() - Method in class org.apache.bookkeeper.meta.LedgerManager.LedgerRange
 
getLedgersContainBookies(Set<BookieId>) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
getLedgersCountGauge() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndexStats
 
getLedgersMap() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.BufferedLogChannel
 
getLedgersMap() - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
getLedgersNotAdheringToPlacementPolicyGuageValue() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getLedgersSoftlyAdheringToPlacementPolicyGuageValue() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getLedgerStorage() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
getLedgerStorage() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getLedgerStorage() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
getLedgerStorageClass() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
getLedgerStorageList() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getLedgerToRereplicate() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Acquire a underreplicated ledger for rereplication.
getLedgerToRereplicate() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
getLedgerToRereplicate() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getLedgerUnreplicationInfo(long) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Get the UnderreplicatedLedger info if this ledger is marked underreplicated otherwise it returns null.
getLedgerUnreplicationInfo(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
getLedgerUnreplicationInfo(long) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getLength() - Method in class org.apache.bookkeeper.bookie.EntryKeyValue
 
getLength() - Method in interface org.apache.bookkeeper.client.api.LedgerEntry
The length of the entry, that is the size of the content expressed in bytes.
getLength() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the length of this ledger.
getLength() - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Returns the length of the data written in this ledger so much, in bytes.
getLength() - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
The length of the entry, that is the size of the content expressed in bytes.
getLength() - Method in class org.apache.bookkeeper.client.LedgerEntry
 
getLength() - Method in class org.apache.bookkeeper.client.LedgerHandle
Returns the length of the ledger in bytes.
getLength() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getLength() - Method in class org.apache.bookkeeper.proto.checksum.DigestManager.RecoveryData
 
getLength() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int64 length = 3;
getLength() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
required int64 length = 3;
getLength() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
required int64 length = 3;
getLEP() - Method in interface org.apache.bookkeeper.bookie.LedgerCache.PageEntries
 
getLevel() - Method in interface org.apache.bookkeeper.net.Node
 
getLevel() - Method in class org.apache.bookkeeper.net.NodeBase
 
getLf() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
getLh() - Method in class org.apache.bookkeeper.client.SyncCounter
 
getLifecycleComponentStack() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getLimbo() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
optional bool limbo = 5;
getLimbo() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
optional bool limbo = 5;
getLimbo() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
optional bool limbo = 5;
getLimit() - Method in class org.apache.bookkeeper.common.util.Backoff.Constant
 
getLimit() - Method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
getLimit() - Method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
getLimitStatsLogging() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Return the flag indicating whether to limit stats logging.
getLinkCount(File) - Static method in class org.apache.bookkeeper.util.HardLink
Retrieves the number of links to the specified file.
getLinkCountCommand - Static variable in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
getLinkMultArgLength(File, String[], File) - Static method in class org.apache.bookkeeper.util.HardLink
Calculate the nominal length of all contributors to the total commandstring length, including fixed overhead of the OS-dependent command.
getLinkMultArgLength(File, String[], File) - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGUnix
 
getLinkMultArgLength(File, String[], File) - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
getList(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getList(String, List<?>) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getList(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting from the configuration conf as a Class value.
getListeners() - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Get all dir listeners.
getListeningInterface() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the network interface that the bookie should listen for connections on.
getListOfEntriesOfLedger(long) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
getListOfEntriesOfLedger(long) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getListOfEntriesOfLedger(long) - Method in class org.apache.bookkeeper.bookie.EntryMemTable
 
getListOfEntriesOfLedger(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
getListOfEntriesOfLedger(long) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
getListOfEntriesOfLedger(long) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
getListOfEntriesOfLedger(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Returns the primitive long iterator for entries of the ledger, stored in this LedgerStorage.
getListOfEntriesOfLedger(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getListOfEntriesOfLedger(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getListOfEntriesOfLedger(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getListOfEntriesOfLedger(long, BookkeeperInternalCallbacks.GetListOfEntriesOfLedgerCallback) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
getListOfEntriesOfLedger(BookieId, long) - Method in interface org.apache.bookkeeper.proto.BookieClient
Makes async request for getting list of entries of ledger from a bookie and returns Future for the result.
getListOfEntriesOfLedger(BookieId, long) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
getListOfEntriesOfLedgerComplete(int, long, AvailabilityOfEntriesOfLedger) - Method in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.FutureGetListOfEntriesOfLedger
 
getListOfEntriesOfLedgerComplete(int, long, AvailabilityOfEntriesOfLedger) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.GetListOfEntriesOfLedgerCallback
 
GetListOfEntriesOfLedgerCompletion(PerChannelBookieClient.CompletionKey, BookkeeperInternalCallbacks.GetListOfEntriesOfLedgerCallback, long) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.GetListOfEntriesOfLedgerCompletion
 
GetListOfEntriesOfLedgerProcessorV3 - Class in org.apache.bookkeeper.proto
A processor class for v3 entries of a ledger packets.
GetListOfEntriesOfLedgerProcessorV3(BookkeeperProtocol.Request, BookieRequestHandler, BookieRequestProcessor) - Constructor for class org.apache.bookkeeper.proto.GetListOfEntriesOfLedgerProcessorV3
 
getListOfEntriesOfLedgerRequest - Variable in class org.apache.bookkeeper.proto.GetListOfEntriesOfLedgerProcessorV3
 
GETLISTOFENTRIESOFLEDGERREQUEST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
getListOfEntriesOfLedgerRequestStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
GETLISTOFENTRIESOFLEDGERRESPONSE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
getListOfEntriesOfLedgerStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
getLocalAddress() - Method in class org.apache.bookkeeper.proto.BookieServer
 
getLocalBookies(String, int, int, boolean, ServerConfiguration) - Static method in class org.apache.bookkeeper.util.LocalBookKeeper
 
getLocalRegion(BookieNode) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
getLocalScrubPeriod() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get local scrub interval.
getLocalScrubRateLimit() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get local scrub rate limit (entries/second).
getLocation() - Method in class org.apache.bookkeeper.bookie.EntryLocation
 
getLocation(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getLocation(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
getLock(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
getLockData() - Static method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getLockReleaseOfFailedLedgerGracePeriod() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the grace period, in milliseconds, which the replication worker has to wait before releasing the lock after it failed to replicate a ledger.
getLogChannel() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger.BufferedLogChannelWithDirInfo
 
getLogFile() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.BufferedLogChannel
 
getLogFileId() - Method in class org.apache.bookkeeper.bookie.LogMark
 
getLogFileOffset() - Method in class org.apache.bookkeeper.bookie.LogMark
 
getLogId() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.BufferedLogChannel
 
getLogin() - Method in interface org.apache.bookkeeper.sasl.JAASCredentialsContainer
 
getLogin() - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
getLogin() - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
getLoginContextName() - Method in interface org.apache.bookkeeper.sasl.JAASCredentialsContainer
 
getLoginContextName() - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
getLoginContextName() - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
getLong() - Method in class com.scurrilous.circe.crc.JavaCrc32
 
getLong() - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
getLong() - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
getLong() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
getLong() - Method in interface com.scurrilous.circe.StatefulHash
Returns the first eight bytes of the output of this hash function as a little-endian long.
getLong(byte[], int) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.ArrayUtil
 
getLong(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getLong(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getLong(String, long) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getLong(String, Long) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getLong(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting from the configuration conf as a Long value.
getLongHierarchicalLedgerPath(long) - Static method in class org.apache.bookkeeper.util.StringUtils
Get the long hierarchical ledger path according to the ledger id.
getLongLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getLongPollPreWaitStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getLongPollReadRequestStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getLongPollReadStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getLongPollThreadPool() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
The threadpool used to execute all long poll requests issued to this server after they are done waiting.
getLongPollWaitStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getLongVariableOrDefault(ServerConfiguration, String, long) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getLongVersion() - Method in class org.apache.bookkeeper.versioning.LongVersion
 
getLookupEntryLocationStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndexStats
 
getLostBookieRecoveryDelay() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Returns the current LostBookieRecoveryDelay value (in seconds) in Zookeeper.
getLostBookieRecoveryDelay() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get how long to delay the recovery of ledgers of a lost bookie.
getLostBookieRecoveryDelay() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Getter for the lostBookieRecoveryDelay.
getLostBookieRecoveryDelay() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
getLostBookieRecoveryDelay() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getLostBookieRecoveryDelayBeforeChange() - Method in class org.apache.bookkeeper.replication.Auditor
 
getMacCodeLength() - Method in class org.apache.bookkeeper.proto.checksum.CRC32CDigestManager
 
getMacCodeLength() - Method in class org.apache.bookkeeper.proto.checksum.CRC32DigestManager
 
getMacCodeLength() - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
getMacCodeLength() - Method in class org.apache.bookkeeper.proto.checksum.DummyDigestManager
 
getMacCodeLength() - Method in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
getMainWorkerPool() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getMainWorkerPool() - Method in interface org.apache.bookkeeper.client.ClientContext
 
getMajorCompactionCounter() - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
getMajorCompactionCounter() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getMajorCompactionInterval() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get interval to run major compaction, in seconds.
getMajorCompactionMaxTimeMillis() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the maximum milliseconds to run major compaction.
getMajorCompactionThreshold() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get threshold of major compaction.
getManagerFactoryClass() - Method in class org.apache.bookkeeper.meta.LedgerLayout
 
getManagerVersion() - Method in class org.apache.bookkeeper.meta.LedgerLayout
 
getMasterKey() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
getMasterKey() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bytes masterKey = 3;
getMasterKey() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
required bytes masterKey = 3;
getMasterKey() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
required bytes masterKey = 3;
getMasterKey() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
getMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required bytes masterKey = 3;
getMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
required bytes masterKey = 3;
getMasterKey() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
required bytes masterKey = 3;
getMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used while fencing a ledger.
getMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
Used while fencing a ledger.
getMasterKey() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
Used while fencing a ledger.
getMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required bytes masterKey = 3;
getMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
required bytes masterKey = 3;
getMasterKey() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequestOrBuilder
required bytes masterKey = 3;
getMasterKeyHex() - Method in class org.apache.bookkeeper.bookie.LedgerCache.LedgerIndexMetadata
 
getMax() - Method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
 
getMax() - Method in class org.apache.bookkeeper.stats.codahale.FastSnapshot
 
getMaxAddsInProgress() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getMaxAddsInProgressLimit() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get max number of adds in progress.
getMaxAllowedCmdArgLength() - Static method in class org.apache.bookkeeper.util.HardLink
Return this private value for use by unit tests.
getMaxAllowedCmdArgLength() - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGUnix
 
getMaxAllowedCmdArgLength() - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
getMaxAllowedEnsembleChanges() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the max allowed ensemble change number.
getMaxBackupJournals() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Max number of older journal files kept.
getMaxBatchReadSize() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the max batch read size.
getMaxCount() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadRequest
 
getMaximumNumberOfActiveEntryLogs() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
getMaxJournalSizeMB() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Max journal file size.
getMaxLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
Piggyback LAC
getMaxLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
Piggyback LAC
getMaxLAC() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
Piggyback LAC
getMaxLatency() - Method in class org.apache.bookkeeper.proto.BKStats.OpStatData
 
getMaxMs() - Method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
getMaxMs() - Method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
getMaxOperationNumbersInSingleRocksDBBatch() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the max operation numbers in a single rocksdb write batch.
getMaxPendingAddRequestPerThread() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
If add workers threads are enabled, limit the number of pending requests, to avoid the executor queue to grow indefinitely (default: 10000 entries).
getMaxPendingReadRequestPerThread() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
If read workers threads are enabled, limit the number of pending requests, to avoid the executor queue to grow indefinitely (default: 10000 entries).
getMaxPossibleEntry() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getMaxPriority(EnumSet<HashSupport>) - Static method in enum com.scurrilous.circe.HashSupport
Returns the priority of the highest-priority hash algorithm support flag in the given set of flags.
getMaxReadsInProgress() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getMaxReadsInProgressLimit() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get max number of reads in progress.
getMaxSize() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadRequest
 
getMaxSpeculativeReadLACTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the maximum interval between successive speculative read last add confirmed and entry requests.
getMaxSpeculativeReadTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the max speculative read timeout.
getMean() - Method in class org.apache.bookkeeper.stats.codahale.FastSnapshot
 
getMeanRate() - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
 
getMedium(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getMediumLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getMemoryUsage() - Method in class org.apache.bookkeeper.bookie.Journal
 
getMessage(int) - Method in exception org.apache.bookkeeper.bookie.BookieException
 
getMessage(int) - Static method in exception org.apache.bookkeeper.client.api.BKException
Describe an error code.
getMetadata() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult
 
getMetadataClientDriver() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getMetadataFormatVersion() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Get the format version which should be used to serialize the metadata.
getMetadataFormatVersion() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getMetadataServiceUri() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get metadata service uri.
getMetadataServiceUriUnchecked() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get metadata service uri.
getMetastoreImplClass() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get metastore implementation class.
getMetastoreMaxEntriesPerScan() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get max entries per scan in metastore.
getMetrics() - Method in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
getMin() - Method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
 
getMin() - Method in class org.apache.bookkeeper.stats.codahale.FastSnapshot
 
getMinLatency() - Method in class org.apache.bookkeeper.proto.BKStats.OpStatData
 
getMinNumRacksPerWriteQuorum() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the minimum number of racks per write quorum.
getMinNumZonesPerWriteQuorum() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the minimum number of zones per write quorum in ZoneAwarePlacementPolicy.
getMinorCompactionCounter() - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
getMinorCompactionCounter() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getMinorCompactionInterval() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get interval to run minor compaction, in seconds.
getMinorCompactionMaxTimeMillis() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the maximum milliseconds to run minor compaction.
getMinorCompactionThreshold() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get threshold of minor compaction.
getMinUsableSizeForEntryLogCreation() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Gets the minimum safe usable size to be available in ledger directory for Bookie to create entry log files.
getMinUsableSizeForHighPriorityWrites() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Gets the minimum safe usable size to be available in ledger directory for Bookie to accept high priority writes.
getMinUsableSizeForIndexFileCreation() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Gets the minimum safe Usable size to be available in index directory for Bookie to create Index File while replaying journal at the time of Bookie Start in Readonly Mode (in bytes).
getModInitialDelay() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
when number of ledger's Dir are more than 1,the same of GarbageCollectorThread will do the same thing, Especially 1) deleting ledger, then SyncThread will be timed to do rocksDB compact 2) compact: entry, cost cpu.
getMs() - Method in class org.apache.bookkeeper.common.util.Backoff.Constant
 
getMultiplier() - Method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
getMutableProperties() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
Deprecated.
getName() - Method in class org.apache.bookkeeper.auth.BookKeeperPrincipal
 
getName() - Method in class org.apache.bookkeeper.common.component.AbstractComponent
 
getName() - Method in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
getName() - Method in interface org.apache.bookkeeper.common.component.LifecycleComponent
 
getName() - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
getName() - Method in class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
getName() - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
getName() - Method in interface org.apache.bookkeeper.metastore.MetaStore
Return the name of the plugin.
getName() - Method in interface org.apache.bookkeeper.metastore.MetastoreTable
Get table name.
getName() - Method in interface org.apache.bookkeeper.net.Node
 
getName() - Method in class org.apache.bookkeeper.net.NodeBase
 
getName() - Method in class org.apache.bookkeeper.stats.otel.ScopeContext
 
getNettyMaxFrameSizeBytes() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the maximum netty frame size in bytes.
getNetworkLocation() - Method in interface org.apache.bookkeeper.net.Node
 
getNetworkLocation() - Method in class org.apache.bookkeeper.net.NodeBase
 
getNetworkLocation(int) - Method in interface org.apache.bookkeeper.net.Node
 
getNetworkLocation(int) - Method in class org.apache.bookkeeper.net.NodeBase
 
getNetworkLocations(Set<Node>) - Static method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
getNetworkTopologyStabilizePeriodSeconds() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the network topology stabilize period in seconds.
getNextEnsembleChange(LedgerMetadata, long) - Static method in class org.apache.bookkeeper.client.LedgerMetadataUtils
the entry id greater than the given entry-id at which the next ensemble change takes place.
getNextEntries(int) - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
getNextRandom() - Method in class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
getNextRandom() - Method in interface org.apache.bookkeeper.client.WeightedRandomSelection
 
getNextRandom() - Method in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
getNextRandom(Collection<T>) - Method in class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
getNextRandom(Collection<T>) - Method in interface org.apache.bookkeeper.client.WeightedRandomSelection
 
getNextRandom(Collection<T>) - Method in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
getNode(String) - Method in interface org.apache.bookkeeper.net.NetworkTopology
Retrieve a node from the network topology.
getNode(String) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Given a string representation of a node, return its reference.
getNode(String) - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
getNodeForNetworkLocation(Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Return a reference to the node given its string representation.
getNumActiveLedgers() - Method in class org.apache.bookkeeper.bookie.ScanAndCompareGarbageCollector
 
getNumAddWorkerThreads() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of threads that should handle write requests.
getNumber() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
 
getNumber() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
 
getNumber() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
 
getNumber() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
 
getNumber() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
 
getNumber() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
 
getNumber() - Method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
 
getNumber() - Method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
 
getNumberOfBuckets() - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
Returns the number of response time buckets used by this timer.
getNumBookieAuditsDelayed() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumBookies() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the count of unique bookies that own part of this ledger by going over all the fragments of the ledger.
getNumBookiesPerLedger() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumChannelsPerBookie() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get num channels per bookie.
getNumComponents() - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
getNumDelayedBookieAuditsCancelled() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumEntries() - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.RecoveryStats
 
getNumFailedEvents() - Method in class org.apache.bookkeeper.stats.OpStatsData
 
getNumFailedOps() - Method in class org.apache.bookkeeper.proto.BKStats.OpStatData
 
getNumFragments() - Method in class org.apache.bookkeeper.client.LedgerHandle
Get the number of fragments that makeup this ledger.
getNumFragmentsPerLedger() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumHighPriorityWorkerThreads() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of threads that should be used for high priority requests (i.e.
getNumIOThreads() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the number of IO threads.
getNumJournalCallbackThreads() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Deprecated.
getNumLedgersChecked() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumLedgersHavingLessThanAQReplicasOfAnEntry() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumLedgersHavingLessThanAQReplicasOfAnEntryGuageValue() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumLedgersHavingLessThanWQReplicasOfAnEntry() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumLedgersHavingLessThanWQReplicasOfAnEntryGuageValue() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumLedgersHavingNoReplicaOfAnEntry() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumLedgersHavingNoReplicaOfAnEntryGuageValue() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumLedgersNotAdheringToPlacementPolicy() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumLedgersSoftlyAdheringToPlacementPolicy() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumListeners() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
getNumLongPollWorkerThreads() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of threads that should handle long poll requests.
getNumOfBytesInWriteBuffer() - Method in class org.apache.bookkeeper.bookie.BufferedChannel
 
getNumOfChildren() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
 
getNumOfClosedLedgersAuditedInPlacementPolicyCheck() - Method in class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
getNumOfLeaves() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
 
getNumOfLeaves() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Get number of leaves.
getNumOfLedgersFoundNotAdheringInPlacementPolicyCheck() - Method in class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
getNumOfLedgersFoundSoftlyAdheringInPlacementPolicyCheck() - Method in class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
getNumOfMemtableFlushThreads() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
getNumOfRacks() - Method in interface org.apache.bookkeeper.net.NetworkTopology
Returns number of racks in the network topology.
getNumOfRacks() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
 
getNumOfRacks() - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
getNumOfURLedgersElapsedRecoveryGracePeriod() - Method in class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
getNumOfURLedgersElapsedRecoveryGracePeriodGuageValue() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumPendingCompletionRequests() - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
getNumPendingCompletionRequests() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
getNumPendingCompletionRequests() - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientPool
Get the number of pending completion requests in the channel.
getNumPendingRequests(BookieId, long) - Method in interface org.apache.bookkeeper.proto.BookieClient
Get the number of outstanding requests on the channel used to connect to a bookie at address for a ledger with ledgerId.
getNumPendingRequests(BookieId, long) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
getNumReadWorkerThreads() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of threads that should handle read requests.
getNumResponsesPending() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedOp
 
getNumSkippingCheckTaskTimes() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumSuccessfulEvents() - Method in class org.apache.bookkeeper.stats.OpStatsData
 
getNumSuccessOps() - Method in class org.apache.bookkeeper.proto.BKStats.OpStatData
 
getNumUnderReplicatedLedger() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumUnderreplicatedLedgersElapsedRecoveryGracePeriod() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getNumVal() - Method in enum org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementPolicyAdherence
 
getNumWatchers() - Method in class org.apache.bookkeeper.common.util.Watchable
 
getNumWorkerThreads() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the number of worker threads.
getOffset() - Method in class org.apache.bookkeeper.bookie.EntryKeyValue
 
getOffset() - Method in class org.apache.bookkeeper.bookie.SkipListArena.MemorySlice
 
getOffset(int) - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getOneMinuteRate() - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
 
getOnResponseTimeout() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
getOpCode() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
getOpCode() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
getOpCode(int) - Static method in class org.apache.bookkeeper.proto.BookieProtocol.PacketHeader
 
getOpenFileLimit() - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
getOpenFileLimit() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get open file limit.
getOpenLedgerRereplicationGracePeriod() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the grace period which the rereplication worker to wait before fencing and rereplicating a ledger fragment which is still being written to, on bookie failure.
getOpenOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getOpenOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getOpenReaderCounter() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLoggerStats
 
getOperation() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required .OperationType operation = 2;
getOperation() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
required .OperationType operation = 2;
getOperation() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeaderOrBuilder
required .OperationType operation = 2;
getOpportunisticStriping() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Whether to allow opportunistic striping.
getOpStats(int) - Method in class org.apache.bookkeeper.proto.BKStats
Stats of operations.
getOpStatsLogger(String) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
 
getOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
 
getOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
 
getOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.codahale.FastCodahaleStatsLogger
 
getOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.NullStatsLogger
 
getOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
getOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
getOpStatsLogger(String) - Method in interface org.apache.bookkeeper.stats.StatsLogger
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.AutoRecoveryCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieFormatCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieInfoCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieSanityTestCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.CheckDbLedgersIndexCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ClusterInfoCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ConvertToDbStorageCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ConvertToInterleavedStorageCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.DecommissionBookieCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.DeleteLedgerCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.EndpointInfoCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ForceAuditorChecksCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.HelpCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.InitBookieCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.InitNewCluster
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.LastMarkCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.LedgerCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.LedgerMetadataCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListActiveLedgersCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListBookiesCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListDiskFilesCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListLedgersCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListUnderreplicatedCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.LocalConsistencyCheck
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.LostBookieRecoveryDelayCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.MetaFormatCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.NukeExistingCluster
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.QueryAutoRecoveryStatusCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadJournalCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLedgerEntriesCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLogCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLogMetadataCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgerLocationsIndexCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgersIndexCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.RecoverCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.RegenerateInterleavedStorageIndexFile
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.SimpleTestCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.TriggerAuditCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateBookieInLedgerCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateCookieCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateLedgerCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.WhatIsInstanceId
 
getOptions() - Method in class org.apache.bookkeeper.bookie.BookieShell.WhoIsAuditorCmd
 
getOptions() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
getOrdinal() - Method in class org.apache.bookkeeper.stats.ThreadRegistry.ThreadPoolThread
 
getOUMap(X509Certificate) - Static method in class org.apache.bookkeeper.util.CertUtils
 
getOUMapFromOUString(String) - Static method in class org.apache.bookkeeper.util.CertUtils
 
getOUString(X509Certificate) - Static method in class org.apache.bookkeeper.util.CertUtils
 
getOUStringFromSubject(String) - Static method in class org.apache.bookkeeper.util.CertUtils
 
getOutput() - Method in class org.apache.bookkeeper.util.Shell.ShellCommandExecutor
Get the output of the shell command.
getP10Latency() - Method in class org.apache.bookkeeper.stats.OpStatsData
 
getP50Latency() - Method in class org.apache.bookkeeper.stats.OpStatsData
 
getP90Latency() - Method in class org.apache.bookkeeper.stats.OpStatsData
 
getP9999Latency() - Method in class org.apache.bookkeeper.stats.OpStatsData
 
getP999Latency() - Method in class org.apache.bookkeeper.stats.OpStatsData
 
getP99Latency() - Method in class org.apache.bookkeeper.stats.OpStatsData
 
getPageLimit() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get limitation number of index pages in ledger cache.
getPageSize() - Method in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
getPageSize() - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
getPageSize() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get page size.
getPageToWrite() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getParent() - Method in interface org.apache.bookkeeper.net.Node
 
getParent() - Method in class org.apache.bookkeeper.net.NodeBase
 
getParentZnodePath(String, long) - Static method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getParserForType() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
getParserForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
getParserForType() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
getPassword() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Get the password for the ledger.
getPassword() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getPassword() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional bytes password = 8;
getPassword() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional bytes password = 8;
getPassword() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional bytes password = 8;
getPath(Node) - Static method in class org.apache.bookkeeper.net.NodeBase
Get the path of a node.
getPayload() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required bytes payload = 2;
getPayload() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
required bytes payload = 2;
getPayload() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessageOrBuilder
required bytes payload = 2;
getPCBCTimeoutTimerNumTicks() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Deprecated.
getPCBCTimeoutTimerTickDurationMs() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Deprecated.
getPendingAddOps() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
getPendingGetFileInfoCounter() - Method in class org.apache.bookkeeper.bookie.stats.IndexPersistenceMgrStats
 
getPermittedStartupUsers() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get array of users specified in this property.
getPersistEntryBeyondInMem(long, long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
getPlacementPolicy() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getPlacementPolicy() - Method in interface org.apache.bookkeeper.client.ClientContext
 
getPlacementPolicyCheckCTime() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Getter for the PlacementPolicyCheck last executed ctime.
getPlacementPolicyCheckCTime() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
getPlacementPolicyCheckCTime() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getPlacementPolicyCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
optional int64 placementPolicyCheckCTime = 1;
getPlacementPolicyCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
optional int64 placementPolicyCheckCTime = 1;
getPlacementPolicyCheckCTime() - Method in interface org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormatOrBuilder
optional int64 placementPolicyCheckCTime = 1;
getPlacementPolicyCheckTime() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getPluginName() - Method in interface org.apache.bookkeeper.auth.BookieAuthProvider.Factory
Get Auth provider plugin name.
getPluginName() - Method in interface org.apache.bookkeeper.auth.ClientAuthProvider.Factory
Get Auth provider plugin name.
getPluginName() - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
getPluginName() - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
getPluginName() - Method in class org.apache.bookkeeper.tls.BookieAuthZFactory
 
getPort() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher.EndpointInfo
 
getPort() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
getPort() - Method in class org.apache.bookkeeper.net.BookieSocketAddress
 
getPort() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required int32 port = 2;
getPort() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required int32 port = 2;
getPort() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required int32 port = 2;
getPreallocatedLogId() - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
getPreallocationFuture() - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
get the preallocation for tests.
getPreserveMdcForTaskExecution() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Whether to preserve MDC for tasks in Executor.
getPreviousAllocatedEntryLogId() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
getPreviousLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used for waiting on last add confirmed update
getPreviousLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
Used for waiting on last add confirmed update
getPreviousLAC() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
Used for waiting on last add confirmed update
getPreviousLAC() - Method in class org.apache.bookkeeper.proto.LongPollReadEntryProcessorV3
 
getPreviousLAC() - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
getPrincipal() - Method in interface org.apache.bookkeeper.sasl.JAASCredentialsContainer
 
getPrincipal() - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
getPrincipal() - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
getPrincipal(String) - Static method in class org.apache.bookkeeper.sasl.SaslConstants
 
getPriority() - Method in enum com.scurrilous.circe.HashSupport
Returns the relative priority of a hash algorithm support flag, which is an indicator of its performance and flexibility.
getPriority() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
optional uint32 priority = 4 [default = 0];
getPriority() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
optional uint32 priority = 4 [default = 0];
getPriority() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeaderOrBuilder
optional uint32 priority = 4 [default = 0];
getProcess() - Method in class org.apache.bookkeeper.util.Shell
Get the current sub-process executing the given command.
getProperties() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher
 
getProperties() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo
Unmodifiable map with bookie wide information.
getProperties() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
Deprecated.
getProperties() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
Deprecated.
getProperties() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
Deprecated.
getProperties(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getPropertiesCount() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
getPropertiesCount() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
getPropertiesCount() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
map<string, string> properties = 7;
getPropertiesMap() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
map<string, string> properties = 7;
getPropertiesMap() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
map<string, string> properties = 7;
getPropertiesMap() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
map<string, string> properties = 7;
getPropertiesOrDefault(String, String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
map<string, string> properties = 7;
getPropertiesOrDefault(String, String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
map<string, string> properties = 7;
getPropertiesOrDefault(String, String) - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
map<string, string> properties = 7;
getPropertiesOrThrow(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
map<string, string> properties = 7;
getPropertiesOrThrow(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
map<string, string> properties = 7;
getPropertiesOrThrow(String) - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormatOrBuilder
map<string, string> properties = 7;
getProperty(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getProperty(String) - Method in class org.apache.bookkeeper.common.conf.ConcurrentConfiguration
 
getProtocol() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher.EndpointInfo
 
getProtocol() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
getProtocol() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string protocol = 4;
getProtocol() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required string protocol = 4;
getProtocol() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required string protocol = 4;
getProtocolBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string protocol = 4;
getProtocolBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required string protocol = 4;
getProtocolBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required string protocol = 4;
getProtocolPrincipals() - Method in interface org.apache.bookkeeper.proto.ConnectionPeer
Additional principals bound to the connection, like TLS certificates.
getProtocolVersion() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
getProtocolVersion() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
getProvider() - Static method in class org.apache.bookkeeper.tls.TLSContextFactory
Get Bouncy Castle provider, and call Security.addProvider(provider) if success.
getPutEntryStats() - Method in class org.apache.bookkeeper.bookie.stats.EntryMemTableStats
 
getQuantileValue(boolean, double) - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
getQueuedTasksCount() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
getQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int32 quorumSize = 1;
getQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
required int32 quorumSize = 1;
getQuorumSize() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
required int32 quorumSize = 1;
getRack(String) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Given a string representation of a rack for a specific network location.
getRate() - Method in class org.apache.bookkeeper.client.LedgerFragmentReplicator.Throttler
 
getRate(int) - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
Returns the average per-second rate of events this timer has seen.
getrc() - Method in class org.apache.bookkeeper.client.SyncCounter
 
getRc() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
Get result code of this entry.
getRc() - Method in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
Get result code of this entry.
getRC() - Method in class org.apache.bookkeeper.client.LedgerHandle.LastConfirmedCtx
 
getReadable(long) - Method in class org.apache.bookkeeper.server.http.service.ListBookieInfoService
 
getReadable(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.InfoCommand
 
getReadAheadBatchCountStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadAheadBatchSizeStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadAheadTime() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadBlockStats() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLoggerStats
 
getReadBufferBytes() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of bytes we should use as capacity for org.apache.bookkeeper.bookie.BufferedReadChannel.
getReadBytes() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getReadBytesStats() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getReadCacheCountGauge() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadCacheHitCounter() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadCacheMissCounter() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadCacheSizeGauge() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadEntryBlockedStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadEntryRejectedCounter() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadEntrySchedulingDelayStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadEntryStats() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getReadEntryStats() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLoggerStats
 
getReadEntryStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadEntryStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadEntryTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the timeout for read entry.
getReadFileInfoCacheSizeGauge() - Method in class org.apache.bookkeeper.bookie.stats.IndexPersistenceMgrStats
 
getReadFromEntryLogTime() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadFromLocationIndexTime() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getReadLacAndEntryOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getReadLacAndEntryOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getReadLacAndEntryRespLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getReadLacAndEntryRespLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getReadLacOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getReadLacOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getReadLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ReadLacRequest readLacRequest = 104;
getReadLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .ReadLacRequest readLacRequest = 104;
getReadLacRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .ReadLacRequest readLacRequest = 104;
getReadLacRequestBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ReadLacRequest readLacRequest = 104;
getReadLacRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ReadLacRequest readLacRequest = 104;
getReadLacRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .ReadLacRequest readLacRequest = 104;
getReadLacRequestOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .ReadLacRequest readLacRequest = 104;
getReadLacRequestStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ReadLacResponse readLacResponse = 104;
getReadLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .ReadLacResponse readLacResponse = 104;
getReadLacResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .ReadLacResponse readLacResponse = 104;
getReadLacResponseBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ReadLacResponse readLacResponse = 104;
getReadLacResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ReadLacResponse readLacResponse = 104;
getReadLacResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .ReadLacResponse readLacResponse = 104;
getReadLacResponseOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .ReadLacResponse readLacResponse = 104;
getReadLacStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadLastEntryNoEntryErrorCounter() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadOnlyBookies() - Method in interface org.apache.bookkeeper.client.BookieWatcher
 
getReadOnlyBookies() - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
 
getReadOnlyBookies() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Get a list of readonly bookies synchronously.
getReadOnlyBookies() - Method in interface org.apache.bookkeeper.discover.RegistrationClient
Get the list of readonly bookie identifiers.
getReadOnlyBookies() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
getReadonlyBookiesCount() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
getReadonlyBookiesCount() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
getReadOnlyHandle(long) - Method in interface org.apache.bookkeeper.bookie.HandleFactory
 
getReadOnlyHandle(long) - Method in class org.apache.bookkeeper.bookie.HandleFactoryImpl
 
getReadOpDmCounter() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getReadOpDmCounter() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getReadOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getReadOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getReadRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
Requests
getReadRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
Requests
getReadRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
Requests
getReadRequestBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
Requests
getReadRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
Requests
getReadRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
Requests
getReadRequestOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
Requests
getReadRequestStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
Response
getReadResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
Response
getReadResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
Response
getReadResponse() - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
getReadResponseBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
Response
getReadResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
Response
getReadResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
Response
getReadResponseOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
Response
getReadsBlocked() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadsInProgress() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getReadsSemaphore() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
getReadThreadPool() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
The threadpool used to execute all read entry requests issued to this server.
getReadTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
getReadWriteBookieInfo() - Method in class org.apache.bookkeeper.client.BookieInfoReader
Performs scan described by instanceState using the cached bookie information in bookieInfoMap.
getReclaimedSpaceViaCompaction() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getReclaimedSpaceViaDeletes() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getReclaimFailedToDelete() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getRecoverAddCountLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getRecoverAddCountLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getRecoverOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getRecoverOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getRecoverReadCountLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getRecoverReadCountLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getRecoveryAddEntryStats() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getRecoveryReadBatchSize() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get Recovery Read Batch Size.
getRecvByteBufAllocatorSizeInitial() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get Recv ByteBuf allocator initial buf size.
getRecvByteBufAllocatorSizeMax() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get Recv ByteBuf allocator max buf size.
getRecvByteBufAllocatorSizeMin() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get Recv ByteBuf allocator min buf size.
getRefCount() - Method in class org.apache.bookkeeper.bookie.FileInfoBackingCache.CachedFileInfo
 
getRegion(BookieId) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
getRegistrationClient() - Method in class org.apache.bookkeeper.client.DefaultBookieAddressResolver
 
getRegistrationClient() - Method in interface org.apache.bookkeeper.meta.MetadataClientDriver
Return the registration client used for discovering registered bookies.
getRegistrationClient() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
getRegistrationClientClass() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Deprecated.
since 4.7.0
getRegistrationManager() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getRegistrationManagerClass() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Deprecated.
since 4.7.0, in favor of using AbstractConfiguration.getMetadataServiceUri()
getRejectedTasksCount() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
getRejectedWriteRequests() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getRemainingSize() - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
getRemoteAddr() - Method in interface org.apache.bookkeeper.proto.ConnectionPeer
Address from which originated the connection.
getReorderThresholdPendingRequests() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the threshold for the number of pending requests beyond which to reorder reads.
getReplica(int) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
repeated string replica = 1;
getReplica(int) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
repeated string replica = 1;
getReplica(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormatOrBuilder
repeated string replica = 1;
getReplicaBytes(int) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
repeated string replica = 1;
getReplicaBytes(int) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
repeated string replica = 1;
getReplicaBytes(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormatOrBuilder
repeated string replica = 1;
getReplicaCount() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
repeated string replica = 1;
getReplicaCount() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
repeated string replica = 1;
getReplicaCount() - Method in interface org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormatOrBuilder
repeated string replica = 1;
getReplicaList() - Method in class org.apache.bookkeeper.meta.UnderreplicatedLedger
 
getReplicaList() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
repeated string replica = 1;
getReplicaList() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
repeated string replica = 1;
getReplicaList() - Method in interface org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormatOrBuilder
repeated string replica = 1;
getReplicasCheckCTime() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Getter for the ReplicasCheck last executed ctime.
getReplicasCheckCTime() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
getReplicasCheckCTime() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getReplicasCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
optional int64 replicasCheckCTime = 1;
getReplicasCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
optional int64 replicasCheckCTime = 1;
getReplicasCheckCTime() - Method in interface org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormatOrBuilder
optional int64 replicasCheckCTime = 1;
getReplicasCheckTime() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getReplicateType() - Method in class org.apache.bookkeeper.client.LedgerFragment
 
getReplicationRateByBytes() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the bytes rate of re-replication.
getReplicationWorker() - Method in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
getReplicationWorkerIdRereplicatingLedger(long) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
If a replicationworker has acquired lock on an underreplicated ledger, then getReplicationWorkerIdRereplicatingLedger should return ReplicationWorkerId (BookieId) of the ReplicationWorker that is holding lock.
getReplicationWorkerIdRereplicatingLedger(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
getReplicationWorkerIdRereplicatingLedger(long) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getRequestContext(int) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
getRequestContext(int) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
to pass MDC context
getRequestContext(int) - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
to pass MDC context
getRequestContextBuilder(int) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
getRequestContextBuilderList() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
getRequestContextCount() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
getRequestContextCount() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
to pass MDC context
getRequestContextCount() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
to pass MDC context
getRequestContextList() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
getRequestContextList() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
to pass MDC context
getRequestContextList() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
to pass MDC context
getRequestContextOrBuilder(int) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
getRequestContextOrBuilder(int) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
to pass MDC context
getRequestContextOrBuilder(int) - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
to pass MDC context
getRequestContextOrBuilderList() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
getRequestContextOrBuilderList() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
to pass MDC context
getRequestContextOrBuilderList() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
to pass MDC context
getRequested() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
bitwise OR of Flags
getRequested() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
bitwise OR of Flags
getRequested() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequestOrBuilder
bitwise OR of Flags
getRequestId() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadRequest
 
getRequestId() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
getRequestStats() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
getRequestTimer() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
The Timer used to time out requests for long polling.
getRequestTimerNumTicks() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of ticks per wheel for the request timer.
getRequestTimerTickDurationMs() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the tick duration in milliseconds.
getRereplicationEntryBatchSize() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the re-replication entry batch size.
getResult() - Method in class org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementResult
 
getResult() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.SyncResult
Deprecated.
 
getResult() - Method in class org.apache.bookkeeper.metastore.MetastoreUtils.SyncMetastoreCallback
 
getRetCode() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.SyncResult
Deprecated.
 
getReturnRc(int) - Method in class org.apache.bookkeeper.client.BookKeeper
 
getReturnRc(BookieClient, int) - Static method in class org.apache.bookkeeper.client.BookKeeper
 
getRolesFromOU(X509Certificate) - Static method in class org.apache.bookkeeper.util.CertUtils
 
getRolesFromOUMap(Map<String, String>) - Static method in class org.apache.bookkeeper.util.CertUtils
 
getRotatedLogChannels() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
getRwRereplicateBackoffMs() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get how long to backoff when encountering exception on rereplicating a ledger.
getSample() - Method in interface org.apache.bookkeeper.stats.Gauge
 
getSample() - Method in class org.apache.bookkeeper.stats.prometheus.SimpleGauge
 
getScheduler() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getScheduler() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getScheduler() - Method in interface org.apache.bookkeeper.client.ClientContext
 
getScheme() - Method in interface org.apache.bookkeeper.meta.MetadataBookieDriver
Get the scheme of the metadata driver.
getScheme() - Method in interface org.apache.bookkeeper.meta.MetadataClientDriver
Get the scheme of the metadata driver.
getScheme() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver
 
getScheme() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
getScope() - Method in class org.apache.bookkeeper.stats.prometheus.ScopeContext
 
getSecond() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LongPairWrapper
 
getSecurityProviderFactory(String) - Static method in class org.apache.bookkeeper.tls.SecurityProviderFactoryFactory
 
getSegment(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegment(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegment(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentBuilderList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentCount() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentCount() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentCount() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentList() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentOrBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentOrBuilder(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentOrBuilder(int) - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentOrBuilderList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentOrBuilderList() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
repeated .LedgerMetadataFormat.Segment segment = 6;
getSegmentOrBuilderList() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
repeated .LedgerMetadataFormat.Segment segment = 6;
getSequence() - Method in class org.apache.bookkeeper.client.SyncCounter
 
getSerializedSize() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
getSerializedSize() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
getServer() - Method in class org.apache.bookkeeper.server.service.BookieService
 
getServerAcceptorGroup(ServerConfiguration, ThreadFactory) - Static method in class org.apache.bookkeeper.util.EventLoopUtil
 
getServerCfg() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
The server configuration.
getServerConf() - Method in class org.apache.bookkeeper.server.conf.BookieConfiguration
 
getServerEventLoopGroup(ServerConfiguration, ThreadFactory) - Static method in class org.apache.bookkeeper.util.EventLoopUtil
 
getServerNumAcceptorThreads() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of Acceptor threads.
getServerNumIOThreads() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of IO threads.
getServerSockKeepalive() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get socket keepalive.
getServerSockLinger() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Timeout to drain the socket on close.
getServerTcpNoDelay() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Is tcp connection no delay.
getServerWriteBufferHighWaterMark() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get server netty channel write buffer high water mark.
getServerWriteBufferLowWaterMark() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get server netty channel write buffer low water mark.
getServiceHosts() - Method in class org.apache.bookkeeper.common.net.ServiceURI
 
getServiceInfos() - Method in class org.apache.bookkeeper.common.net.ServiceURI
 
getServiceName() - Method in class org.apache.bookkeeper.common.net.ServiceURI
 
getServicePath() - Method in class org.apache.bookkeeper.common.net.ServiceURI
 
getServiceUser() - Method in class org.apache.bookkeeper.common.net.ServiceURI
 
getSessionId() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getSessionPasswd() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getSessionTimeout() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getSettings() - Method in class org.apache.bookkeeper.common.conf.ConfigDef
 
getShadedLedgerManagerFactoryClassPrefix() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the class prefix of the shaded ledger manager factory class name allowed to be used for instantiating ledger manager factory.
getShFactory() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
TLS management.
getShort() - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
 
getShort() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
getShort() - Method in interface com.scurrilous.circe.StatefulHash
Returns the first two bytes of the output of this hash function as a little-endian short.
getShort(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getShort(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getShort(String, short) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getShort(String, Short) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getShort(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting from the configuration conf as a Short value.
getShortHierarchicalLedgerPath(long) - Static method in class org.apache.bookkeeper.util.StringUtils
Get the hierarchical ledger path according to the ledger id.
getShortLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getShutdownHandler() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
getSizeSinceLastWrite() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
getSkipListArenaChunkSize() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of bytes we should use as chunk allocation for org.apache.bookkeeper.bookie.SkipListArena.
getSkipListArenaMaxAllocSize() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the max size we should allocate from the skiplist arena.
getSkipListSizeLimit() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get skip list data size limitation (default 64MB).
getSnapshot() - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
Returns a snapshot of this timer.
getSnapshotStats() - Method in class org.apache.bookkeeper.bookie.stats.EntryMemTableStats
 
getSocketAddress() - Method in class org.apache.bookkeeper.net.BookieSocketAddress
 
getSortedLedgerStorageEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Check if sorted-ledger storage enabled (default true).
getSpeculativeReadCounter() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getSpeculativeReadCounter() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getSpeculativeReadLACTimeoutBackoffMultiplier() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Multipler to use when determining time between successive speculative read LAC requests.
getSpeculativeReadTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the period of time after which a speculative entry read should be triggered.
getSpeculativeReadTimeoutBackoffMultiplier() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Multipler to use when determining time between successive speculative read requests.
getSpeculativeTask() - Method in class org.apache.bookkeeper.client.ReadOpBase
 
getSrcLogId() - Method in interface org.apache.bookkeeper.bookie.storage.CompactionEntryLog
Get the log ID of the entrylog which is being compacted.
getSrcLogId() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
getStartMs() - Method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
getStartMs() - Method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
getStartTLSRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .StartTLSRequest startTLSRequest = 106;
getStartTLSRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .StartTLSRequest startTLSRequest = 106;
getStartTLSRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .StartTLSRequest startTLSRequest = 106;
getStartTLSRequestBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .StartTLSRequest startTLSRequest = 106;
getStartTLSRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .StartTLSRequest startTLSRequest = 106;
getStartTLSRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .StartTLSRequest startTLSRequest = 106;
getStartTLSRequestOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .StartTLSRequest startTLSRequest = 106;
getStartTLSResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .StartTLSResponse startTLSResponse = 106;
getStartTLSResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .StartTLSResponse startTLSResponse = 106;
getStartTLSResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .StartTLSResponse startTLSResponse = 106;
getStartTLSResponseBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .StartTLSResponse startTLSResponse = 106;
getStartTLSResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .StartTLSResponse startTLSResponse = 106;
getStartTLSResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .StartTLSResponse startTLSResponse = 106;
getStartTLSResponseOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .StartTLSResponse startTLSResponse = 106;
getStartTLSTimeout() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Return the timeout value for startTLS request.
getState() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the state of the metadata.
getState() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getState() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required .LedgerMetadataFormat.State state = 5 [default = OPEN];
getState() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
required .LedgerMetadataFormat.State state = 5 [default = OPEN];
getState() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
required .LedgerMetadataFormat.State state = 5 [default = OPEN];
getState() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
getStateCounter(Watcher.Event.KeeperState) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperWatcherBase
 
getStatelessInt(HashParameters) - Static method in class com.scurrilous.circe.Hashes
Requests a stateless, int-width hash function with the given parameters.
getStatelessInt(HashParameters) - Method in interface com.scurrilous.circe.HashProvider
Requests a stateless, int-width hash function with the given parameters.
getStatelessInt(HashParameters) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
 
getStatelessLong(HashParameters) - Static method in class com.scurrilous.circe.Hashes
Requests a stateless, long-width hash function with the given parameters.
getStatelessLong(HashParameters) - Method in interface com.scurrilous.circe.HashProvider
Requests a stateless, long-width hash function with the given parameters.
getStatelessLong(HashParameters) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
 
getStateManager() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
getStateManager() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getStateManager() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getStatsLogger() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getStatsLogger() - Method in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
getStatsLogger() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getStatsLogger() - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
getStatsLogger() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getStatsLogger(String) - Method in class org.apache.bookkeeper.stats.CachingStatsProvider
 
getStatsLogger(String) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
getStatsLogger(String) - Method in class org.apache.bookkeeper.stats.codahale.FastCodahaleMetricsProvider
 
getStatsLogger(String) - Method in class org.apache.bookkeeper.stats.NullStatsProvider
 
getStatsLogger(String) - Method in class org.apache.bookkeeper.stats.otel.OtelMetricsProvider
 
getStatsLogger(String) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
getStatsLogger(String) - Method in interface org.apache.bookkeeper.stats.StatsProvider
Return the stats logger to a given scope.
getStatsName(String...) - Method in class org.apache.bookkeeper.stats.CachingStatsProvider
 
getStatsName(String...) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
getStatsName(String...) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
getStatsName(String...) - Method in interface org.apache.bookkeeper.stats.StatsProvider
Return the fully qualified stats name comprised of given statsComponents.
getStatsProvider() - Method in class org.apache.bookkeeper.server.EmbeddedServer
 
getStatsProvider() - Method in class org.apache.bookkeeper.server.service.StatsProviderService
 
getStatsProviderClass() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the stats provider used by bookie.
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
required .StatusCode status = 1;
getStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponseOrBuilder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
required .StatusCode status = 1;
getStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponseOrBuilder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
required .StatusCode status = 1;
getStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponseOrBuilder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
required .StatusCode status = 1;
getStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponseOrBuilder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
required .StatusCode status = 1;
getStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponseOrBuilder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
required .StatusCode status = 1;
getStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
EOK if the underlying request succeeded.
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
EOK if the underlying request succeeded.
getStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
EOK if the underlying request succeeded.
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
required .StatusCode status = 1;
getStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
required .StatusCode status = 1;
getStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponseOrBuilder
required .StatusCode status = 1;
getStdDev() - Method in class org.apache.bookkeeper.stats.codahale.FastSnapshot
 
getStickyReadBookieIndex(LedgerMetadata, Optional<Integer>) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Select one bookie to the "sticky" bookie where all reads for a particular ledger will be directed to.
getStorageStateFlags() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
getStorageStateFlags() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Get the storage state flags currently set for the storage instance.
getStorageStateFlags() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getStorageStateFlags() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
getStorageStateFlags() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
getStorageStateFlags() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
getStoreSystemtimeAsLedgerCreationTime() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Return the flag that indicates whether client is using system time as the ledger creation time when creating ledgers.
getStoreSystemTimeAsLedgerUnderreplicatedMarkTime() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Return the flag that indicates whether auditor is using system time as underreplicated ledger mark time.
getString(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getString(String, String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getString(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Retrieve the setting from the configuration conf as a String value.
getStringArray(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getSubject() - Method in interface org.apache.bookkeeper.sasl.JAASCredentialsContainer
 
getSubject() - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
getSubject() - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
getSubmittedTasksCount() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
getSum(boolean) - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
getSwitchMap() - Method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
Get a copy of the map (for diagnostics).
getSwitchMap() - Method in class org.apache.bookkeeper.net.CachedDNSToSwitchMapping
Get the (host x switch) map.
getSysFileDescriptor(FileDescriptor) - Static method in class org.apache.bookkeeper.util.PageCacheUtil
Get system file descriptor (int) from FileDescriptor object.
getTaskExecutionWarnTimeMicros() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get task execution duration which triggers a warning.
getTcpUserTimeoutMillis() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get client netty TCP user timeout in millis (only for Epoll channels).
getThis() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Trickery to allow inheritance with fluent style.
getThis() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
 
getThis() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
getThreadFactory(String, boolean) - Static method in class org.apache.bookkeeper.common.util.ExecutorUtils
Get a ThreadFactory suitable for use in the current environment.
getThreadID(long) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
getThreadPool() - Method in class org.apache.bookkeeper.stats.ThreadRegistry.ThreadPoolThread
 
getThreadScopedCounter(String) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
Thread-scoped stats not currently supported.
getThreadScopedCounter(String) - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
Thread-scoped stats not currently supported.
getThreadScopedCounter(String) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
Thread-scoped stats not currently supported.
getThreadScopedCounter(String) - Method in class org.apache.bookkeeper.stats.NullStatsLogger
 
getThreadScopedCounter(String) - Method in class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
getThreadScopedCounter(String) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
getThreadScopedCounter(String) - Method in interface org.apache.bookkeeper.stats.StatsLogger
 
getThreadScopedOpStatsLogger(String) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
Thread-scoped stats not currently supported.
getThreadScopedOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
Thread-scoped stats not currently supported.
getThreadScopedOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
Thread-scoped stats not currently supported.
getThreadScopedOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.NullStatsLogger
 
getThreadScopedOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
getThreadScopedOpStatsLogger(String) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
getThreadScopedOpStatsLogger(String) - Method in interface org.apache.bookkeeper.stats.StatsLogger
 
getThrottledWriteRequests() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getThrottledWriteStats() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getThrottleValue() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get throttle value.
getThrottlingCounter() - Method in class org.apache.bookkeeper.bookie.stats.EntryMemTableStats
 
getThrottlingStats() - Method in class org.apache.bookkeeper.bookie.stats.EntryMemTableStats
 
getThrowable() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult
 
getTime() - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
Returns the current absolute time (in seconds).
getTimeOut() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used as a timeout (in milliseconds) for the long polling request
getTimeOut() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
Used as a timeout (in milliseconds) for the long polling request
getTimeOut() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
Used as a timeout (in milliseconds) for the long polling request
getTimeoutMonitorIntervalSec() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the interval between successive executions of the operation timeout monitor.
getTimeoutTaskIntervalMillis() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Deprecated.
getTimeoutTimerNumTicks() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get number of ticks that used for timeout timer.
getTimeoutTimerTickDurationMs() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the tick duration in milliseconds that used for timeout timer.
getTimestamp() - Method in class org.apache.bookkeeper.bookie.LastAddConfirmedUpdateNotification
 
getTLSCertFilesRefreshDurationSeconds() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get tls certificate files refresh duration in seconds.
getTLSCertificatePath() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the path to file containing TLS Certificate.
getTLSCertificatePath() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the path to file containing TLS Certificate.
getTLSClientAuthentication() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Whether the client will send an TLS certificate on TLS-handshake.
getTLSEnabledCipherSuites() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the list of enabled TLS cipher suites.
getTLSEnabledProtocols() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the list of enabled TLS protocols.
getTLSKeyStore() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the keystore path for the client.
getTLSKeyStore() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the keystore path for the client.
getTLSKeyStorePasswordPath() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the path to file containing keystore password, if the client keystore is password protected.
getTLSKeyStorePasswordPath() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the path to file containing keystore password if the client keystore is password protected.
getTLSKeyStoreType() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the keystore type for client.
getTLSKeyStoreType() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the keystore type for client.
getTLSProvider() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get TLS Provider (JDK or OpenSSL).
getTLSProviderFactoryClass() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get the security provider factory class name.
getTLSTrustStore() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the truststore path for the client.
getTLSTrustStore() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the truststore path for the client.
getTLSTrustStorePasswordPath() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the path to file containing truststore password, if the client truststore is password protected.
getTLSTrustStorePasswordPath() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the path to file containing truststore password if the client truststore is password protected.
getTLSTrustStoreType() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get the truststore type for client.
getTLSTrustStoreType() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the truststore type for client.
getTotalBookiesCount() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
getTotalBookiesCount() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
getTotalDiskCapacity() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
optional int64 totalDiskCapacity = 2;
getTotalDiskCapacity() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
optional int64 totalDiskCapacity = 2;
getTotalDiskCapacity() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponseOrBuilder
optional int64 totalDiskCapacity = 2;
getTotalDiskSpace() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
getTotalDiskSpace() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getTotalDiskSpace() - Method in class org.apache.bookkeeper.client.BookieInfoReader.BookieInfo
 
getTotalDiskSpace(List<File>) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Calculate the total amount of free space available in all of the ledger directories put together.
getTotalDiskSpace(List<File>) - Method in class org.apache.bookkeeper.util.DiskChecker
Calculate the total amount of disk space in all of the ledger directories put together.
getTotalDiskUsage(List<File>) - Method in class org.apache.bookkeeper.util.DiskChecker
calculates and returns the disk usage factor in the provided list of dirs.
getTotalFreeSpace() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
getTotalFreeSpace() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
getTotalFreeSpace(List<File>) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Calculate the total amount of free space available in all of the ledger directories put together.
getTotalFreeSpace(List<File>) - Method in class org.apache.bookkeeper.util.DiskChecker
Calculate the total amount of free space available in all of the ledger directories put together.
getTotalNumOfAvailableEntries() - Method in class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
getTotalSize() - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
getTotalSpace() - Method in class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
getTxnId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required uint64 txnId = 3;
getTxnId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
required uint64 txnId = 3;
getTxnId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeaderOrBuilder
required uint64 txnId = 3;
getType() - Method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
getType() - Method in class org.apache.bookkeeper.metastore.MSWatchedEvent
 
getType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required string type = 1;
getType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
required string type = 1;
getType() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormatOrBuilder
required string type = 1;
getTypeBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required string type = 1;
getTypeBytes() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
required string type = 1;
getTypeBytes() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormatOrBuilder
required string type = 1;
getTypeNameSuffix(Collector.Type) - Static method in class org.apache.bookkeeper.stats.prometheus.PrometheusTextFormat
 
getTypeStr(Collector.Type) - Static method in class org.apache.bookkeeper.stats.prometheus.PrometheusTextFormat
 
getUnavailableBookiesCount() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
getUnavailableBookiesCount() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
getUnavailableEntries(long, long, BitSet) - Method in class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
getUnderlying() - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
getUnderlyingConf() - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
getUnderlyingLedgerManager() - Method in class org.apache.bookkeeper.client.BookKeeper
 
getUnderlyingLedgerStorage() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
getUnderlyingLedgerStorage() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
getUnderreplicatedFragments(LedgerHandle, Long) - Method in class org.apache.bookkeeper.replication.ReplicationWorker
Gets the under replicated fragments.
getUnderreplicatedLedgerRecoveryGracePeriod() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Gets the grace period (in seconds) for underreplicated ledgers recovery.
getUnderreplicatedLedgerRecoveryGracePeriod() - Method in class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
getUnderReplicatedLedgersGuageValue() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getUnderReplicatedLedgerTotalSize() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getUnpersistedBytes() - Method in class org.apache.bookkeeper.bookie.BufferedChannel
 
getUnsignedByte(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getUnsignedInt(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getUnsignedIntLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getUnsignedMedium(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getUnsignedMediumLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getUnsignedShort(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getUnsignedShortLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
getUpgradeDomain() - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl.ZoneAwareNodeLocation
 
getUri() - Method in class org.apache.bookkeeper.common.net.ServiceURI
 
getUrLedgerLockZnode(String, long) - Static method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getUrLedgerZnode(String, long) - Static method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getUrLockPath(String) - Static method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
getURLPublishTimeForLostBookies() - Method in class org.apache.bookkeeper.replication.AuditorStats
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.AutoRecoveryCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieFormatCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieInfoCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieSanityTestCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.CheckDbLedgersIndexCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ClusterInfoCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ConvertToDbStorageCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ConvertToInterleavedStorageCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.DecommissionBookieCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.DeleteLedgerCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.EndpointInfoCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ForceAuditorChecksCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.HelpCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.InitBookieCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.InitNewCluster
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.LastMarkCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.LedgerCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.LedgerMetadataCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListActiveLedgersCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListBookiesCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListDiskFilesCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListLedgersCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ListUnderreplicatedCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.LocalConsistencyCheck
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.LostBookieRecoveryDelayCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.MetaFormatCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.NukeExistingCluster
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.QueryAutoRecoveryStatusCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadJournalCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLedgerEntriesCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLogCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLogMetadataCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgerLocationsIndexCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgersIndexCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.RecoverCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.RegenerateInterleavedStorageIndexFile
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.SimpleTestCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.TriggerAuditCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateBookieInLedgerCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateCookieCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateLedgerCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.WhatIsInstanceId
 
getUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.WhoIsAuditorCmd
 
getUsage() - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
getUsage() - Method in class org.apache.bookkeeper.tools.framework.CliCommand
 
getUsage() - Method in exception org.apache.bookkeeper.util.DiskChecker.DiskOutOfSpaceException
 
getUsage() - Method in exception org.apache.bookkeeper.util.DiskChecker.DiskWarnThresholdException
 
getUsedBucketCount() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
getUsedBucketCount() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
getUsedBucketCount() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
getUsedBucketCount() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
getUsedBucketCount() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
getUsedBucketCount() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
getUseHostNameAsBookieID() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether bookie is using hostname for registration and in ledger metadata.
getUseHostnameResolveLocalNodePlacementPolicy() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Get whether to use hostname to resolve local node placement policy.
getUserName() - Method in class org.apache.bookkeeper.sasl.SaslServerState
 
getUseShortHostName() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
If bookie is using hostname for registration and in ledger metadata then whether to use short hostname or FQDN hostname.
getUseTransactionalCompaction() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether to use transactional compaction and using a separate log for compaction or not.
getUseV2WireProtocol() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Use older Bookkeeper wire protocol (no protobuf).
getValue() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LongWrapper
 
getValue() - Method in enum org.apache.bookkeeper.client.api.WriteFlag
 
getValue() - Method in class org.apache.bookkeeper.metastore.MetastoreTableItem
Get the value of the item.
getValue() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string value = 2;
getValue() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
required string value = 2;
getValue() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPairOrBuilder
required string value = 2;
getValue() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional bytes value = 2;
getValue() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
optional bytes value = 2;
getValue() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntryOrBuilder
optional bytes value = 2;
getValue() - Method in class org.apache.bookkeeper.versioning.Versioned
 
getValue(double) - Method in class org.apache.bookkeeper.stats.codahale.FastSnapshot
 
getValueAndReset() - Method in interface org.apache.bookkeeper.proto.checksum.CRC32DigestManager.CRC32Digest
 
getValueAndReset() - Method in class org.apache.bookkeeper.proto.checksum.DirectMemoryCRC32Digest
 
getValueAndReset() - Method in class org.apache.bookkeeper.proto.checksum.StandardCRC32Digest
 
getValueAsByteBuffer() - Method in class org.apache.bookkeeper.bookie.EntryKeyValue
Returns the blob wrapped in a new ByteBuffer.
getValueBytes() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string value = 2;
getValueBytes() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
required string value = 2;
getValueBytes() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPairOrBuilder
required string value = 2;
getValueDescriptor() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
 
getValueDescriptor() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
 
getValueDescriptor() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
 
getValueDescriptor() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
 
getValueDescriptor() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
 
getValueDescriptor() - Method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
 
getValueDescriptor() - Method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
 
getValueDescriptor() - Method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
 
getValues() - Method in class org.apache.bookkeeper.stats.codahale.FastSnapshot
 
getVerifyMetadataOnGC() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether the bookie is configured to double check prior to gc.
getVersion() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
getVersion() - Method in class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
getVersion() - Method in interface org.apache.bookkeeper.metastore.MetaStore
Get the plugin verison.
getVersion() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required .ProtocolVersion version = 1;
getVersion() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
required .ProtocolVersion version = 1;
getVersion() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeaderOrBuilder
required .ProtocolVersion version = 1;
getVersion() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required int32 version = 2;
getVersion() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
required int32 version = 2;
getVersion() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormatOrBuilder
required int32 version = 2;
getVersion() - Method in class org.apache.bookkeeper.versioning.Versioned
 
getVersion(int) - Static method in class org.apache.bookkeeper.proto.BookieProtocol.PacketHeader
 
getVersionedLedgerMetadata() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
getWaitTimeoutOnBackpressureMillis() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Timeout controlling wait on request send in case of unresponsive bookie(s) (i.e.
getWaitTimeoutOnBackpressureMillis() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
getWaitTimeoutOnResponseBackpressureMillis() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Timeout controlling wait on response send in case of unresponsive client (i.e.
getWatchReadOnlyBookiesTask() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
getWatchWritableBookiesTask() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
getWeight() - Method in class org.apache.bookkeeper.client.BookieInfoReader.BookieInfo
 
getWeight() - Method in interface org.apache.bookkeeper.client.WeightedRandomSelection.WeightedObject
 
getWritableBookies() - Method in interface org.apache.bookkeeper.discover.RegistrationClient
Get the list of writable bookie identifiers.
getWritableBookies() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
getWritableBookiesCount() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
getWritableBookiesCount() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
getWritableLedgerDirs() - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Get only writable ledger dirs.
getWritableLedgerDirsForNewLog() - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
 
getWriteBufferBytes() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the number of bytes used as capacity for the write buffer.
getWriteBytes() - Method in class org.apache.bookkeeper.bookie.stats.BookieStats
 
getWriteCacheCountGauge() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getWriteCacheHitCounter() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getWriteCacheMissCounter() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getWriteCacheSizeGauge() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageStats
 
getWriteDelayedDueToNotEnoughFaultDomains() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getWriteDelayedDueToNotEnoughFaultDomains() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getWriteDelayedDueToNotEnoughFaultDomainsLatency() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getWriteDelayedDueToNotEnoughFaultDomainsLatency() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getWriteFileInfoCacheSizeGauge() - Method in class org.apache.bookkeeper.bookie.stats.IndexPersistenceMgrStats
 
getWriteFlags() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
getWriteFlags() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
optional int32 writeFlags = 5;
getWriteFlags() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
optional int32 writeFlags = 5;
getWriteFlags() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
optional int32 writeFlags = 5;
getWriteFlags(int) - Static method in enum org.apache.bookkeeper.client.api.WriteFlag
Converts a set of flags from a binary representation.
getWriteFlagsValue(EnumSet<WriteFlag>) - Static method in enum org.apache.bookkeeper.client.api.WriteFlag
Converts a set of flags from a binary representation.
getWriteLacOpLogger() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getWriteLacOpLogger() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getWriteLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .WriteLacRequest writeLacRequest = 103;
getWriteLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .WriteLacRequest writeLacRequest = 103;
getWriteLacRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .WriteLacRequest writeLacRequest = 103;
getWriteLacRequestBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .WriteLacRequest writeLacRequest = 103;
getWriteLacRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .WriteLacRequest writeLacRequest = 103;
getWriteLacRequestOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .WriteLacRequest writeLacRequest = 103;
getWriteLacRequestOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .WriteLacRequest writeLacRequest = 103;
getWriteLacRequestStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getWriteLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .WriteLacResponse writeLacResponse = 103;
getWriteLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .WriteLacResponse writeLacResponse = 103;
getWriteLacResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .WriteLacResponse writeLacResponse = 103;
getWriteLacResponseBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .WriteLacResponse writeLacResponse = 103;
getWriteLacResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .WriteLacResponse writeLacResponse = 103;
getWriteLacResponseOrBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .WriteLacResponse writeLacResponse = 103;
getWriteLacResponseOrBuilder() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .WriteLacResponse writeLacResponse = 103;
getWriteLacStats() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getWriteQuorumSize() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns the write quorum size of this ledger.
getWriteQuorumSize() - Method in interface org.apache.bookkeeper.client.DistributionSchedule
 
getWriteQuorumSize() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
getWriteQuorumSize() - Method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
getWriterFlushStats() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLoggerStats
 
getWriteSet(long) - Method in interface org.apache.bookkeeper.client.DistributionSchedule
Return the set of bookie indices to send the message to.
getWriteSet(long) - Method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
getWriteSetBookieIndex(long, int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule
Return the WriteSet bookie index for a given and index in the WriteSet.
getWriteSetBookieIndex(long, int) - Method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
getWriteSetForReadOperation(long) - Method in class org.apache.bookkeeper.client.LedgerHandle
Return a DistributionSchedule.WriteSet suitable for reading a particular entry.
getWriteThreadPool() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
The threadpool used to execute all add entry requests issued to this server.
getWriteThreadQueuedLatency() - Method in class org.apache.bookkeeper.proto.RequestStats
 
getWriteTimedOutDueToNotEnoughFaultDomains() - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
getWriteTimedOutDueToNotEnoughFaultDomains() - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
getZk() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
getZk() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
getZk() - Method in class org.apache.bookkeeper.meta.ZkLayoutManager
 
getZkAvailableBookiesPath() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Deprecated.
getZkLedgersRootPath() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Deprecated.
getZkRequestRateLimit() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get zookeeper access request rate limit.
getZkRetryBackoffMaxMs() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get zookeeper client backoff retry max time in millis.
getZkRetryBackoffMaxRetries() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get zookeeper client backoff max retry times.
getZkRetryBackoffStartMs() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get zookeeper client backoff retry start time in millis.
getZkServers() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Deprecated.
since 4.7.0
getZKServersFromServiceUri(URI) - Static method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
getZkSessionTimeOut() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperWatcherBase
Return zookeeper session time out.
getZKStringId(long) - Static method in class org.apache.bookkeeper.util.StringUtils
Formats ledger ID according to ZooKeeper rules.
getZKStringIdForLongHierarchical(long) - Static method in class org.apache.bookkeeper.util.StringUtils
Formats ledger ID according to ZooKeeper rules.
getZkTimeout() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Get zookeeper timeout.
getZone() - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl.ZoneAwareNodeLocation
 
getZoneAwareNodeLocation(BookieId) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
getZoneAwareNodeLocation(BookieNode) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
group() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The key-group to group settings together.
group(ConfigKeyGroup) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
The key-group to group settings together.
group(ConfigKeyGroup) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The key-group to group settings together.
GrowableMpScArrayConsumerBlockingQueue<T> - Class in org.apache.bookkeeper.common.collections
This implements a BlockingQueue backed by an array with no fixed capacity.
GrowableMpScArrayConsumerBlockingQueue() - Constructor for class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
GrowableMpScArrayConsumerBlockingQueue(int) - Constructor for class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 

H

handle - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterator
 
handle - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
handle(Callback[]) - Method in class org.apache.bookkeeper.sasl.SaslClientState.ClientCallbackHandler
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.AutoRecoveryStatusService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.BookieInfoService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.BookieIsReadyService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.BookieSanityService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.BookieStateService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ConfigurationService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.DecommissionService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.DeleteLedgerService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ExpandStorageService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.GCDetailsService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.GetLastLogMarkService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.GetLedgerMetaService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ListBookieInfoService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ListBookiesService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ListDiskFilesService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ListLedgerService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ListUnderReplicatedLedgerService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.LostBookieRecoveryDelayService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.MetricsService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ReadLedgerEntryService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.RecoveryBookieService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.ResumeCompactionService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.SuspendCompactionService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.TriggerAuditService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.TriggerGCService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.TriggerLocationCompactService
 
handle(HttpServiceRequest) - Method in class org.apache.bookkeeper.server.http.service.WhoIsAuditorService
 
Handle - Interface in org.apache.bookkeeper.client.api
Handle to manage an open ledger.
handleAsync(ServerConfiguration, SanityTestCommand.SanityFlags) - Static method in class org.apache.bookkeeper.tools.cli.commands.bookie.SanityTestCommand
 
handleBookieFailure(Map<Integer, BookieId>) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
handleBookieFailure(Map<Integer, BookieId>) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
For a read only ledger handle, this method will only ever be called during recovery, when we are reading forward from LAC and writing back those entries.
handleBookiesThatJoined(Set<BookieId>) - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy
Handle bookies that joined.
handleBookiesThatJoined(Set<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
handleBookiesThatJoined(Set<BookieId>) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
handleBookiesThatJoined(Set<BookieId>) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
handleBookiesThatJoined(Set<BookieId>) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicy
 
handleBookiesThatLeft(Set<BookieId>) - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy
Handle bookies that left.
handleBookiesThatLeft(Set<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
handleBookiesThatLeft(Set<BookieId>) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
handleBookiesThatLeft(Set<BookieId>) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
handleBookiesThatLeft(Set<BookieId>) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicy
 
handleException(Thread, Throwable) - Method in class org.apache.bookkeeper.bookie.BookieCriticalThread
 
handleException(Thread, Throwable) - Method in class org.apache.bookkeeper.bookie.BookieThread
Handles uncaught exception occurred in thread.
HandleFactory - Interface in org.apache.bookkeeper.bookie
 
HandleFactoryImpl - Class in org.apache.bookkeeper.bookie
 
HandleFactoryImpl(LedgerStorage) - Constructor for class org.apache.bookkeeper.bookie.HandleFactoryImpl
 
handleNonWritableChannel(Channel) - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
handler(ServerConfiguration) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.TriggerAuditCommand
 
handler(ServerConfiguration, ListUnderReplicatedCommand.LURFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand
 
handler(ServerConfiguration, LostBookieRecoveryDelayCommand.LBRDFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.LostBookieRecoveryDelayCommand
 
handler(ServerConfiguration, QueryAutoRecoveryStatusCommand.QFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.QueryAutoRecoveryStatusCommand
 
handler(ServerConfiguration, ListActiveLedgersCommand.ActiveLedgerFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand
 
handler(ServerConfiguration, ListLedgersCommand.ListLedgersFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListLedgersCommand
 
HANDLER - Static variable in exception org.apache.bookkeeper.client.api.BKException
 
HANDLER - Static variable in exception org.apache.bookkeeper.client.BKException
 
handleReadResultForFenceRead(ByteBuf, BookkeeperProtocol.ReadResponse.Builder, long, Stopwatch) - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
Handle read result for fence read.
handles - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
handleUnrecoverableErrorDuringAdd(int) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
handleUnrecoverableErrorDuringAdd(int) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
handleV2Response(long, long, BookkeeperProtocol.StatusCode, BookieProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
handleV2Response(long, long, BookkeeperProtocol.StatusCode, BookieProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.BatchedReadCompletion
 
handleV2Response(long, long, BookkeeperProtocol.StatusCode, BookieProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
handleV2Response(long, long, BookkeeperProtocol.StatusCode, BookieProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadCompletion
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.BatchedReadCompletion
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ForceLedgerCompletion
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.GetBookieInfoCompletion
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.GetListOfEntriesOfLedgerCompletion
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadCompletion
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadLacCompletion
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.StartTLSCompletion
 
handleV3Response(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.WriteLacCompletion
 
happensAfter() - Method in annotation type org.apache.bookkeeper.stats.annotations.StatsDoc
The metric name of an operation that happens after the operation of this metric.
HardLink - Class in org.apache.bookkeeper.util
Class for creating hardlinks.
HardLink() - Constructor for class org.apache.bookkeeper.util.HardLink
 
HardLink.HardLinkCGUnix - Class in org.apache.bookkeeper.util
Implementation of HardLinkCommandGetter class for Unix.
HardLink.HardLinkCGWin - Class in org.apache.bookkeeper.util
Implementation of HardLinkCommandGetter class for Windows.
HardLink.LinkStats - Class in org.apache.bookkeeper.util
HardLink statistics counters and methods.
HardLink.OSType - Enum in org.apache.bookkeeper.util
OS Types.
HardLinkCGUnix() - Constructor for class org.apache.bookkeeper.util.HardLink.HardLinkCGUnix
 
HardLinkCGWin() - Constructor for class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
hardLinkCommand - Static variable in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
hardLinkMultDir - Static variable in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
hardLinkMultPrefix - Static variable in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
hardLinkMultSuffix - Static variable in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
HARDWARE - com.scurrilous.circe.HashSupport
Indicates that the hash algorithm is available in hardware-accelerated native code.
HARDWARE_INCREMENTAL - com.scurrilous.circe.HashSupport
Indicates that the hash algorithm is available in hardware-accelerated native code as an IncrementalIntHash or IncrementalLongHash, depending on which of HashSupport.INT_SIZED or HashSupport.LONG_SIZED is set.
HAS_JAVA9_CRC32C - Static variable in class com.scurrilous.circe.checksum.Java9IntHash
 
hasAckQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int32 ackQuorumSize = 9;
hasAckQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional int32 ackQuorumSize = 9;
hasAckQuorumSize() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional int32 ackQuorumSize = 9;
hasAddRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AddRequest addRequest = 101;
hasAddRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .AddRequest addRequest = 101;
hasAddRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .AddRequest addRequest = 101;
hasAddResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AddResponse addResponse = 101;
hasAddResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .AddResponse addResponse = 101;
hasAddResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .AddResponse addResponse = 101;
hasArray() - Method in class org.apache.bookkeeper.util.ByteBufList
Returns true if this buffer has a single backing byte array.
hasArray() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
hasAuthPluginName() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required string authPluginName = 1;
hasAuthPluginName() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
required string authPluginName = 1;
hasAuthPluginName() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessageOrBuilder
required string authPluginName = 1;
hasAuthRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AuthMessage authRequest = 102;
hasAuthRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .AuthMessage authRequest = 102;
hasAuthRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .AuthMessage authRequest = 102;
hasAuthResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AuthMessage authResponse = 102;
hasAuthResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .AuthMessage authResponse = 102;
hasAuthResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .AuthMessage authResponse = 102;
hasAvailabilityOfEntriesOfLedger() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
condensed encoded format representing availability of entries of ledger
hasAvailabilityOfEntriesOfLedger() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
condensed encoded format representing availability of entries of ledger
hasAvailabilityOfEntriesOfLedger() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponseOrBuilder
condensed encoded format representing availability of entries of ledger
hasBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required bytes body = 4;
hasBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
required bytes body = 4;
hasBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
required bytes body = 4;
hasBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
optional bytes body = 4;
hasBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
optional bytes body = 4;
hasBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
optional bytes body = 4;
hasBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required bytes body = 4;
hasBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
required bytes body = 4;
hasBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequestOrBuilder
required bytes body = 4;
hasBookieCheckTask() - Method in class org.apache.bookkeeper.replication.AuditorTask
 
hasBookieHost() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string bookieHost = 1;
hasBookieHost() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
required string bookieHost = 1;
hasBookieHost() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
required string bookieHost = 1;
hasBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
optional string bookieId = 1;
hasBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
optional string bookieId = 1;
hasBookieId() - Method in interface org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormatOrBuilder
optional string bookieId = 1;
hasBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
optional string bookieId = 1;
hasBookieId() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
optional string bookieId = 1;
hasBookieId() - Method in interface org.apache.bookkeeper.proto.DataFormats.LockDataFormatOrBuilder
optional string bookieId = 1;
hasCache() - Static method in class com.scurrilous.circe.impl.HashCacheLoader
Returns whether a hash function cache is available.
hasCheckAllLedgersCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
optional int64 checkAllLedgersCTime = 1;
hasCheckAllLedgersCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
optional int64 checkAllLedgersCTime = 1;
hasCheckAllLedgersCTime() - Method in interface org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormatOrBuilder
optional int64 checkAllLedgersCTime = 1;
hasCommand(String) - Method in class org.apache.bookkeeper.tools.framework.Cli
 
hasCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 ctime = 10;
hasCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional int64 ctime = 10;
hasCtime() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional int64 ctime = 10;
hasCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
optional int64 ctime = 2;
hasCtime() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
optional int64 ctime = 2;
hasCtime() - Method in interface org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormatOrBuilder
optional int64 ctime = 2;
hasCToken() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 cToken = 12;
hasCToken() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional int64 cToken = 12;
hasCToken() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional int64 cToken = 12;
hasData() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
hasData(int, int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
hasDelayedWriteFailedBookies() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
hasDigestType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional .LedgerMetadataFormat.DigestType digestType = 7;
hasDigestType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional .LedgerMetadataFormat.DigestType digestType = 7;
hasDigestType() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional .LedgerMetadataFormat.DigestType digestType = 7;
hasEnsembleSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int32 ensembleSize = 2;
hasEnsembleSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
required int32 ensembleSize = 2;
hasEnsembleSize() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
required int32 ensembleSize = 2;
hasEntry() - Method in interface org.apache.bookkeeper.client.api.LastConfirmedAndEntry
Whether this entity contains an entry.
hasEntry() - Method in class org.apache.bookkeeper.client.impl.LastConfirmedAndEntryImpl
Whether this entity contains an entry.
hasEntry(long, int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule
Whether entry presents on given bookie index.
hasEntry(long, int) - Method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
hasEntry(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.ReadCache
 
hasEntry(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
hasEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required int64 entryId = 2;
hasEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
required int64 entryId = 2;
hasEntryId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
required int64 entryId = 2;
hasEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required int64 entryId = 3;
hasEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
required int64 entryId = 3;
hasEntryId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponseOrBuilder
required int64 entryId = 3;
hasEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
entryId will be -1 for reading the LAST_ADD_CONFIRMED entry.
hasEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
entryId will be -1 for reading the LAST_ADD_CONFIRMED entry.
hasEntryId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
entryId will be -1 for reading the LAST_ADD_CONFIRMED entry.
hasEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required int64 entryId = 3;
hasEntryId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
required int64 entryId = 3;
hasEntryId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
required int64 entryId = 3;
hasExists() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bool exists = 1;
hasExists() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
required bool exists = 1;
hasExists() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
required bool exists = 1;
hasExplicitLac() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
optional bytes explicitLac = 4;
hasExplicitLac() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
optional bytes explicitLac = 4;
hasExplicitLac() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
optional bytes explicitLac = 4;
hasFenced() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bool fenced = 2;
hasFenced() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
required bool fenced = 2;
hasFenced() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
required bool fenced = 2;
hasFirstEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
required int64 firstEntryId = 2;
hasFirstEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
required int64 firstEntryId = 2;
hasFirstEntryId() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.SegmentOrBuilder
required int64 firstEntryId = 2;
hasFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
optional .AddRequest.Flag flag = 100;
hasFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
optional .AddRequest.Flag flag = 100;
hasFlag() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
optional .AddRequest.Flag flag = 100;
hasFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
optional .ReadRequest.Flag flag = 100;
hasFlag() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
optional .ReadRequest.Flag flag = 100;
hasFlag() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
optional .ReadRequest.Flag flag = 100;
hasFlag(BookkeeperProtocol.AddRequest, BookkeeperProtocol.AddRequest.Flag) - Static method in class org.apache.bookkeeper.proto.RequestUtils
 
hasFlag(BookkeeperProtocol.ReadRequest, BookkeeperProtocol.ReadRequest.Flag) - Static method in class org.apache.bookkeeper.proto.RequestUtils
 
hasFlushBeenTriggered - Variable in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
hasForceLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ForceLedgerRequest forceLedgerRequest = 107;
hasForceLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .ForceLedgerRequest forceLedgerRequest = 107;
hasForceLedgerRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .ForceLedgerRequest forceLedgerRequest = 107;
hasForceLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ForceLedgerResponse forceLedgerResponse = 107;
hasForceLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .ForceLedgerResponse forceLedgerResponse = 107;
hasForceLedgerResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .ForceLedgerResponse forceLedgerResponse = 107;
hasFreeDiskSpace() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
optional int64 freeDiskSpace = 3;
hasFreeDiskSpace() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
optional int64 freeDiskSpace = 3;
hasFreeDiskSpace() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponseOrBuilder
optional int64 freeDiskSpace = 3;
hasGetBookieInfoRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
hasGetBookieInfoRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
hasGetBookieInfoRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
hasGetBookieInfoResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
hasGetBookieInfoResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
hasGetBookieInfoResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
hasGetListOfEntriesOfLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
hasGetListOfEntriesOfLedgerRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
hasGetListOfEntriesOfLedgerRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
hasGetListOfEntriesOfLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
hasGetListOfEntriesOfLedgerResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
hasGetListOfEntriesOfLedgerResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
hash(long) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
hash(long) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
hash(long) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
hash(long, long) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
hash(K) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
hash(K) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
Hash - Interface in com.scurrilous.circe
Abstract hash function.
HashCache - Interface in com.scurrilous.circe.impl
Interface implemented by hash function caches.
HashCacheLoader - Class in com.scurrilous.circe.impl
Provides access to a singleton hash function cache, if an implementation is available.
hashCode() - Method in class com.scurrilous.circe.params.CrcParameters
 
hashCode() - Method in class com.scurrilous.circe.params.SimpleHashParameters
 
hashCode() - Method in class org.apache.bookkeeper.auth.BookKeeperPrincipal
 
hashCode() - Method in class org.apache.bookkeeper.bookie.Cookie
 
hashCode() - Method in class org.apache.bookkeeper.bookie.EntryKey
 
hashCode() - Method in class org.apache.bookkeeper.bookie.EntryKeyValue
 
hashCode() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
hashCode() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
hashCode() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
hashCode() - Method in class org.apache.bookkeeper.client.PendingAddOp
 
hashCode() - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl.ZoneAwareNodeLocation
 
hashCode() - Method in class org.apache.bookkeeper.common.collections.RecyclableArrayList
 
hashCode() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
hashCode() - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
hashCode() - Method in class org.apache.bookkeeper.common.conf.validators.ClassValidator
 
hashCode() - Method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
 
hashCode() - Method in class org.apache.bookkeeper.common.net.ServiceURI
 
hashCode() - Method in class org.apache.bookkeeper.common.util.Backoff.Constant
 
hashCode() - Method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
hashCode() - Method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
hashCode() - Method in class org.apache.bookkeeper.meta.LedgerLayout
 
hashCode() - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.MetadataVersion
 
hashCode() - Method in class org.apache.bookkeeper.metastore.Value
 
hashCode() - Method in class org.apache.bookkeeper.net.BookieId
 
hashCode() - Method in class org.apache.bookkeeper.net.BookieNode
 
hashCode() - Method in class org.apache.bookkeeper.net.BookieSocketAddress
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
hashCode() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
hashCode() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.TxnCompletionKey
 
hashCode() - Method in class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
hashCode() - Method in class org.apache.bookkeeper.server.http.service.BookieSanityService.BookieSanity
 
hashCode() - Method in class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService.ReadOnlyState
 
hashCode() - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
hashCode() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
hashCode() - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
 
hashCode() - Method in class org.apache.bookkeeper.stats.otel.ScopeContext
 
hashCode() - Method in class org.apache.bookkeeper.stats.prometheus.ScopeContext
 
hashCode() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
hashCode() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
hashCode() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
hashCode() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.LongPair
 
hashCode() - Method in class org.apache.bookkeeper.versioning.LongVersion
 
hashCode() - Method in class org.apache.bookkeeper.versioning.Versioned
 
hasHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
required .BKPacketHeader header = 1;
hasHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
required .BKPacketHeader header = 1;
hasHeader() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
required .BKPacketHeader header = 1;
hasHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
required .BKPacketHeader header = 1;
hasHeader() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
required .BKPacketHeader header = 1;
hasHeader() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
required .BKPacketHeader header = 1;
Hashes - Class in com.scurrilous.circe
Static methods to obtain various forms of abstract hash functions.
hasHost() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string host = 3;
hasHost() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required string host = 3;
hasHost() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required string host = 3;
HashParameters - Interface in com.scurrilous.circe
Base interface implemented by classes describing parameters for a particular family of hash algorithms.
HashProvider - Interface in com.scurrilous.circe
Interface used to obtain instances of various kinds of hash algorithms.
HashProviders - Class in com.scurrilous.circe
Static utility methods for discovering HashProvider instances.
HashSupport - Enum in com.scurrilous.circe
Flags indicating the support available for some set of hash algorithm.
HashSupport.SetComparator - Class in com.scurrilous.circe
Comparator for EnumSets for hash support flags.
hasId() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string id = 1;
hasId() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required string id = 1;
hasId() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required string id = 1;
hasIndexDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string indexDirs = 5;
hasIndexDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
optional string indexDirs = 5;
hasIndexDirs() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
optional string indexDirs = 5;
hasInitialResponse() - Method in class org.apache.bookkeeper.sasl.SaslClientState
 
hasInstanceId() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string instanceId = 4;
hasInstanceId() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
optional string instanceId = 4;
hasInstanceId() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
optional string instanceId = 4;
hasJournalDir() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string journalDir = 2;
hasJournalDir() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
required string journalDir = 2;
hasJournalDir() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
required string journalDir = 2;
hasKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string key = 1;
hasKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
required string key = 1;
hasKey() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPairOrBuilder
required string key = 1;
hasKey() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional string key = 1;
hasKey() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
optional string key = 1;
hasKey() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntryOrBuilder
optional string key = 1;
hasLac() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required int64 lac = 2;
hasLac() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
required int64 lac = 2;
hasLac() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequestOrBuilder
required int64 lac = 2;
hasLacBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
lac sent by PutLacRequest
hasLacBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
lac sent by PutLacRequest
hasLacBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponseOrBuilder
lac sent by PutLacRequest
hasLacUpdateTimestamp() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
optional int64 lacUpdateTimestamp = 6;
hasLacUpdateTimestamp() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
optional int64 lacUpdateTimestamp = 6;
hasLacUpdateTimestamp() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
optional int64 lacUpdateTimestamp = 6;
hasLastEntryBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
Actual last entry on the disk
hasLastEntryBody() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
Actual last entry on the disk
hasLastEntryBody() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponseOrBuilder
Actual last entry on the disk
hasLastEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 lastEntryId = 4;
hasLastEntryId() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional int64 lastEntryId = 4;
hasLastEntryId() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional int64 lastEntryId = 4;
hasLedgerDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string ledgerDirs = 3;
hasLedgerDirs() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
required string ledgerDirs = 3;
hasLedgerDirs() - Method in interface org.apache.bookkeeper.proto.DataFormats.CookieFormatOrBuilder
required string ledgerDirs = 3;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
required int64 ledgerId = 1;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
required int64 ledgerId = 2;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponseOrBuilder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
required int64 ledgerId = 1;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequestOrBuilder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
required int64 ledgerId = 2;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponseOrBuilder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
required int64 ledgerId = 1;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequestOrBuilder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
required int64 ledgerId = 2;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponseOrBuilder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
required int64 ledgerId = 1;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequestOrBuilder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
required int64 ledgerId = 2;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponseOrBuilder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
required int64 ledgerId = 1;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
required int64 ledgerId = 2;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
required int64 ledgerId = 1;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequestOrBuilder
required int64 ledgerId = 1;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
required int64 ledgerId = 2;
hasLedgerId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
required int64 ledgerId = 2;
hasLedgerId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponseOrBuilder
required int64 ledgerId = 2;
hasLength() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int64 length = 3;
hasLength() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
required int64 length = 3;
hasLength() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
required int64 length = 3;
hasLimbo() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
optional bool limbo = 5;
hasLimbo() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
optional bool limbo = 5;
hasLimbo() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
optional bool limbo = 5;
hasLimboState(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
hasLimboState(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Check whether a ledger is in limbo state.
hasLimboState(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
hasLimboState(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
hasLimboState(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
hasMasterKey() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bytes masterKey = 3;
hasMasterKey() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
required bytes masterKey = 3;
hasMasterKey() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerDataOrBuilder
required bytes masterKey = 3;
hasMasterKey() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
hasMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required bytes masterKey = 3;
hasMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
required bytes masterKey = 3;
hasMasterKey() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
required bytes masterKey = 3;
hasMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used while fencing a ledger.
hasMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
Used while fencing a ledger.
hasMasterKey() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
Used while fencing a ledger.
hasMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required bytes masterKey = 3;
hasMasterKey() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
required bytes masterKey = 3;
hasMasterKey() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequestOrBuilder
required bytes masterKey = 3;
hasMaxLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
Piggyback LAC
hasMaxLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
Piggyback LAC
hasMaxLAC() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
Piggyback LAC
hasMemoryAddress() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
hasMoreEntries() - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreCursor
 
hasMoreEntries() - Method in interface org.apache.bookkeeper.metastore.MetastoreCursor
Is there any entries left in the cursor to read.
hasNext() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage.CloseableIterator
 
hasNext() - Method in interface org.apache.bookkeeper.client.api.LedgersIterator
Return true if there is at least one ledger to visit.
hasNext() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterator
 
hasNext() - Method in interface org.apache.bookkeeper.meta.LedgerManager.LedgerRangeIterator
 
hasNext() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager.MSLedgerRangeIterator
Deprecated.
 
hasNext() - Method in class org.apache.bookkeeper.slogger.AbstractSlogger.CtxIterator
 
hasNext() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo.EntryIterator
 
hasOperation() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required .OperationType operation = 2;
hasOperation() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
required .OperationType operation = 2;
hasOperation() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeaderOrBuilder
required .OperationType operation = 2;
hasPassword() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Whether the metadata contains the password and digest type for the ledger.
hasPassword() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
In versions 4.1.0 and below, the digest type and password were not stored in the metadata.
hasPassword() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional bytes password = 8;
hasPassword() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
optional bytes password = 8;
hasPassword() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
optional bytes password = 8;
hasPayload() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required bytes payload = 2;
hasPayload() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
required bytes payload = 2;
hasPayload() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessageOrBuilder
required bytes payload = 2;
hasPlacementPolicyCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
optional int64 placementPolicyCheckCTime = 1;
hasPlacementPolicyCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
optional int64 placementPolicyCheckCTime = 1;
hasPlacementPolicyCheckCTime() - Method in interface org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormatOrBuilder
optional int64 placementPolicyCheckCTime = 1;
hasPort() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required int32 port = 2;
hasPort() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required int32 port = 2;
hasPort() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required int32 port = 2;
hasPreviousLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used for waiting on last add confirmed update
hasPreviousLAC() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
Used for waiting on last add confirmed update
hasPreviousLAC() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
Used for waiting on last add confirmed update
hasPriority() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
optional uint32 priority = 4 [default = 0];
hasPriority() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
optional uint32 priority = 4 [default = 0];
hasPriority() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeaderOrBuilder
optional uint32 priority = 4 [default = 0];
hasProtocol() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string protocol = 4;
hasProtocol() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
required string protocol = 4;
hasProtocol() - Method in interface org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.EndpointOrBuilder
required string protocol = 4;
hasQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int32 quorumSize = 1;
hasQuorumSize() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
required int32 quorumSize = 1;
hasQuorumSize() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
required int32 quorumSize = 1;
hasReadLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ReadLacRequest readLacRequest = 104;
hasReadLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .ReadLacRequest readLacRequest = 104;
hasReadLacRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .ReadLacRequest readLacRequest = 104;
hasReadLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ReadLacResponse readLacResponse = 104;
hasReadLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .ReadLacResponse readLacResponse = 104;
hasReadLacResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .ReadLacResponse readLacResponse = 104;
hasReadRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
Requests
hasReadRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
Requests
hasReadRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
Requests
hasReadResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
Response
hasReadResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
Response
hasReadResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
Response
hasReplicasCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
optional int64 replicasCheckCTime = 1;
hasReplicasCheckCTime() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
optional int64 replicasCheckCTime = 1;
hasReplicasCheckCTime() - Method in interface org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormatOrBuilder
optional int64 replicasCheckCTime = 1;
hasRequested() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
bitwise OR of Flags
hasRequested() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
bitwise OR of Flags
hasRequested() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequestOrBuilder
bitwise OR of Flags
hasRun - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
hasSpace(int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
hasStartTLSRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .StartTLSRequest startTLSRequest = 106;
hasStartTLSRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .StartTLSRequest startTLSRequest = 106;
hasStartTLSRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .StartTLSRequest startTLSRequest = 106;
hasStartTLSResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .StartTLSResponse startTLSResponse = 106;
hasStartTLSResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .StartTLSResponse startTLSResponse = 106;
hasStartTLSResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .StartTLSResponse startTLSResponse = 106;
hasState() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required .LedgerMetadataFormat.State state = 5 [default = OPEN];
hasState() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
required .LedgerMetadataFormat.State state = 5 [default = OPEN];
hasState() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormatOrBuilder
required .LedgerMetadataFormat.State state = 5 [default = OPEN];
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
required .StatusCode status = 1;
hasStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponseOrBuilder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
required .StatusCode status = 1;
hasStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponseOrBuilder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
required .StatusCode status = 1;
hasStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponseOrBuilder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
required .StatusCode status = 1;
hasStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponseOrBuilder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
required .StatusCode status = 1;
hasStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponseOrBuilder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
required .StatusCode status = 1;
hasStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponseOrBuilder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
EOK if the underlying request succeeded.
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
EOK if the underlying request succeeded.
hasStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
EOK if the underlying request succeeded.
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
required .StatusCode status = 1;
hasStatus() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
required .StatusCode status = 1;
hasStatus() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponseOrBuilder
required .StatusCode status = 1;
hasTimeOut() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used as a timeout (in milliseconds) for the long polling request
hasTimeOut() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
Used as a timeout (in milliseconds) for the long polling request
hasTimeOut() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequestOrBuilder
Used as a timeout (in milliseconds) for the long polling request
hasTotalDiskCapacity() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
optional int64 totalDiskCapacity = 2;
hasTotalDiskCapacity() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
optional int64 totalDiskCapacity = 2;
hasTotalDiskCapacity() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponseOrBuilder
optional int64 totalDiskCapacity = 2;
hasTxnId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required uint64 txnId = 3;
hasTxnId() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
required uint64 txnId = 3;
hasTxnId() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeaderOrBuilder
required uint64 txnId = 3;
hasType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required string type = 1;
hasType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
required string type = 1;
hasType() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormatOrBuilder
required string type = 1;
hasValidResponse - Variable in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
hasValue() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string value = 2;
hasValue() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
required string value = 2;
hasValue() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPairOrBuilder
required string value = 2;
hasValue() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional bytes value = 2;
hasValue() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
optional bytes value = 2;
hasValue() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntryOrBuilder
optional bytes value = 2;
hasVersion() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required .ProtocolVersion version = 1;
hasVersion() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
required .ProtocolVersion version = 1;
hasVersion() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeaderOrBuilder
required .ProtocolVersion version = 1;
hasVersion() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required int32 version = 2;
hasVersion() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
required int32 version = 2;
hasVersion() - Method in interface org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormatOrBuilder
required int32 version = 2;
hasWritableLedgerDirs() - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
 
hasWriteFlags() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
optional int32 writeFlags = 5;
hasWriteFlags() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
optional int32 writeFlags = 5;
hasWriteFlags() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequestOrBuilder
optional int32 writeFlags = 5;
hasWriteLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .WriteLacRequest writeLacRequest = 103;
hasWriteLacRequest() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
optional .WriteLacRequest writeLacRequest = 103;
hasWriteLacRequest() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.RequestOrBuilder
optional .WriteLacRequest writeLacRequest = 103;
hasWriteLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .WriteLacResponse writeLacResponse = 103;
hasWriteLacResponse() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
optional .WriteLacResponse writeLacResponse = 103;
hasWriteLacResponse() - Method in interface org.apache.bookkeeper.proto.BookkeeperProtocol.ResponseOrBuilder
optional .WriteLacResponse writeLacResponse = 103;
Header - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
The 1K block at the head of the entry logger file that contains the fingerprint and meta-data.
Header() - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
HEADER_CURRENT_VERSION - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
HEADER_CURRENT_VERSION - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
HEADER_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
HEADER_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
HEADER_SIZE - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
HEADER_SIZE - Static variable in class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
HEADER_V0 - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
HEADER_V1 - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
HEADER_VERSION_OFFSET - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
HEADER_VERSION_POSITION - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
headerVersion - Variable in class org.apache.bookkeeper.bookie.FileInfo
 
HealthCheckFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.health.SwitchOfHealthCheckCommand.HealthCheckFlags
 
heardFromHosts - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
heardFromHostsBitSet - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
heardFromHostsBitSet - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
help - Variable in class org.apache.bookkeeper.tools.framework.CliFlags
 
help() - Method in annotation type org.apache.bookkeeper.stats.annotations.StatsDoc
The help message of this stats.
HelpCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.HelpCmd
 
HelpCommand<GlobalFlagsT extends CliFlags,​CommandFlagsT extends CliFlags> - Class in org.apache.bookkeeper.tools.framework
Help command to show help information.
HelpCommand(Cli<CommandFlagsT>) - Constructor for class org.apache.bookkeeper.tools.framework.HelpCommand
 
HexDumpEntryFormatter - Class in org.apache.bookkeeper.util
A hex dump entry formatter.
HexDumpEntryFormatter() - Constructor for class org.apache.bookkeeper.util.HexDumpEntryFormatter
 
HexLedgerIdFormatter() - Constructor for class org.apache.bookkeeper.util.LedgerIdFormatter.HexLedgerIdFormatter
 
hidden() - Method in interface org.apache.bookkeeper.tools.framework.Command
Returns whether to hide this command from showing in help message.
HIERARCHICAL_LEDGER_PARENT_NODE_REGEX - Static variable in class org.apache.bookkeeper.util.StringUtils
 
HierarchicalLedgerManager - Class in org.apache.bookkeeper.meta
HierarchicalLedgerManager makes use of both LongHierarchicalLedgerManager and LegacyHierarchicalLedgerManager to extend the 31-bit ledger id range of the LegacyHierarchicalLedgerManager to that of the LongHierarchicalLedgerManager while remaining backwards-compatible with the legacy manager.
HierarchicalLedgerManager(AbstractConfiguration, ZooKeeper) - Constructor for class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
HierarchicalLedgerManagerFactory - Class in org.apache.bookkeeper.meta
Legacy Hierarchical Ledger Manager Factory.
HierarchicalLedgerManagerFactory() - Constructor for class org.apache.bookkeeper.meta.HierarchicalLedgerManagerFactory
 
historyBookies - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
HMAC - org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
HMAC = 2;
HMAC_VALUE - Static variable in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
HMAC = 2;
HOST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
hostname(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand.FlipBookieIdFlags
 
hostname(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand.AdminFlags
 
HTTP_SERVER_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
HTTP_SERVER_HOST - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
HTTP_SERVER_KEY_STORE_PASSWORD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
HTTP_SERVER_KEY_STORE_PATH - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
HTTP_SERVER_PORT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
HTTP_SERVER_TLS_ENABLE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
HTTP_SERVER_TRUST_STORE_PASSWORD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
HTTP_SERVER_TRUST_STORE_PATH - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
HttpService - Class in org.apache.bookkeeper.server.service
A ServerLifecycleComponent that runs http service.
HttpService(BKHttpServiceProvider, BookieConfiguration, StatsLogger) - Constructor for class org.apache.bookkeeper.server.service.HttpService
 

I

i - Variable in class org.apache.bookkeeper.client.SyncCounter
 
id - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
ID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
IDGEN_ZNODE - Static variable in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManager
 
IDGEN_ZNODE - Static variable in class org.apache.bookkeeper.meta.LongHierarchicalLedgerManager
 
IDGEN_ZNODE - Static variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
ignore(CompletableFuture<T>) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
Ignore exception from the future.
ignore(CompletableFuture<T>, String) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
Ignore exception from the future and log errorMsg on exceptions.
IGNORE_EXTRA_SERVER_COMPONENTS_STARTUP_FAILURES - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
IGNORE_LOCAL_NODE_IN_PLACEMENT_POLICY - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ignoreLocalNodeInPlacementPolicy - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
IllegalOp - org.apache.bookkeeper.metastore.MSException.Code
 
IllegalOpException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
IllegalOpException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Operation is illegal.
IllegalOpException(String) - Constructor for exception org.apache.bookkeeper.metastore.MSException.IllegalOpException
 
IllegalOpException(String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MSException.IllegalOpException
 
impl - Variable in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
IN_FLIGHT_READ_ENTRY_NUM_IN_LEDGER_CHECKER - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
IN_RECOVERY - org.apache.bookkeeper.client.api.LedgerMetadata.State
A reader has tried to, or may be trying to recover the ledger.
IN_RECOVERY - org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
IN_RECOVERY = 2;
IN_RECOVERY_VALUE - Static variable in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
IN_RECOVERY = 2;
inc() - Method in class org.apache.bookkeeper.client.SyncCounter
 
inc() - Method in interface org.apache.bookkeeper.stats.Counter
Increment the value associated with this stat.
inc() - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullCounter
 
inc() - Method in class org.apache.bookkeeper.stats.otel.OtelCounter
 
inc() - Method in class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
 
inc() - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedLongAdderCounter
 
incompleteCompactionLogs() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
incompleteCompactionLogs() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
incompleteCompactionLogs() - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Return a collection of all the compaction entry logs which have been compacted, but have not been cleaned up.
IncorrectParameterException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Incorrect parameters (operations are absolutely not executed).
incReads() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
increment - Variable in class org.apache.bookkeeper.streaming.LedgerInputStream
 
INCREMENTAL - com.scurrilous.circe.HashSupport
Indicates that the hash algorithm is available as an incremental stateful hash function, for which StatefulHash.supportsIncremental() returns true.
IncrementalIntHash - Interface in com.scurrilous.circe
Incremental stateless integer hash function, which has the property that its output is the same as (or easily derivable from) its state.
IncrementalIntStatefulHash - Class in com.scurrilous.circe.impl
 
IncrementalIntStatefulHash(AbstractIncrementalIntHash) - Constructor for class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
IncrementalLongHash - Interface in com.scurrilous.circe
Incremental stateless long integer hash function, which has the property that its output is the same as (or easily derivable from) its state.
IncrementalLongStatefulHash - Class in com.scurrilous.circe.impl
 
IncrementalLongStatefulHash(AbstractIncrementalLongHash) - Constructor for class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
incrementFailedOps() - Method in class org.apache.bookkeeper.proto.BKStats.OpStats
Increment number of failed operations.
incrementVersion() - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.MetadataVersion
 
index - Variable in class org.apache.bookkeeper.slogger.AbstractSlogger.CtxIterator
 
index(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListFilesOnDiscCommand.LFODFlags
 
INDEX_DIRS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
INDEX_INMEM_ILLEGAL_STATE_DELETE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
INDEX_INMEM_ILLEGAL_STATE_RESET - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
indexDirectories - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
indexDirs(String) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand.Flags
 
INDEXDIRS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
indexDirsManager(LedgerDirsManager) - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
 
IndexInMemPageMgr - Class in org.apache.bookkeeper.bookie
 
IndexInMemPageMgr(int, int, ServerConfiguration, IndexPersistenceMgr, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
IndexInMemPageMgrStats - Class in org.apache.bookkeeper.bookie.stats
A umbrella class for IndexInMemPageMgr stats.
IndexInMemPageMgrStats(StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.stats.IndexInMemPageMgrStats
 
indexOf(int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
Index of a specified bookie index.
indexOf(int, int, byte) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
IndexPersistenceMgr - Class in org.apache.bookkeeper.bookie
A IndexPersistenceMgr is responsible for managing the persistence state for the index in a bookie.
IndexPersistenceMgr(int, int, ServerConfiguration, SnapshotMap<Long, Boolean>, LedgerDirsManager, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
IndexPersistenceMgrStats - Class in org.apache.bookkeeper.bookie.stats
A umbrella class for IndexPersistenceMgr stats.
IndexPersistenceMgrStats(StatsLogger, Supplier<Number>, Supplier<Number>) - Constructor for class org.apache.bookkeeper.bookie.stats.IndexPersistenceMgrStats
 
info() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand
 
info(Enum<?>) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
info(Enum<?>) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
info(Enum<?>) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
info(Enum<?>, Throwable) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
info(Enum<?>, Throwable) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
info(Enum<?>, Throwable) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
info(String) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
info(String) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
info(String) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
info(String, Throwable) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
info(String, Throwable) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
info(String, Throwable) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
INFO - org.apache.bookkeeper.slogger.AbstractSlogger.Level
 
InfoCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
A bookie command to retrieve bookie info.
InfoCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.InfoCommand
 
init() - Method in class org.apache.bookkeeper.bookie.LedgerDirsMonitor
Sweep through all the directories to check disk errors or disk full.
init(byte, byte, int, long, long) - Method in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
init(byte, byte, long, long, short, byte[]) - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
init(AuthCallbacks.GenericCallback<AuthToken>) - Method in interface org.apache.bookkeeper.auth.ClientAuthProvider
Initiate the authentication.
init(AuthCallbacks.GenericCallback<AuthToken>) - Method in class org.apache.bookkeeper.sasl.SASLClientAuthProvider
 
init(ClientConfiguration) - Method in interface org.apache.bookkeeper.auth.ClientAuthProvider.Factory
Initialize the factory with the client configuration and protobuf message registry.
init(ClientConfiguration) - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
init(ServerConfiguration) - Method in interface org.apache.bookkeeper.auth.BookieAuthProvider.Factory
Initialize the factory with the server configuration and protobuf message registry.
init(ServerConfiguration) - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
init(ServerConfiguration) - Method in class org.apache.bookkeeper.tls.BookieAuthZFactory
 
init(SecurityHandlerFactory.NodeType, AbstractConfiguration, ByteBufAllocator) - Method in interface org.apache.bookkeeper.tls.SecurityHandlerFactory
 
init(SecurityHandlerFactory.NodeType, AbstractConfiguration, ByteBufAllocator) - Method in class org.apache.bookkeeper.tls.TLSContextFactory
 
init(Configuration, int) - Method in class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
init(Configuration, int) - Method in interface org.apache.bookkeeper.metastore.MetaStore
Initialize the meta store.
init(T, BookieRequestHandler, BookieRequestProcessor) - Method in class org.apache.bookkeeper.proto.PacketProcessorBase
 
initBookie(ServerConfiguration) - Static method in class org.apache.bookkeeper.client.BookKeeperAdmin
Initializes bookie, by making sure that the journalDir, ledgerDirs and indexDirs are empty and there is no registered Bookie with this BookieId.
InitBookieCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.InitBookieCmd
 
InitCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
A command to initialize new bookie.
InitCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Intializes new cluster by creating required znodes for the cluster.
InitCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.InitCommand
 
InitCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.InitCommand
 
initial() - Method in class com.scurrilous.circe.crc.AbstractIntCrc
 
initial() - Method in class com.scurrilous.circe.crc.AbstractLongCrc
 
initial() - Method in class com.scurrilous.circe.crc.ReflectedIntCrc
 
initial() - Method in class com.scurrilous.circe.crc.ReflectedLongCrc
 
initial() - Method in class com.scurrilous.circe.crc.Sse42Crc32C
 
initial() - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
The initial state of the hash function, which is the same as the output value for an empty input sequence.
initial() - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
The initial state of the hash function, which is the same as the output value for an empty input sequence.
initial() - Method in class com.scurrilous.circe.params.CrcParameters
Returns the initial value of the CRC register.
initialBlockingBookieRead() - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
Blocks until bookies are read from zookeeper, used in the BookKeeper constructor.
initialize() - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
initialize() - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientPool
initialize the pool.
initialize(File, File, int, int) - Method in interface org.apache.bookkeeper.shims.zk.ZooKeeperServerShim
Initialize zookeeper server.
initialize(File, File, int, int) - Method in class org.apache.bookkeeper.shims.zk.ZooKeeperServerShimImpl
 
initialize(AbstractConfiguration<?>, StatsLogger, RetryPolicy, Optional<Object>) - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
initialize(AbstractConfiguration, LayoutManager, int) - Method in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
initialize(AbstractConfiguration, LayoutManager, int) - Method in interface org.apache.bookkeeper.meta.LedgerManagerFactory
Initialize a factory.
initialize(AbstractConfiguration, LayoutManager, int) - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
initialize(AbstractConfiguration, LayoutManager, int) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
initialize(AbstractConfiguration, LayoutManager, int) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
initialize(ClientConfiguration, ScheduledExecutorService, StatsLogger, Optional<Object>) - Method in interface org.apache.bookkeeper.meta.MetadataClientDriver
Initialize the metadata driver.
initialize(ClientConfiguration, ScheduledExecutorService, StatsLogger, Optional<Object>) - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
initialize(ClientConfiguration, Optional<DNSToSwitchMapping>, HashedWheelTimer, FeatureProvider, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
initialize(ClientConfiguration, Optional<DNSToSwitchMapping>, HashedWheelTimer, FeatureProvider, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
initialize(ClientConfiguration, Optional<DNSToSwitchMapping>, HashedWheelTimer, FeatureProvider, StatsLogger, BookieAddressResolver) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Initialize the policy.
initialize(ClientConfiguration, Optional<DNSToSwitchMapping>, HashedWheelTimer, FeatureProvider, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
initialize(ClientConfiguration, Optional<DNSToSwitchMapping>, HashedWheelTimer, FeatureProvider, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
initialize(ClientConfiguration, Optional<DNSToSwitchMapping>, HashedWheelTimer, FeatureProvider, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicy
 
initialize(ClientConfiguration, Optional<DNSToSwitchMapping>, HashedWheelTimer, FeatureProvider, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
initialize(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, StatsLogger, ByteBufAllocator) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
initialize(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, StatsLogger, ByteBufAllocator) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Initialize the LedgerStorage implementation.
initialize(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, StatsLogger, ByteBufAllocator) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
initialize(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, StatsLogger, ByteBufAllocator) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
initialize(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, StatsLogger, ByteBufAllocator) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
initialize(ServerConfiguration, StatsLogger) - Method in interface org.apache.bookkeeper.meta.MetadataBookieDriver
Initialize the metadata driver.
initialize(ServerConfiguration, StatsLogger) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver
 
initialize(ServerConfiguration, StatsLogger) - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataBookieDriver
 
initialize(DNSToSwitchMapping, HashedWheelTimer, boolean, int, int, boolean, int, int, boolean, boolean, boolean, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
initialize(DNSToSwitchMapping, HashedWheelTimer, boolean, int, int, boolean, int, int, boolean, boolean, boolean, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
Initialize the policy.
initialize(DNSToSwitchMapping, HashedWheelTimer, boolean, int, int, boolean, int, int, boolean, boolean, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
initialize(DNSToSwitchMapping, HashedWheelTimer, boolean, int, int, boolean, int, int, boolean, boolean, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
Initialize the policy.
initialized() - Method in class org.apache.bookkeeper.common.component.Lifecycle
Returns true if the state is initialized.
INITIALIZED - org.apache.bookkeeper.common.component.Lifecycle.State
 
initializeEnsemblePlacementPolicy(ClientConfiguration, DNSToSwitchMapping, HashedWheelTimer, FeatureProvider, StatsLogger, BookieAddressResolver) - Method in class org.apache.bookkeeper.client.BookKeeper
 
initializeLostBookieRecoveryDelay(int) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Creates the zNode for lostBookieRecoveryDelay with the specified value and returns true.
initializeLostBookieRecoveryDelay(int) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
initializeLostBookieRecoveryDelay(int) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
initializeStateManager() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
initializeThread(Map<String, String>) - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
initializeThread(Map<String, String>) - Method in class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
 
initializeWithEntryLogger(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, EntryLogger, StatsLogger) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
initializeWithEntryLogListener(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, DefaultEntryLogger.EntryLogListener, StatsLogger, ByteBufAllocator) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
initializeWriteHandleState() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
initializeWriteHandleState() - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
initiate() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgersIndexCheckOp
 
initiate() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgersIndexRebuildOp
 
initiate() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LocationsIndexRebuildOp
 
initiate() - Method in class org.apache.bookkeeper.client.BatchedReadOp
 
initiate() - Method in class org.apache.bookkeeper.client.ForceLedgerOp
 
initiate() - Method in class org.apache.bookkeeper.client.LedgerCreateOp
Initiates the operation.
initiate() - Method in class org.apache.bookkeeper.client.LedgerDeleteOp
Initiates the operation.
initiate() - Method in class org.apache.bookkeeper.client.LedgerOpenOp
Inititates the ledger open operation.
initiate() - Method in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
initiate() - Method in class org.apache.bookkeeper.client.PendingAddOp
Initiate the add operation.
initiate() - Method in class org.apache.bookkeeper.client.PendingReadLacOp
 
initiate() - Method in class org.apache.bookkeeper.client.PendingReadOp
 
initiate() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
initiate() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedOp
 
initiate() - Method in class org.apache.bookkeeper.client.ReadOpBase
 
initiate() - Method in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
initiate(boolean) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp
 
initiate(ByteBufList) - Method in class org.apache.bookkeeper.client.PendingWriteLacOp
 
initiateAdv(long) - Method in class org.apache.bookkeeper.client.LedgerCreateOp
Initiates the operation to return LedgerHandleAdv.
initiateSpeculativeRequest(ScheduledExecutorService, SpeculativeRequestExecutor) - Method in class org.apache.bookkeeper.client.DefaultSpeculativeRequestExecutionPolicy
Initialize the speculative request execution policy.
initiateSpeculativeRequest(ScheduledExecutorService, SpeculativeRequestExecutor) - Method in interface org.apache.bookkeeper.client.SpeculativeRequestExecutionPolicy
Initialize the speculative request execution policy and initiate requests.
initiateWithFencing() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedOp
 
initiateWithoutRecovery() - Method in class org.apache.bookkeeper.client.LedgerOpenOp
Inititates the ledger open operation without recovery.
initIfNecessary() - Method in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
initNanos - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.TimedCallable
 
initNanos - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.TimedRunnable
 
initNewCluster() - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Initializes new cluster by creating required znodes for the cluster.
initNewCluster() - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
initNewCluster() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
initNewCluster(ServerConfiguration) - Static method in class org.apache.bookkeeper.client.BookKeeperAdmin
Intializes new cluster by creating required znodes for the cluster.
InitNewCluster() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.InitNewCluster
 
initState() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
initState() - Method in interface org.apache.bookkeeper.bookie.StateManager
Init state of Bookie when launch bookie.
initTLSHandshake() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
InMemoryEntryLogMetadataMap - Class in org.apache.bookkeeper.bookie
In-memory metadata-store to store entry-log metadata-map in memory-map.
InMemoryEntryLogMetadataMap() - Constructor for class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
InMemoryMetaStore - Class in org.apache.bookkeeper.metastore
An in-memory implementation of the MetaStore interface.
InMemoryMetaStore() - Constructor for class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
InMemoryMetastoreCursor - Class in org.apache.bookkeeper.metastore
 
InMemoryMetastoreCursor(SortedMap<String, Versioned<Value>>, Set<String>, ScheduledExecutorService) - Constructor for class org.apache.bookkeeper.metastore.InMemoryMetastoreCursor
 
InMemoryMetastoreTable - Class in org.apache.bookkeeper.metastore
An in-memory implementation of a Metastore table.
InMemoryMetastoreTable(InMemoryMetaStore, String) - Constructor for class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
InMemoryMetastoreTable.MetadataVersion - Class in org.apache.bookkeeper.metastore
An implementation of the Version interface for metadata.
InMemoryMetastoreTable.Result<T> - Class in org.apache.bookkeeper.metastore
 
InnerNode(String) - Constructor for class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Construct an InnerNode from a path-like string.
InnerNode(String, String) - Constructor for class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Construct an InnerNode from its name and its network location.
InnerNode(String, String, NetworkTopologyImpl.InnerNode, int) - Constructor for class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Construct an InnerNode from its name, its network location, its parent, and its level.
instance - Static variable in class org.apache.bookkeeper.client.LedgerHandle.NoopCloseCallback
 
INSTANCE - Static variable in class org.apache.bookkeeper.client.SyncCallbackUtils.LastAddConfirmedCallback
 
INSTANCE - Static variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.EnsembleForReplacementWithNoConstraints
 
INSTANCE - Static variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.TruePredicate
 
INSTANCE - Static variable in class org.apache.bookkeeper.stats.NullStatsLogger
 
instanceId(String) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand.Flags
 
INSTANCEID - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
INSTANCEID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
InstanceIdCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Command to print instance id of the cluster.
InstanceIdCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.InstanceIdCommand
 
instandId(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.NukeExistingClusterCommand.NukeExistingClusterFlags
 
instantiate(long, byte[], DataFormats.LedgerMetadataFormat.DigestType, ByteBufAllocator, boolean) - Static method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
INT - org.apache.bookkeeper.common.conf.Type
 
INT_SIZED - com.scurrilous.circe.HashSupport
Indicates that the hash algorithm is available as a StatefulIntHash and StatelessIntHash.
interactive(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.MetaFormatCommand.MetaFormatFlags
 
InterfaceAudience - Class in org.apache.bookkeeper.common.annotation
Annotation to inform users of a package, class or method's intended audience.
InterfaceAudience.LimitedPrivate - Annotation Type in org.apache.bookkeeper.common.annotation
Intended for use only within the project(s) specified in the annotation.
InterfaceAudience.Private - Annotation Type in org.apache.bookkeeper.common.annotation
Intended for use only within bookkeeper itself.
InterfaceAudience.Public - Annotation Type in org.apache.bookkeeper.common.annotation
Intended for use by any project or application.
InterfaceStability - Class in org.apache.bookkeeper.common.annotation
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability.Evolving - Annotation Type in org.apache.bookkeeper.common.annotation
Evolving, but can break compatibility at minor release (i.e.
InterfaceStability.Stable - Annotation Type in org.apache.bookkeeper.common.annotation
Can evolve while retaining compatibility for minor release boundaries.; can break compatibility only at major release (ie.
InterfaceStability.Unstable - Annotation Type in org.apache.bookkeeper.common.annotation
No guarantee is provided as to reliability or stability across any level of release granularity.
InterleavedLedgerStorage - Class in org.apache.bookkeeper.bookie
Interleave ledger storage.
InterleavedLedgerStorage() - Constructor for class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
InterleavedStorageRegenerateIndexOp - Class in org.apache.bookkeeper.bookie
Scan all entries in the entry log and rebuild the index file for one ledger.
InterleavedStorageRegenerateIndexOp(ServerConfiguration, Set<Long>, byte[]) - Constructor for class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp
 
InterleavedStorageRegenerateIndexOp.DryRunLedgerCache - Class in org.apache.bookkeeper.bookie
 
InterleavedStorageRegenerateIndexOp.RecoveryStats - Class in org.apache.bookkeeper.bookie
 
internalBuilder() - Static method in class org.apache.bookkeeper.common.conf.ConfigKey
 
internalBuilder() - Static method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
 
internalConf - Variable in class org.apache.bookkeeper.client.BookKeeper
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
internalGetMapField(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
internalGetMapField(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
internalGetMutableMapField(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
internalGetValueMap() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
 
internalGetValueMap() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
 
internalGetValueMap() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
 
internalGetValueMap() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
 
internalGetValueMap() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
 
internalGetValueMap() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
 
internalGetValueMap() - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
 
internalGetValueMap() - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
 
internalNioBuffer(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
internalUpdate(int, byte[], int, int) - Method in class org.apache.bookkeeper.proto.checksum.CRC32CDigestManager
 
internalUpdate(int, byte[], int, int) - Method in class org.apache.bookkeeper.proto.checksum.CRC32DigestManager
 
internalUpdate(int, byte[], int, int) - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
internalUpdate(int, byte[], int, int) - Method in class org.apache.bookkeeper.proto.checksum.DummyDigestManager
 
internalUpdate(int, byte[], int, int) - Method in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
internalUpdate(int, ByteBuf, int, int) - Method in class org.apache.bookkeeper.proto.checksum.CRC32CDigestManager
 
internalUpdate(int, ByteBuf, int, int) - Method in class org.apache.bookkeeper.proto.checksum.CRC32DigestManager
 
internalUpdate(int, ByteBuf, int, int) - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
internalUpdate(int, ByteBuf, int, int) - Method in class org.apache.bookkeeper.proto.checksum.DummyDigestManager
 
internalUpdate(int, ByteBuf, int, int) - Method in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
InterruptedException - org.apache.bookkeeper.metastore.MSException.Code
 
InterruptedException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Synchronous operations are interrupted.
interruptThread() - Method in class org.apache.bookkeeper.bookie.Journal
 
interval() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityService
 
intervalUnit() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityService
 
IntHash - Interface in com.scurrilous.circe.checksum
 
IntStatefulLongHash - Class in com.scurrilous.circe.impl
IntStatefulLongHash(StatefulIntHash) - Constructor for class com.scurrilous.circe.impl.IntStatefulLongHash
Constructs a new IntStatefulLongHash that delegates to the given StatefulIntHash.
IntStatelessLongHash - Class in com.scurrilous.circe.impl
IntStatelessLongHash(StatelessIntHash) - Constructor for class com.scurrilous.circe.impl.IntStatelessLongHash
Constructs a new IntStatelessLongHash that delegates to the given StatelessIntHash.
inUse() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
INVALID_CONF - Static variable in class org.apache.bookkeeper.bookie.ExitCode
 
INVALID_ENTRY_ID - Static variable in class org.apache.bookkeeper.client.LedgerHandle
Invalid entry id.
INVALID_ENTRY_ID - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Entry Entry ID.
INVALID_ENTRYID - Static variable in class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
INVALID_LEDGER_ID - Static variable in class org.apache.bookkeeper.client.LedgerHandle
Invalid ledger id.
INVALID_LID - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
INVALID_LID - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.LogMetadata
 
INVALID_METADATA - org.apache.bookkeeper.bookie.datainteg.Events
Preboot found an invalid ledger metadata.
INVALID_METADATA_SERVICE_URI - org.apache.bookkeeper.meta.exceptions.Code
 
invalidateBlacklist(Channel) - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
invalidateLedgerIdGenPathStatus() - Method in class org.apache.bookkeeper.meta.LongZkLedgerIdGenerator
 
InvalidCookieException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
InvalidCookieException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.InvalidCookieException
 
InvalidCookieException(String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.InvalidCookieException
 
InvalidCookieException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.InvalidCookieException
 
InvalidEntryLengthException(long, long, long, long) - Constructor for exception org.apache.bookkeeper.bookie.DefaultEntryLogger.EntryLookupException.InvalidEntryLengthException
 
InvalidFragmentException() - Constructor for exception org.apache.bookkeeper.client.LedgerChecker.InvalidFragmentException
 
InvalidTopologyException(String) - Constructor for exception org.apache.bookkeeper.net.NetworkTopologyImpl.InvalidTopologyException
 
INVERSE - Static variable in class org.apache.bookkeeper.net.NetworkTopologyImpl
 
invocationCount - Variable in class org.apache.bookkeeper.bookie.BufferedReadChannel
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.bookkeeper.common.util.BoundedExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.BoundedExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.bookkeeper.common.util.BoundedExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.BoundedExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
IOUtils - Class in org.apache.bookkeeper.util
An utility class for I/O related functionality.
IOUtils() - Constructor for class org.apache.bookkeeper.util.IOUtils
 
ip(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand.AdminFlags
 
IS_FORCE_GC_ALLOW_WHEN_NO_SPACE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
IS_THROTTLE_BY_BYTES - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
isAdheringToPolicy() - Method in class org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementResult
Deprecated.
isAligned(long) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
isAlive() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
isAllowMultipleDirsUnderSameDiskPartition() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
returns whether it is allowed to have multiple ledger/index/journal Directories in the same filesystem diskpartition.
isAncestor(Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Judge if this node is an ancestor of node n.
isArrayAllZeros(byte[]) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.ArrayUtil
 
isAuditorElected() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
isAuditorElected() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
isAuthenticated() - Method in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler
 
isAutoRecoveryDaemonEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether the Bookie itself can start auto-recovery service also or not.
isAutoRecoveryRunning() - Method in class org.apache.bookkeeper.replication.AutoRecoveryMain
Is auto-recovery service running?
isAvailable() - Static method in class org.apache.bookkeeper.common.util.affinity.impl.CpuAffinityJni
 
isAvailable() - Method in interface org.apache.bookkeeper.feature.Feature
Whether this feature is available or not.
isAvailable() - Method in class org.apache.bookkeeper.feature.FixedValueFeature
 
isAvailableForHighPriorityWrites() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
isAvailableForHighPriorityWrites() - Method in class org.apache.bookkeeper.bookie.BookieImpl
Check whether Bookie is available for high priority writes.
isAvailableForHighPriorityWrites() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
isAvailableForHighPriorityWrites() - Method in interface org.apache.bookkeeper.bookie.StateManager
Check if the bookie is available for high priority writes or not.
isAvailableForHighPriorityWrites() - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
isBatchReadEnabled() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
 
isBlacklisted(Channel) - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
isBookieAddressTracking() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
isBookieHealthCheckEnabled() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Check if bookie health check is enabled.
isBookieHostCreatedFromIp() - Method in class org.apache.bookkeeper.bookie.Cookie
Check whether the 'bookieHost' was created using a hostname or an IP address.
isBookieRegistered(BookieId) - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Checks if Bookie with the given BookieId is registered as readwrite or readonly bookie.
isBookieRegistered(BookieId) - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
isBookieRegistered(BookieId) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
isBookieRunning() - Method in class org.apache.bookkeeper.proto.BookieServer
Whether bookie is running?
isBookieUnavailable(BookieId) - Method in interface org.apache.bookkeeper.client.BookieWatcher
Determine if a bookie should be considered unavailable.
isBookieUnavailable(BookieId) - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
Determine if a bookie should be considered unavailable.
isBusyWaitEnabled() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Return whether the busy-wait is enabled for BookKeeper and Netty IO threads.
isClean() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
isClientClosed() - Method in interface org.apache.bookkeeper.client.ClientContext
 
isClosed - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
isClosed() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
isClosed() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
isClosed() - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogReader
 
isClosed() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Returns whether the ledger is sealed or not.
isClosed() - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Returns whether the ledger is sealed or not.
isClosed() - Method in class org.apache.bookkeeper.client.BookKeeper
 
isClosed() - Method in class org.apache.bookkeeper.client.LedgerFragment
Returns true, if and only if the ledger fragment will never be modified by any of the clients in future, otherwise false.
isClosed() - Method in class org.apache.bookkeeper.client.LedgerHandle
Returns whether the ledger is sealed or not.
isClosed() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
isClosed() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
isClosed() - Method in interface org.apache.bookkeeper.proto.BookieClient
 
isClosed() - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
isClosed() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
isClosed(long) - Method in class org.apache.bookkeeper.client.BookKeeper
Check whether the ledger with identifier lId has been closed.
isClosedComplete(int, boolean, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.IsClosedCallback
Callback definition for isClosed operation.
isClusterUnderReplicated() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
isClusterUnderReplicated() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
isCommandGroup() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
isCompacting() - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
isComplete() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
Whether the read request completed.
isComplete() - Method in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
Whether the read request completed.
isComplete() - Method in class org.apache.bookkeeper.sasl.SaslClientState
 
isComplete() - Method in class org.apache.bookkeeper.sasl.SaslServerState
 
isDataIntegrityCheckingEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
isDataIntegrityStampMissingCookiesEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
isDeleted() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
isDeleted() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
isDirect() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
isDirectBufferPooled() - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorImpl
 
isDirFull(File) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Get dirs, which are full more than threshold.
isDirWritableForNewIndexFile(File) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
 
isDisableServerSocketBind() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether to disable bind of server-side sockets.
isDummyBookieIdForHostname(BookieId) - Static method in class org.apache.bookkeeper.net.BookieSocketAddress
Tells whether a BookieId may be a dummy id.
isEmpty() - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
isEmpty() - Method in interface org.apache.bookkeeper.bookie.EntryLogMetadataMap
Returns true if there are no elements in the map.
isEmpty() - Method in class org.apache.bookkeeper.bookie.EntryMemTable
Check if there is data in the mem-table.
isEmpty() - Method in class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
isEmpty() - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
isEmpty() - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
isEmpty() - Method in class org.apache.bookkeeper.common.conf.ConcurrentConfiguration
 
isEmpty() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
isEmpty() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
isEmpty() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
isEmpty() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
isEmpty() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
isEmpty() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
isEnableLocalTransport() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether to listen for local JVM clients.
isEnsembleAdheringToPlacementPolicy(List<BookieId>, int, int) - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
isEnsembleAdheringToPlacementPolicy(List<BookieId>, int, int) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
returns boolean value specifying if the ensemble of the segment is adhering to the ensemble placement policy for the given writeQuorumSize and ackQuorumSize.
isEnsembleAdheringToPlacementPolicy(List<BookieId>, int, int) - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
isEnsembleAdheringToPlacementPolicy(List<BookieId>, int, int) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
returns AdherenceLevel if the Ensemble is strictly/softly/fails adhering to placement policy, like in the case of RackawareEnsemblePlacementPolicy, bookies in the writeset are from 'minNumRacksPerWriteQuorum' number of racks.
isEnsembleAdheringToPlacementPolicy(List<BookieId>, int, int) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
isEnsembleAdheringToPlacementPolicy(List<BookieId>, int, int) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
isEnsembleAdheringToPlacementPolicy(List<BookieId>, int, int) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
isEntryAvailable(long) - Method in class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
isEntryLocationCompacting() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
isEntryLocationCompacting() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
isEntryLocationCompacting() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
isEntryLocationCompacting(List<String>) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
isEntryLocationCompacting(List<String>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
isEntryLogFilePreAllocationEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Is entry log file preallocation enabled.
isEntryLogPerLedgerEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
isEntryMissing(WriteSets, NavigableMap<Long, Integer>, long, long) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
isError() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult
 
isFenced() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
isFenced() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
isFenced() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
isFenced(long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
isFenced(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
isFenced(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
isFenced(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
isFenced(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
isFenced(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Check whether the ledger is fenced in ledger storage or not.
isFenced(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
isFenced(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
isFenced(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
isFenceRequest(BookkeeperProtocol.ReadRequest) - Static method in class org.apache.bookkeeper.proto.RequestUtils
 
isFencing() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadRequest
 
isFlushedLogId(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.RecentEntryLogsStatus
 
isFlushRequired() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
isFlushRequired() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
isForceAllowCompaction() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
The force compaction is allowed or not when disabling the entry log compaction.
isForceCompacting() - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
isForceGCAllowWhenNoSpace - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
isForceGCAllowWhenNoSpace() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
isForceMajorCompactionAllow - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
isForceMinorCompactionAllow - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
isForceReadOnly() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
isForceReadOnly() - Method in interface org.apache.bookkeeper.bookie.StateManager
Check is forceReadOnly.
isForceReadOnlyBookie() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether the Bookie is force started in read only mode or not.
isGcEntryLogMetadataCacheEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether the bookie is configured to use persistent entrylogMetadataMap.
isHandleWritable() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
isHealthCheckEnabled() - Method in interface org.apache.bookkeeper.meta.MetadataBookieDriver
Return health check is enable or disable.
isHealthCheckEnabled() - Method in interface org.apache.bookkeeper.meta.MetadataClientDriver
Return health check is enable or disable.
isHealthCheckEnabled() - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
isHighPriority() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
isHighPriority(BookkeeperProtocol.Request) - Static method in class org.apache.bookkeeper.proto.RequestUtils
 
isHttpServerEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether to start the http server or not.
isHttpServerTlsEnable() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get if Http Server Tls enable.
isInForceGC() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
isInForceGC() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
isInForceGC() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Whether force triggered Garbage Collection is running or not.
isInForceGC() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
isInForceGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
isInForceGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
isInitialized() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
isInitialized() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
isInReadOnlyMode() - Method in class org.apache.bookkeeper.bookie.BookieStatus
 
isInt32Digest() - Method in class org.apache.bookkeeper.proto.checksum.CRC32CDigestManager
 
isInt32Digest() - Method in class org.apache.bookkeeper.proto.checksum.CRC32DigestManager
 
isInt32Digest() - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
isInt32Digest() - Method in class org.apache.bookkeeper.proto.checksum.DummyDigestManager
 
isInt32Digest() - Method in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
isInWritable() - Method in class org.apache.bookkeeper.bookie.BookieStatus
 
isLeadgerIdGeneratorZnode(String) - Static method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
isLeafParent() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
 
isLedgerBeingReplicated(long) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Check whether the ledger is being replicated by any bookie.
isLedgerBeingReplicated(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
isLedgerBeingReplicated(long) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
Check whether the ledger is being replicated by any bookie.
isLedgerParentNode(String) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
whether the child of ledgersRootPath is a top level parent znode for ledgers (in HierarchicalLedgerManager) or znode of a ledger (in FlatLedgerManager).
isLedgerReplicationEnabled() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Check whether the ledger replication is enabled or not.
isLedgerReplicationEnabled() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
isLedgerReplicationEnabled() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
isLedgerReplicationEnabled() - Method in class org.apache.bookkeeper.replication.AuditorTask
 
isLedgerReplicationEnabled() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
isLedgerReplicationEnabled() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
isLocalBookie(BookieId) - Static method in class org.apache.bookkeeper.proto.LocalBookiesRegistry
 
isLocalConsistencyCheckOnStartup() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
True if a local consistency check should be performed on startup.
isLocalScrubEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether local scrub is enabled.
isLongPollReadRequest(BookkeeperProtocol.ReadRequest) - Static method in class org.apache.bookkeeper.proto.RequestUtils
 
isMajorCompacting() - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
isMajorGcSuspend() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
isMajorGcSuspended() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
isMajorGcSuspended() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
isMajorGcSuspended() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
isMajorGcSuspended() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
isMajorGcSuspended() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
isMappingSingleSwitch(DNSToSwitchMapping) - Static method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
Query for a DNSToSwitchMapping instance being on a single switch.
isMinorCompacting() - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
isMinorGcSuspend() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
isMinorGcSuspended() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
isMinorGcSuspended() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
isMinorGcSuspended() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
isMinorGcSuspended() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
isMinorGcSuspended() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
isMissing() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult
 
isNettyUsePooledBuffers() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
isNodeGroupAware() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Check if network topology is aware of NodeGroup.
isOK() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult
 
IsolatedProcessors - Class in org.apache.bookkeeper.common.util.affinity.impl
 
isOnSameNodeGroup(Node, Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Return false directly as not aware of NodeGroup, to be override in sub-class.
isOnSameRack(Node, Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Check if two nodes are on the same rack.
isParent(Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Judge if this node is the parent of node n.
isPassed() - Method in class org.apache.bookkeeper.server.http.service.BookieSanityService.BookieSanity
 
isPersistBookieStatusEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether to persist the bookie status so that when bookie server restarts, it will continue using the previous status.
isPreserveMdcForTaskExecution() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
isRack() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Judge if this node represents a rack.
isReadable() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
isReadable(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
isReadOnly() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
isReadOnly() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
isReadOnly() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
isReadOnly() - Method in interface org.apache.bookkeeper.bookie.StateManager
Check is ReadOnly.
isReadOnly() - Method in class org.apache.bookkeeper.server.http.service.BookieSanityService.BookieSanity
 
isReadOnly() - Method in class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService.ReadOnlyState
 
isReadOnly() - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
isReadOnly() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
isReadOnlyModeEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether read-only mode is enabled.
isReadOnlyModeOnAnyDiskFullEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get whether read-only mode is enable when any disk is full.
isReadWorkerThreadsThrottlingEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get the auto-throttling status of the read-worker threads.
isRecoverableException(int) - Static method in class org.apache.bookkeeper.zookeeper.ZooWorker
Check whether the given result code is recoverable by retry.
isRecoverableException(KeeperException) - Static method in class org.apache.bookkeeper.zookeeper.ZooWorker
Check whether the given exception is recoverable by retry.
isRecoveryAdd - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
isRecoveryAdd() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ParsedAddRequest
 
isRecoveryBatchReadEnabled() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
If recovery batch read enabled or not.
isRecoveryRead - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
isRegistered() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
isReorderReadSequenceEnabled() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
If reorder read sequence enabled or not.
isRepairedPlacementPolicyNotAdheringBookieEnable() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Now the feature only support RackawareEnsemblePlacementPolicy.
isRoot() - Static method in class org.apache.bookkeeper.common.util.affinity.impl.CpuAffinityJni
 
isRunning - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
isRunning() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
isRunning() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
isRunning() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
isRunning() - Method in interface org.apache.bookkeeper.bookie.StateManager
Check is Running.
isRunning() - Method in class org.apache.bookkeeper.proto.BookieNettyServer
 
isRunning() - Method in class org.apache.bookkeeper.proto.BookieServer
 
isRunning() - Method in class org.apache.bookkeeper.replication.Auditor
Return true if auditor is running otherwise return false.
isRunning() - Method in class org.apache.bookkeeper.replication.AuditorElector
If current bookie is running as auditor, return the status of the auditor.
isRunning() - Method in class org.apache.bookkeeper.replication.ReplicationWorker
Gives the running status of ReplicationWorker.
isRunning() - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
isSameFile(File) - Method in class org.apache.bookkeeper.bookie.FileInfo
 
isSameParents(Node, Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Compare the parents of each node for equality.
isSanityCheckMetricsEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Flag to enable sanity check metrics in bookie stats.
isSealed(long) - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
isSecure() - Method in interface org.apache.bookkeeper.proto.ConnectionPeer
This flag returns true if a 'secure' channel in use, like TLS.
isShadedLedgerManagerFactoryClassAllowed() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Is shaded ledger manager factory class name allowed to be used for instantiating ledger manager factory.
isShutdown() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
isShutdown() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
isShuttingDown() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
isShuttingDown() - Method in interface org.apache.bookkeeper.bookie.StateManager
Check is Shutting down.
isShuttingDown() - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
isSingleSwitch() - Method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
Predicate that indicates that the switch mapping is known to be single-switch.
isSingleSwitch() - Method in class org.apache.bookkeeper.net.CachedDNSToSwitchMapping
Delegate the switch topology query to the raw mapping, via AbstractDNSToSwitchMapping.isMappingSingleSwitch(DNSToSwitchMapping).
isSingleSwitchByScriptPolicy() - Method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
 
isSizeLimitReached() - Method in class org.apache.bookkeeper.bookie.EntryMemTable
Check if the entire heap usage for this EntryMemTable exceeds limit.
isSkipReplayJournalInvalidRecord() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
isSpecialZnode(String) - Static method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
Whether the znode a special znode.
isSpecialZnode(String) - Static method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
Whether the znode a special znode.
isStale() - Method in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
isStatisticsEnabled() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Is statistics enabled.
isStatsEnabled() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
isStickyReadsEnabled() - Method in class org.apache.bookkeeper.conf.ClientConfiguration
If read operation should be sticky to a single bookie or not.
isStoredEntryId(long, int) - Method in class org.apache.bookkeeper.client.LedgerFragment
 
issueSpeculativeRequest() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
Speculative Read Logic.
issueSpeculativeRequest() - Method in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
Issues a speculative request and indicates if more speculative requests should be issued.
issueSpeculativeRequest() - Method in interface org.apache.bookkeeper.client.SpeculativeRequestExecutor
Issues a speculative request and indicates if more speculative requests should be issued.
isSupported() - Static method in class com.scurrilous.circe.crc.Sse42Crc32C
Returns whether SSE 4.2 CRC-32C is supported on this system.
isSupported() - Static method in class org.apache.bookkeeper.proto.checksum.DirectMemoryCRC32Digest
 
isTentativeToRemove() - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology.NodeStatus
 
isTerminated() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
isTerminated() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
isThreadInitialized() - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
isThreadInitialized() - Method in class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
 
isThrottleReadResponses() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
isTimedOut() - Method in class org.apache.bookkeeper.util.Shell
To check if the passed script to shell command executor timed out or not.
isUseTargetEntryLogSizeForGc() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
isUsingTicketCache() - Method in interface org.apache.bookkeeper.sasl.JAASCredentialsContainer
 
isUsingTicketCache() - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
isUsingTicketCache() - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
isUsingTicketCache(String) - Static method in class org.apache.bookkeeper.sasl.SaslConstants
 
isVersionCompatible() - Method in class org.apache.bookkeeper.proto.PacketProcessorBase
 
isVersionCompatible() - Method in class org.apache.bookkeeper.proto.PacketProcessorBaseV3
 
isWeighted - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
isWritable() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
isWritable() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
isWritable(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
isWritable(long) - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
isWritable(long) - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientPool
Returns status of a client.
isWritable(BookieId, long) - Method in interface org.apache.bookkeeper.proto.BookieClient
Check whether the channel used to write to a bookie channel is writable.
isWritable(BookieId, long) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
isZkEnableSecurity() - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Are z-node created with strict ACLs.
items() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
iter - Variable in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
iterator() - Static method in class com.scurrilous.circe.HashProviders
Returns an iterator over all known HashProvider instances.
iterator() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Return an iterator object that can be used to sequentially scan through all the entries in the database.
iterator() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
iterator() - Method in interface org.apache.bookkeeper.client.api.LedgerEntries
Get an iterator over all the ledger entries contained in the LedgerEntries object.
iterator() - Method in interface org.apache.bookkeeper.client.api.ListLedgersResult
Creates a LedgersIterator.
iterator() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterable
 
iterator() - Method in class org.apache.bookkeeper.client.impl.LedgerEntriesImpl
Get an iterator over all the ledger entries contained in the LedgerEntries object.
iterator() - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
iterator() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
iterator() - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
IteratorUtility - Class in org.apache.bookkeeper.util
Utility class to merge iterators.
IteratorUtility() - Constructor for class org.apache.bookkeeper.util.IteratorUtility
 
ITopologyAwareEnsemblePlacementPolicy<T extends Node> - Interface in org.apache.bookkeeper.client
Interface for topology aware ensemble placement policy.
ITopologyAwareEnsemblePlacementPolicy.Ensemble<T extends Node> - Interface in org.apache.bookkeeper.client
Ensemble used to hold the result of an ensemble selected for placement.
ITopologyAwareEnsemblePlacementPolicy.Predicate<T extends Node> - Interface in org.apache.bookkeeper.client
Predicate used when choosing an ensemble.

J

JAAS_AUDITOR_SECTION_NAME - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
JAAS_BOOKIE_SECTION_NAME - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
JAAS_CLIENT_ALLOWED_IDS - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
This is a regexp which limits the range of possible ids which can connect to the Bookie using SASL.
JAAS_CLIENT_ALLOWED_IDS_DEFAULT - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
JAAS_CLIENT_SECTION_NAME - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
JAAS_DEFAULT_AUDITOR_SECTION_NAME - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
JAAS_DEFAULT_BOOKIE_SECTION_NAME - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
JAAS_DEFAULT_CLIENT_SECTION_NAME - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
JAASCredentialsContainer - Interface in org.apache.bookkeeper.sasl
JAAS Credentials Container.
Java8IntHash - Class in com.scurrilous.circe.checksum
 
Java8IntHash() - Constructor for class com.scurrilous.circe.checksum.Java8IntHash
 
Java9IntHash - Class in com.scurrilous.circe.checksum
 
Java9IntHash() - Constructor for class com.scurrilous.circe.checksum.Java9IntHash
 
JavaCrc32 - Class in com.scurrilous.circe.crc
Wraps CRC32 in a StatefulIntHash.
JavaCrc32() - Constructor for class com.scurrilous.circe.crc.JavaCrc32
 
JITTER_PERCENT - Static variable in class org.apache.bookkeeper.zookeeper.ExponentialBackOffWithDeadlinePolicy
 
JKS - org.apache.bookkeeper.tls.TLSContextFactory.KeyStoreType
 
jmx - Variable in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
JniIntHash - Class in com.scurrilous.circe.checksum
 
JniIntHash() - Constructor for class com.scurrilous.circe.checksum.JniIntHash
 
join() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
join() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
join() - Method in class org.apache.bookkeeper.proto.BookieServer
 
join() - Method in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
joinThread() - Method in class org.apache.bookkeeper.bookie.Journal
Wait for the Journal thread to exit.
journal(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListFilesOnDiscCommand.LFODFlags
 
Journal - Class in org.apache.bookkeeper.bookie
Provide journal related management.
Journal(int, File, ServerConfiguration, LedgerDirsManager) - Constructor for class org.apache.bookkeeper.bookie.Journal
 
Journal(int, File, ServerConfiguration, LedgerDirsManager, StatsLogger, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.bookie.Journal
 
Journal(int, File, ServerConfiguration, LedgerDirsManager, StatsLogger, ByteBufAllocator, JournalAliveListener) - Constructor for class org.apache.bookkeeper.bookie.Journal
 
JOURNAL_ADAPTIVE_GROUP_WRITES - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_ADD_ENTRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_ALIGNMENT_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_BUFFERED_ENTRIES_THRESHOLD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_BUFFERED_WRITES_THRESHOLD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_CHANNEL_PROVIDER - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_CREATION_LATENCY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_DIR - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_DIRS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_DIRS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_FLUSH_LATENCY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_FLUSH_WHEN_QUEUE_EMPTY - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_FORCE_LEDGER - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_FORCE_WRITE_BATCH_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_FORCE_WRITE_BATCH_ENTRIES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_FORCE_WRITE_ENQUEUE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_FORCE_WRITE_GROUPING_COUNT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_FORCE_WRITE_QUEUE_SIZE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_FORMAT_VERSION_TO_WRITE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_MAX_GROUP_WAIT_MSEC - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_MAX_MEMORY_SIZE_MB - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_MEMORY_MAX - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_MEMORY_USED - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_NUM_FLUSH_EMPTY_QUEUE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_NUM_FLUSH_MAX_OUTSTANDING_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_NUM_FLUSH_MAX_WAIT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_PAGECACHE_FLUSH_INTERVAL_MSEC - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_PRE_ALLOC_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_PROCESS_TIME_LATENCY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_QUEUE_LATENCY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_QUEUE_MAX_SIZE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_QUEUE_SIZE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_QUEUE_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_REMOVE_FROM_PAGE_CACHE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_REUSE_FILES - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_SCOPE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_SYNC - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_SYNC_DATA - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_WRITE_BUFFER_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
JOURNAL_WRITE_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
JOURNAL_WRITE_DATA - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
Journal.BufferedChannelBuilder - Interface in org.apache.bookkeeper.bookie
For testability.
Journal.ForceWriteRequest - Class in org.apache.bookkeeper.bookie
Token which represents the need to force a write to the Journal.
Journal.JournalIdFilter - Interface in org.apache.bookkeeper.bookie
Filter to pickup journals.
Journal.JournalScanner - Interface in org.apache.bookkeeper.bookie
Scanner used to scan a journal.
Journal.LastLogMark - Class in org.apache.bookkeeper.bookie
Last Log Mark.
Journal.QueueEntry - Class in org.apache.bookkeeper.bookie
Journal Entry to Record.
journalAddEntryStats - Variable in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
JournalAliveListener - Interface in org.apache.bookkeeper.bookie
Listener for journal alive.
JournalChannel - Class in org.apache.bookkeeper.bookie
Simple wrapper around FileChannel to add versioning information to the file.
JournalChannel(File, long) - Constructor for class org.apache.bookkeeper.bookie.JournalChannel
 
JournalChannel(File, long, long, int, int, boolean, int, Journal.BufferedChannelBuilder, ServerConfiguration, FileChannelProvider, Long) - Constructor for class org.apache.bookkeeper.bookie.JournalChannel
 
JournalChannel(File, long, long, int, int, boolean, int, ServerConfiguration, FileChannelProvider) - Constructor for class org.apache.bookkeeper.bookie.JournalChannel
 
JournalChannel(File, long, long, int, long, ServerConfiguration, FileChannelProvider) - Constructor for class org.apache.bookkeeper.bookie.JournalChannel
 
JournalChannel(File, long, long, int, ServerConfiguration, FileChannelProvider) - Constructor for class org.apache.bookkeeper.bookie.JournalChannel
 
JOURNALDIR_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
journalDirectories - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
journalDirectories - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
journalDirectory - Variable in class org.apache.bookkeeper.bookie.Journal
 
journalDirs(String) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand.Flags
 
journalId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand.ReadJournalFlags
 
journalPreAllocSize - Variable in class org.apache.bookkeeper.bookie.Journal
 
journals - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
journals - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
journals - Variable in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand
 
JournalStats - Class in org.apache.bookkeeper.bookie.stats
A umbrella class for journal related stats.
JournalStats(StatsLogger, long, Supplier<Long>) - Constructor for class org.apache.bookkeeper.bookie.stats.JournalStats
 
journalWriteBufferSize - Variable in class org.apache.bookkeeper.bookie.Journal
 
JsonUtil - Class in org.apache.bookkeeper.common.util
Util class which helps to parse Json to and from Object.
JsonUtil() - Constructor for class org.apache.bookkeeper.common.util.JsonUtil
 
JsonUtil.ParseJsonException - Exception in org.apache.bookkeeper.common.util
A JSON parsing exception.
jvmEventLoopGroup - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 

K

KB - Static variable in class org.apache.bookkeeper.bookie.Journal
 
key - Variable in class org.apache.bookkeeper.metastore.MSWatchedEvent
 
key - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
KEY_ALGORITHM - Static variable in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
KEY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
KEY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
key2LedgerId(String) - Static method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
KeyComparator - Class in org.apache.bookkeeper.bookie
Compare EntryKey.
KeyComparator() - Constructor for class org.apache.bookkeeper.bookie.KeyComparator
 
KeyExists - org.apache.bookkeeper.metastore.MSException.Code
 
KeyExistsException(String) - Constructor for exception org.apache.bookkeeper.metastore.MSException.KeyExistsException
 
KeyExistsException(String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MSException.KeyExistsException
 
keys() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Get an iterator over to scan sequentially through all the keys in the database.
keys() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
keys() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
keys() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
keys() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
keys() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
keys(byte[], byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Get an iterator over to scan sequentially through all the keys within a specified range.
keys(byte[], byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
KeyValueStorage - Interface in org.apache.bookkeeper.bookie.storage.ldb
Abstraction of a generic key-value local database.
KeyValueStorage.Batch - Interface in org.apache.bookkeeper.bookie.storage.ldb
Interface for a batch to be written in the storage.
KeyValueStorage.CloseableIterator<T> - Interface in org.apache.bookkeeper.bookie.storage.ldb
Iterator interface.
KeyValueStorageFactory - Interface in org.apache.bookkeeper.bookie.storage.ldb
Factory class to create instances of the key-value storage implementation.
KeyValueStorageFactory.DbConfigType - Enum in org.apache.bookkeeper.bookie.storage.ldb
Enum used to specify different config profiles in the underlying storage.
KeyValueStorageRocksDB - Class in org.apache.bookkeeper.bookie.storage.ldb
RocksDB based implementation of the KeyValueStorage.
KeyValueStorageRocksDB(String, String, KeyValueStorageFactory.DbConfigType, ServerConfiguration) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
KeyValueStorageRocksDB(String, String, KeyValueStorageFactory.DbConfigType, ServerConfiguration, boolean) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
KINIT_COMMAND - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
KINIT_COMMAND_DEFAULT - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
knownBookies - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
kv(Object, Object) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
kv(Object, Object) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
kv(Object, Object) - Method in interface org.apache.bookkeeper.slogger.SloggableAccumulator
 
kv(Object, Object) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
kv(String, Object) - Method in class org.apache.bookkeeper.common.util.ExceptionMessageHelper
 
kvmap - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 

L

lac - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
lac - Variable in class org.apache.bookkeeper.client.ReadOpBase.ReadContext
 
lac - Variable in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
LAC_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
LAC_METADATA_LENGTH - Static variable in class org.apache.bookkeeper.proto.checksum.DigestManager
 
LAC_UPDATE_HITS - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
LAC_UPDATE_MISSES - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
LACBODY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
lacUpdateHitsCounter - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
lacUpdateMissesCounter - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
lacUpdateTimestamp - Variable in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
LACUPDATETIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
LAST_ADD_CONFIRMED - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Entry identifier representing a request to obtain the last add entry confirmed.
lastAddConfirmed - Variable in class org.apache.bookkeeper.client.LedgerHandle
Last entryId which has been confirmed to be written durably to the bookies.
lastAddConfirmed - Variable in class org.apache.bookkeeper.proto.checksum.DigestManager.RecoveryData
 
LastAddConfirmedCallback() - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.LastAddConfirmedCallback
 
LastAddConfirmedUpdateNotification - Class in org.apache.bookkeeper.bookie
A signal object is used for notifying the observers when the LastAddConfirmed is advanced.
LastAddConfirmedUpdateNotification(Recycler.Handle<LastAddConfirmedUpdateNotification>) - Constructor for class org.apache.bookkeeper.bookie.LastAddConfirmedUpdateNotification
 
lastAddPushed - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
LastConfirmedAndEntry - Interface in org.apache.bookkeeper.client.api
This contains LastAddConfirmed entryId and a LedgerEntry wanted to read.
LastConfirmedAndEntryImpl - Class in org.apache.bookkeeper.client.impl
This contains LastAddConfirmed entryId and a LedgerEntry wanted to read.
LastConfirmedAndEntryImpl(Recycler.Handle<LastConfirmedAndEntryImpl>) - Constructor for class org.apache.bookkeeper.client.impl.LastConfirmedAndEntryImpl
 
LastConfirmedCtx() - Constructor for class org.apache.bookkeeper.client.LedgerHandle.LastConfirmedCtx
 
lastEntry - Variable in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.RecoveryStats
 
lastEntry - Variable in class org.apache.bookkeeper.streaming.LedgerInputStream
 
LASTENTRYBODY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
lastEntryId - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterable
 
lastEntryId - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterator
 
lastEntryId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
LASTENTRYID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
LastLogMark(long, long) - Constructor for class org.apache.bookkeeper.bookie.Journal.LastLogMark
 
lastMajorCompactionTime - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
lastMajorCompactionTime(long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
LastMarkCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.LastMarkCmd
 
LastMarkCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
A bookie command to print the last log marker.
LastMarkCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.LastMarkCommand
 
lastMinorCompactionTime - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
lastMinorCompactionTime(long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
lastModifiedTime - Variable in class org.apache.bookkeeper.tls.FileModifiedTimeUpdater
 
lastPhaseStartTime - Variable in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
lastPresentTime - Variable in class org.apache.bookkeeper.net.StabilizeNetworkTopology.NodeStatus
 
lastSeenError - Variable in class org.apache.bookkeeper.client.ForceLedgerOp
 
lastSeenError - Variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
lastSeenError - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
lastShutdownWasUnclean() - Method in interface org.apache.bookkeeper.bookie.UncleanShutdownDetection
 
lastShutdownWasUnclean() - Method in class org.apache.bookkeeper.bookie.UncleanShutdownDetectionImpl
 
latencyBuckets - Variable in class org.apache.bookkeeper.proto.BKStats.OpStats
 
LAYOUT - Static variable in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
LAYOUT_FORMAT_VERSION - Static variable in class org.apache.bookkeeper.meta.LedgerLayout
 
LAYOUT_MIN_COMPAT_VERSION - Static variable in class org.apache.bookkeeper.meta.LedgerLayout
 
LAYOUT_VERSION - Static variable in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
LAYOUT_ZNODE - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
layoutManager - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
LayoutManager - Interface in org.apache.bookkeeper.meta
Layout manager for writing/reading/deleting ledger layout.
LayoutManager.LedgerLayoutExistsException - Exception in org.apache.bookkeeper.meta
The Ledger layout exists exception.
LBRDFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.LostBookieRecoveryDelayCommand.LBRDFlags
 
LD_INDEX_SCOPE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
LD_LEDGER_SCOPE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
LD_NUM_DIRS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
LD_WRITABLE_DIRS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
leakDetectionPolicy - Variable in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
leakDetectionPolicy(LeakDetectionPolicy) - Method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorBuilder
Enable the leak detection for the allocator.
leakDetectionPolicy(LeakDetectionPolicy) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
LeakDetectionPolicy - Enum in org.apache.bookkeeper.common.allocator
Define the policy for the Netty leak detector.
ledger - Variable in class org.apache.bookkeeper.bookie.EntryLocation
 
ledger(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
LEDGER_CACHE_HIT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
LEDGER_CACHE_MISS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
LEDGER_CACHE_NUM_EVICTED_LEDGERS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
LEDGER_CACHE_READ_PAGE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
LEDGER_CHECK_AND_COPY_END - org.apache.bookkeeper.bookie.datainteg.Events
Checking and copying has completed for a ledger.
LEDGER_CHECK_AND_COPY_START - org.apache.bookkeeper.bookie.datainteg.Events
Start checking whether the entries for a ledger exist locally, and copying them if they do not.
LEDGER_COUNT_OFFSET - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
LEDGER_DIRS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
LEDGER_ENSEMBLE_BOOKIE_DISTRIBUTION - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
LEDGER_ID_GEN_PREFIX - Static variable in class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
LEDGER_INFO_CACHING_TIME_MINUTES - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
LEDGER_MANAGER_FACTORY_CLASS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
LEDGER_MANAGER_FACTORY_DISABLE_CLASS_CHECK - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
LEDGER_MANAGER_TYPE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
LEDGER_METADATA_FORMAT_VERSION - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
LEDGER_METADATA_ROCKSDB_CONF - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
LEDGER_NODE_PREFIX - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
LEDGER_NODE_PREFIX - Static variable in class org.apache.bookkeeper.util.StringUtils
 
LEDGER_RECOVER_ADD_ENTRIES - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
LEDGER_RECOVER_READ_ENTRIES - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
LEDGER_STORAGE_CLASS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
LEDGER_STORAGE_CLASS_KEY - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
LedgerAuditorManager - Interface in org.apache.bookkeeper.meta
Interface to handle the ledger auditor election.
LedgerAuditorManager.AuditorEvent - Enum in org.apache.bookkeeper.meta
Events that can be triggered by the LedgerAuditorManager.
ledgerCache - Variable in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
LedgerCache - Interface in org.apache.bookkeeper.bookie
This class maps a ledger entry number into a location (entrylogid, offset) in an entry log file.
LedgerCache.LedgerIndexMetadata - Class in org.apache.bookkeeper.bookie
Represents summary of ledger metadata.
LedgerCache.NoIndexForLedgerException - Exception in org.apache.bookkeeper.bookie
Specific exception to encode the case where the index is not present.
LedgerCache.PageEntries - Interface in org.apache.bookkeeper.bookie
Represents a page of the index.
LedgerCache.PageEntriesIterable - Interface in org.apache.bookkeeper.bookie
Iterable over index pages -- returns PageEntries rather than individual entries because getEntries() above needs to be able to throw an IOException.
LedgerCacheImpl - Class in org.apache.bookkeeper.bookie
Implementation of LedgerCache interface.
LedgerCacheImpl(ServerConfiguration, SnapshotMap<Long, Boolean>, LedgerDirsManager) - Constructor for class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
LedgerCacheImpl(ServerConfiguration, SnapshotMap<Long, Boolean>, LedgerDirsManager, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
LedgerChecker - Class in org.apache.bookkeeper.client
A utility class to check the complete ledger and finds the UnderReplicated fragments if any.
LedgerChecker(BookKeeper) - Constructor for class org.apache.bookkeeper.client.LedgerChecker
 
LedgerChecker(BookKeeper, int) - Constructor for class org.apache.bookkeeper.client.LedgerChecker
 
LedgerChecker(BookieClient, BookieWatcher) - Constructor for class org.apache.bookkeeper.client.LedgerChecker
 
LedgerChecker(BookieClient, BookieWatcher, int) - Constructor for class org.apache.bookkeeper.client.LedgerChecker
 
LedgerChecker.InvalidFragmentException - Exception in org.apache.bookkeeper.client
 
LedgerClosedException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Executing operations on a closed ledger handle.
LedgerCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.LedgerCmd
 
LedgerCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to dump ledger index entries into readable format.
LedgerCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.LedgerCommand
 
LedgerCommand(LedgerIdFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.LedgerCommand
 
LedgerCommand.LedgerFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for ledger command.
LedgerCreateOp - Class in org.apache.bookkeeper.client
Encapsulates asynchronous ledger create operation.
LedgerCreateOp(BookKeeper, int, int, int, BookKeeper.DigestType, byte[], AsyncCallback.CreateCallback, Object, Map<String, byte[]>, EnumSet<WriteFlag>, BookKeeperClientStats) - Constructor for class org.apache.bookkeeper.client.LedgerCreateOp
Constructor.
LedgerCreateOp.CreateBuilderImpl - Class in org.apache.bookkeeper.client
 
ledgerDeleted(long) - Method in class org.apache.bookkeeper.bookie.HandleFactoryImpl
 
ledgerDeleted(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage.LedgerDeletionListener
 
LedgerDeleteOp - Class in org.apache.bookkeeper.client
Encapsulates asynchronous ledger delete operation.
LedgerDeleteOp(BookKeeper, BookKeeperClientStats, long, AsyncCallback.DeleteCallback, Object) - Constructor for class org.apache.bookkeeper.client.LedgerDeleteOp
Constructor.
LedgerDeleteOp.DeleteBuilderImpl - Class in org.apache.bookkeeper.client
 
LedgerDescriptor - Class in org.apache.bookkeeper.bookie
Implements a ledger inside a bookie.
LedgerDescriptor() - Constructor for class org.apache.bookkeeper.bookie.LedgerDescriptor
 
LedgerDescriptorImpl - Class in org.apache.bookkeeper.bookie
Implements a ledger inside a bookie.
LedgerDescriptorImpl(byte[], long, LedgerStorage) - Constructor for class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
LedgerDescriptorReadOnlyImpl - Class in org.apache.bookkeeper.bookie
Implements a ledger inside a bookie.
LedgerDescriptorReadOnlyImpl(long, LedgerStorage) - Constructor for class org.apache.bookkeeper.bookie.LedgerDescriptorReadOnlyImpl
 
ledgerDirectories - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
ledgerDirFull - Variable in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger.BufferedLogChannelWithDirInfo
 
ledgerDirs(String) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand.Flags
 
LEDGERDIRS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
ledgerDirsManager - Variable in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
ledgerDirsManager - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
ledgerDirsManager - Variable in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
ledgerDirsManager(LedgerDirsManager) - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
 
LedgerDirsManager - Class in org.apache.bookkeeper.bookie
This class manages ledger directories used by the bookie.
LedgerDirsManager(ServerConfiguration, File[], DiskChecker) - Constructor for class org.apache.bookkeeper.bookie.LedgerDirsManager
 
LedgerDirsManager(ServerConfiguration, File[], DiskChecker, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.LedgerDirsManager
 
LedgerDirsManager.LedgerDirsListener - Interface in org.apache.bookkeeper.bookie
Listener for the disk check events will be notified from the LedgerDirsManager whenever disk full/failure detected.
LedgerDirsManager.NoWritableLedgerDirException - Exception in org.apache.bookkeeper.bookie
Indicates All configured ledger directories are full.
LedgerDirsMonitor - Class in org.apache.bookkeeper.bookie
Thread to monitor the disk space periodically.
LedgerDirsMonitor(ServerConfiguration, DiskChecker, List<LedgerDirsManager>) - Constructor for class org.apache.bookkeeper.bookie.LedgerDirsMonitor
 
LedgerDirUtil - Class in org.apache.bookkeeper.util
 
LedgerDirUtil() - Constructor for class org.apache.bookkeeper.util.LedgerDirUtil
 
LedgerEntries - Interface in org.apache.bookkeeper.client.api
Interface to wrap a sequence of entries.
LedgerEntriesImpl - Class in org.apache.bookkeeper.client.impl
Ledger entries implementation.
LedgerEntriesIterable(long, long) - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterable
 
LedgerEntriesIterable(long, long, long) - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterable
 
LedgerEntriesIterator(long, long, long) - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterator
 
LedgerEntry - Class in org.apache.bookkeeper.client
Ledger entry.
LedgerEntry - Interface in org.apache.bookkeeper.client.api
An entry in a ledger.
LedgerEntry(LedgerEntryImpl) - Constructor for class org.apache.bookkeeper.client.LedgerEntry
 
LedgerEntryImpl - Class in org.apache.bookkeeper.client.impl
Ledger entry.
LedgerEntryPage - Class in org.apache.bookkeeper.bookie
This is a page in the LedgerCache.
LedgerEntryPage(int, int) - Constructor for class org.apache.bookkeeper.bookie.LedgerEntryPage
 
LedgerEntryPage(int, int, LEPStateChangeCallback) - Constructor for class org.apache.bookkeeper.bookie.LedgerEntryPage
 
LedgerEntryPage.EntryVisitor - Interface in org.apache.bookkeeper.bookie
Interface for getEntries to propagate entry, pos pairs.
LedgerEntryRequest(List<BookieId>, long) - Constructor for class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
LedgerExistException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Ledger already exists.
ledgerExists(long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
ledgerExists(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
ledgerExists(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
ledgerExists(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
ledgerExists(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
ledgerExists(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Whether a ledger exists.
ledgerExists(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
ledgerExists(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
ledgerExists(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
LedgerFencedException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
LedgerFencedException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Operations failed due to ledgers are fenced.
LedgerFencedException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.LedgerFencedException
 
LedgerFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.LedgerCommand.LedgerFlags
 
LedgerFragment - Class in org.apache.bookkeeper.client
Represents the entries of a segment of a ledger which are stored on subset of bookies in the segments bookie ensemble.
LedgerFragment(LedgerFragment, Set<Integer>) - Constructor for class org.apache.bookkeeper.client.LedgerFragment
 
LedgerFragment(LedgerHandle, long, long, Set<Integer>) - Constructor for class org.apache.bookkeeper.client.LedgerFragment
 
LedgerFragment.ReplicateType - Enum in org.apache.bookkeeper.client
ReplicateType.
LedgerFragmentReplicator - Class in org.apache.bookkeeper.client
This is the helper class for replicating the fragments from one bookie to another.
LedgerFragmentReplicator(BookKeeper, ClientConfiguration) - Constructor for class org.apache.bookkeeper.client.LedgerFragmentReplicator
 
LedgerFragmentReplicator(BookKeeper, StatsLogger, ClientConfiguration) - Constructor for class org.apache.bookkeeper.client.LedgerFragmentReplicator
 
LedgerFragmentReplicator.SingleFragmentCallback - Class in org.apache.bookkeeper.client
Callback for recovery of a single ledger fragment.
LedgerFragmentReplicator.Throttler - Class in org.apache.bookkeeper.client
 
ledgerFragmentsMcb - Variable in class org.apache.bookkeeper.client.LedgerFragmentReplicator.SingleFragmentCallback
 
LedgerHandle - Class in org.apache.bookkeeper.client
Ledger handle contains ledger metadata and is used to access the read and write operations to a ledger.
LedgerHandle(ClientContext, long, Versioned<LedgerMetadata>, BookKeeper.DigestType, byte[], EnumSet<WriteFlag>) - Constructor for class org.apache.bookkeeper.client.LedgerHandle
 
LedgerHandle.LastConfirmedCtx - Class in org.apache.bookkeeper.client
Context objects for synchronous call to read last confirmed.
LedgerHandle.NoopCloseCallback - Class in org.apache.bookkeeper.client
 
LedgerHandleAdv - Class in org.apache.bookkeeper.client
Ledger Advanced handle extends LedgerHandle to provide API to add entries with user supplied entryIds.
LedgerHandleAdv(ClientContext, long, Versioned<LedgerMetadata>, BookKeeper.DigestType, byte[], EnumSet<WriteFlag>) - Constructor for class org.apache.bookkeeper.client.LedgerHandleAdv
 
LedgerHandleAdv.PendingOpsComparator - Class in org.apache.bookkeeper.client
 
ledgerId - Variable in class org.apache.bookkeeper.bookie.EntryKey
 
ledgerId - Variable in class org.apache.bookkeeper.bookie.FileInfoBackingCache.CachedFileInfo
 
ledgerId - Variable in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
ledgerId - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterable
 
ledgerId - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterator
 
ledgerId - Variable in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
ledgerId - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
ledgerId - Variable in class org.apache.bookkeeper.client.LedgerDeleteOp
 
ledgerId - Variable in class org.apache.bookkeeper.client.LedgerEntry
 
ledgerId - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
ledgerId - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
ledgerId - Variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManager.CancelWatchLedgerMetadataTask
 
ledgerId - Variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManager.ReadLedgerMetadataTask
 
ledgerId - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager.ReadLedgerMetadataTask
Deprecated.
 
ledgerId - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
ledgerId - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
ledgerId - Variable in class org.apache.bookkeeper.proto.checksum.DigestManager
 
ledgerId - Variable in class org.apache.bookkeeper.proto.GetListOfEntriesOfLedgerProcessorV3
 
ledgerId - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
ledgerId - Variable in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
ledgerId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.LedgerCommand.LedgerFlags
 
ledgerId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
ledgerId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
ledgerId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.client.DeleteLedgerCommand.DeleteLedgerFlags
 
ledgerId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand.LedgerMetadataFlag
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
LEDGERID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
LEDGERID_FORMATTER_CLASS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
LEDGERID_FORMATTER_OPT - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
ledgerId2Key(Long) - Static method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
ledgerIdFormatter - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
ledgerIdFormatter - Variable in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand.LURFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToDBStorageCommand.CTDBFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.LedgerCommand.LedgerFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand.ActiveLedgerFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListLedgersCommand.ListLedgersFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand.ReadJournalFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand.ReadLogMetadataFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.client.DeleteLedgerCommand.DeleteLedgerFlags
 
ledgerIdFormatter(String) - Method in class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand.LedgerMetadataFlag
 
LedgerIdFormatter - Class in org.apache.bookkeeper.util
Formatter to format a ledgerId.
LedgerIdFormatter() - Constructor for class org.apache.bookkeeper.util.LedgerIdFormatter
 
LedgerIdFormatter.HexLedgerIdFormatter - Class in org.apache.bookkeeper.util
hex ledgerId formatter.
LedgerIdFormatter.LongLedgerIdFormatter - Class in org.apache.bookkeeper.util
long ledgerId formatter.
LedgerIdFormatter.UUIDLedgerIdFormatter - Class in org.apache.bookkeeper.util
uuid ledgerId formatter.
ledgerIdGenerator - Variable in class org.apache.bookkeeper.client.BookKeeper
 
LedgerIdGenerator - Interface in org.apache.bookkeeper.meta
The interface for global unique ledger ID generation.
ledgerIdGenPathPresent(ZooKeeper) - Method in class org.apache.bookkeeper.meta.LongZkLedgerIdGenerator
Checks the existence of the long ledger id gen path.
LedgerIdOverflowException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Ledger id overflow happens on ledger manager.
ledgerIds(List<Long>) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.RegenerateInterleavedStorageIndexFileCommand.RISIFFlags
 
LedgerIndexMetadata(byte[], long, boolean) - Constructor for class org.apache.bookkeeper.bookie.LedgerCache.LedgerIndexMetadata
 
LedgerInfo(long, long) - Constructor for class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
LedgerInputStream - Class in org.apache.bookkeeper.streaming
An input stream on reading data from a ledger.
LedgerInputStream(LedgerHandle) - Constructor for class org.apache.bookkeeper.streaming.LedgerInputStream
construct a outputstream from a ledger handle.
LedgerInputStream(LedgerHandle, int) - Constructor for class org.apache.bookkeeper.streaming.LedgerInputStream
construct a outputstream from a ledger handle.
ledgerKey - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
LedgerLayout - Class in org.apache.bookkeeper.meta
This class encapsulates ledger layout information that is persistently stored in registration service.
LedgerLayout(String, int) - Constructor for class org.apache.bookkeeper.meta.LedgerLayout
Ledger Layout Constructor.
LedgerLayout(String, int, int) - Constructor for class org.apache.bookkeeper.meta.LedgerLayout
 
LedgerLayoutExistsException(String) - Constructor for exception org.apache.bookkeeper.meta.LayoutManager.LedgerLayoutExistsException
 
LedgerLayoutExistsException(String, Throwable) - Constructor for exception org.apache.bookkeeper.meta.LayoutManager.LedgerLayoutExistsException
 
LedgerLayoutExistsException(Throwable) - Constructor for exception org.apache.bookkeeper.meta.LayoutManager.LedgerLayoutExistsException
 
ledgerListToSet(List<String>, String) - Method in class org.apache.bookkeeper.meta.AbstractHierarchicalLedgerManager
Get all ledger ids in the given zk path.
ledgerListToSet(List<String>, String) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
Convert the ZK retrieved ledger nodes to a HashSet for easier comparisons.
ledgerManager - Variable in class org.apache.bookkeeper.client.BookKeeper
 
ledgerManager - Variable in class org.apache.bookkeeper.client.LedgerFragmentReplicator.SingleFragmentCallback
 
ledgerManager - Variable in class org.apache.bookkeeper.replication.AuditorTask
 
LedgerManager - Interface in org.apache.bookkeeper.meta
LedgerManager takes responsibility of ledger management in client side.
LedgerManager.LedgerRange - Class in org.apache.bookkeeper.meta
Used to represent the Ledgers range returned from the current scan.
LedgerManager.LedgerRangeIterator - Interface in org.apache.bookkeeper.meta
Interface of the ledger meta range iterator from storage (e.g.
ledgerManagerFactory - Variable in class org.apache.bookkeeper.client.BookKeeper
 
ledgerManagerFactory - Variable in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
ledgerManagerFactory - Variable in class org.apache.bookkeeper.server.http.service.ListLedgerService
 
ledgerManagerFactory(LedgerManagerFactory) - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
 
LedgerManagerFactory - Interface in org.apache.bookkeeper.meta
A factory for creating ledger managers.
LedgerMetadata - org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageFactory.DbConfigType
 
LedgerMetadata - Interface in org.apache.bookkeeper.client.api
Represents the client-side metadata of a ledger.
LedgerMetadata.State - Enum in org.apache.bookkeeper.client.api
Possible metadata states.
LedgerMetadataBuilder - Class in org.apache.bookkeeper.client
Builder for building LedgerMetadata objects.
LedgerMetadataBuilder() - Constructor for class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
LedgerMetadataCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.LedgerMetadataCmd
 
LedgerMetaDataCommand - Class in org.apache.bookkeeper.tools.cli.commands.client
Print the metadata for a ledger.
LedgerMetaDataCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand
 
LedgerMetaDataCommand(LedgerMetaDataCommand.LedgerMetadataFlag) - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand
 
LedgerMetaDataCommand(LedgerIdFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand
 
LedgerMetaDataCommand.LedgerMetadataFlag - Class in org.apache.bookkeeper.tools.cli.commands.client
Flags for ledger metadata command.
LedgerMetadataFlag() - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand.LedgerMetadataFlag
 
LedgerMetadataImpl - Class in org.apache.bookkeeper.client
This class encapsulates all the ledger metadata that is persistently stored in metadata store.
LedgerMetadataImpl(long, int, int, int, int, LedgerMetadata.State, Optional<Long>, Optional<Long>, Map<Long, List<BookieId>>, Optional<DigestType>, Optional<byte[]>, long, boolean, long, Map<String, byte[]>) - Constructor for class org.apache.bookkeeper.client.LedgerMetadataImpl
 
LedgerMetadataIndex - Class in org.apache.bookkeeper.bookie.storage.ldb
Maintains an index for the ledgers metadata.
LedgerMetadataIndex(ServerConfiguration, KeyValueStorageFactory, String, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
LedgerMetadataIndexStats - Class in org.apache.bookkeeper.bookie.storage.ldb
A umbrella class for ledger metadata index stats.
LedgerMetadataIndexStats(StatsLogger, Supplier<Long>) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndexStats
 
LedgerMetadataSerDe - Class in org.apache.bookkeeper.meta
Serialization and deserialization for LedgerMetadata.
LedgerMetadataSerDe() - Constructor for class org.apache.bookkeeper.meta.LedgerMetadataSerDe
 
LedgerMetadataUtils - Class in org.apache.bookkeeper.client
Utilities for working with ledger metadata.
LedgerMetadataUtils() - Constructor for class org.apache.bookkeeper.client.LedgerMetadataUtils
 
LedgerOpenOp - Class in org.apache.bookkeeper.client
Encapsulates the ledger open operation.
LedgerOpenOp(BookKeeper, BookKeeperClientStats, long, AsyncCallback.OpenCallback, Object) - Constructor for class org.apache.bookkeeper.client.LedgerOpenOp
 
LedgerOpenOp(BookKeeper, BookKeeperClientStats, long, BookKeeper.DigestType, byte[], AsyncCallback.OpenCallback, Object) - Constructor for class org.apache.bookkeeper.client.LedgerOpenOp
Constructor.
LedgerOpenOp.OpenBuilderImpl - Class in org.apache.bookkeeper.client
 
LedgerOutputStream - Class in org.apache.bookkeeper.streaming
this class provides a streaming api to get an output stream from a ledger handle and write to it as a stream of bytes.
LedgerOutputStream(LedgerHandle) - Constructor for class org.apache.bookkeeper.streaming.LedgerOutputStream
construct a outputstream from a ledger handle.
LedgerOutputStream(LedgerHandle, int) - Constructor for class org.apache.bookkeeper.streaming.LedgerOutputStream
construct a outputstream from a ledger handle.
ledgerPrefix - Variable in class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
LedgerRange(Set<Long>) - Constructor for class org.apache.bookkeeper.meta.LedgerManager.LedgerRange
 
LedgerRecoveryException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Ledger recovery operations failed.
LedgerRecoveryOp - Class in org.apache.bookkeeper.client
This class encapsulated the ledger recovery operation.
LedgerRecoveryOp(LedgerHandle, ClientContext) - Constructor for class org.apache.bookkeeper.client.LedgerRecoveryOp
 
LedgerRecoveryOp.RecoveryReadOp - Class in org.apache.bookkeeper.client
 
ledgerRootPath - Variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
LEDGERS_MAP_ENTRY_ID - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
LEDGERS_MAP_ENTRY_ID - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.LogMetadata
 
LEDGERS_MAP_ENTRY_SIZE - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
LEDGERS_MAP_ENTRY_SIZE - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.LogMetadata
 
LEDGERS_MAP_HEADER_SIZE - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Ledgers map is composed of multiple parts that can be split into separated entries.
LEDGERS_MAP_HEADER_SIZE - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.LogMetadata
Ledgers map is composed of multiple parts that can be split into separated entries.
LEDGERS_MAP_MAX_BATCH_SIZE - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
LEDGERS_MAP_MAX_BATCH_SIZE - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.LogMetadata
 
LEDGERS_MAP_MAX_MAP_SIZE - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.LogMetadata
 
LEDGERS_MAP_OFFSET - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
LEDGERS_MAP_OFFSET_POSITION - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
ledgerSeq - Variable in class org.apache.bookkeeper.streaming.LedgerInputStream
 
LedgersIndexCheckOp - Class in org.apache.bookkeeper.bookie.storage.ldb
Scan the ledgers index to make sure it is readable.
LedgersIndexCheckOp(ServerConfiguration, boolean) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.LedgersIndexCheckOp
 
LedgersIndexRebuildOp - Class in org.apache.bookkeeper.bookie.storage.ldb
Scan all entries in the journal and entry log files then rebuilds the ledgers index.
LedgersIndexRebuildOp(ServerConfiguration, boolean) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.LedgersIndexRebuildOp
 
LedgersIterator - Interface in org.apache.bookkeeper.client.api
Iterator for ledgers.
ledgersMap - Variable in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
ledgersRootPath - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
ledgerStorage - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
ledgerStorage - Variable in class org.apache.bookkeeper.bookie.EntryLogCompactor
 
ledgerStorage - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
ledgerStorage - Variable in class org.apache.bookkeeper.bookie.HandleFactoryImpl
 
ledgerStorage - Variable in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
ledgerStorage - Variable in class org.apache.bookkeeper.bookie.SyncThread
 
ledgerStorage - Variable in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor
 
LedgerStorage - Interface in org.apache.bookkeeper.bookie
Interface for storing ledger data on persistent storage.
LedgerStorage.DetectedInconsistency - Class in org.apache.bookkeeper.bookie
Class for describing location of a generic inconsistency.
LedgerStorage.LedgerDeletionListener - Interface in org.apache.bookkeeper.bookie
Signals that a ledger is deleted by the garbage collection thread.
LedgerStorage.StorageState - Enum in org.apache.bookkeeper.bookie
StorageState flags.
LedgerStorageFactory - Class in org.apache.bookkeeper.bookie
A factory that creates LedgerStorage by reflection.
LedgerStorageFactory() - Constructor for class org.apache.bookkeeper.bookie.LedgerStorageFactory
 
ledgerTable - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
ledgerUnderreplicationManager - Variable in class org.apache.bookkeeper.replication.AuditorTask
 
LedgerUnderreplicationManager - Interface in org.apache.bookkeeper.meta
Interface for marking ledgers which need to be rereplicated.
LEGACY_BOOKIEID_RESOLVER - Static variable in class org.apache.bookkeeper.net.BookieSocketAddress
Simple converter from legacy BookieId to a real network address.
LegacyCookieValidation - Class in org.apache.bookkeeper.bookie
Legacy implementation of CookieValidation.
LegacyCookieValidation(ServerConfiguration, RegistrationManager) - Constructor for class org.apache.bookkeeper.bookie.LegacyCookieValidation
 
LEGACYHIERARCHICAL_LEDGER_PARENT_NODE_REGEX - Static variable in class org.apache.bookkeeper.util.StringUtils
 
LegacyHierarchicalLedgerManager - Class in org.apache.bookkeeper.meta
Hierarchical Ledger Manager which manages ledger meta in zookeeper using 2-level hierarchical znodes.
LegacyHierarchicalLedgerManager(AbstractConfiguration, ZooKeeper) - Constructor for class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManager
Constructor.
LegacyHierarchicalLedgerManagerFactory - Class in org.apache.bookkeeper.meta
Hierarchical Ledger Manager Factory.
LegacyHierarchicalLedgerManagerFactory() - Constructor for class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
legacyLM - Variable in class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
length - Variable in class org.apache.bookkeeper.client.LedgerEntry
 
length - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
length - Variable in class org.apache.bookkeeper.proto.checksum.DigestManager.RecoveryData
 
length() - Method in class com.scurrilous.circe.crc.AbstractIntCrc
 
length() - Method in class com.scurrilous.circe.crc.AbstractLongCrc
 
length() - Method in class com.scurrilous.circe.crc.JavaCrc32
 
length() - Method in class com.scurrilous.circe.crc.Sse42Crc32C
 
length() - Method in interface com.scurrilous.circe.Hash
Returns the length in bytes of the output of this hash function.
length() - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
length() - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
length() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
length() - Method in class com.scurrilous.circe.impl.IntStatelessLongHash
 
LENGTH_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
LEPStateChangeCallback - Interface in org.apache.bookkeeper.bookie
Callback interface when state of ledger entry page changed.
level - Variable in class org.apache.bookkeeper.net.NodeBase
 
LFODFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListFilesOnDiscCommand.LFODFlags
 
lh - Variable in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
lh - Variable in class org.apache.bookkeeper.client.ForceLedgerOp
 
lh - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
lh - Variable in class org.apache.bookkeeper.client.LedgerFragmentReplicator.SingleFragmentCallback
 
lh - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
lh - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
lh - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
lh - Variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
lh - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
lh - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
lh - Variable in class org.apache.bookkeeper.client.SyncCounter
 
lh - Variable in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
libType() - Static method in class com.scurrilous.circe.utils.NativeUtils
Returns jni library extension based on OS specification.
lId - Variable in class org.apache.bookkeeper.client.BatchedReadOp.BatchedLedgerEntryRequest
 
lifecycle - Variable in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
lifecycle - Variable in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
Lifecycle - Class in org.apache.bookkeeper.common.component
Lifecycle state.
Lifecycle() - Constructor for class org.apache.bookkeeper.common.component.Lifecycle
 
Lifecycle.State - Enum in org.apache.bookkeeper.common.component
Lifecycle State.
LifecycleComponent - Interface in org.apache.bookkeeper.common.component
A component based on lifecycle management.
LifecycleComponentStack - Class in org.apache.bookkeeper.common.component
A stack of LifecycleComponents.
LifecycleComponentStack.Builder - Class in org.apache.bookkeeper.common.component
Builder to build a stack of LifecycleComponents.
LifecycleListener - Interface in org.apache.bookkeeper.common.component
Listener listening of the lifecycle changes.
lifecycleState() - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
lifecycleState() - Method in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
lifecycleState() - Method in interface org.apache.bookkeeper.common.component.LifecycleComponent
 
lifecycleState() - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
LIMBO_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
LIMBO_OR_FENCE_ERROR - org.apache.bookkeeper.bookie.datainteg.Events
An error occurred marking the ledger as fenced or as in-limbo.
limit(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand.FlipBookieIdFlags
 
limit(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags
 
LIMIT_STATS_LOGGING - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
linkCount(File) - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGUnix
 
linkCount(File) - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
linkMult(String[], File) - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGUnix
 
linkMult(String[], File) - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
linkOne(File, File) - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGUnix
 
linkOne(File, File) - Method in class org.apache.bookkeeper.util.HardLink.HardLinkCGWin
 
linkStats - Variable in class org.apache.bookkeeper.util.HardLink
 
LinkStats() - Constructor for class org.apache.bookkeeper.util.HardLink.LinkStats
 
list(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand.AdminFlags
 
LIST - org.apache.bookkeeper.common.conf.Type
 
LIST_BATCH_SIZE - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
LIST_LEDGER_BATCH_SIZE - Static variable in class org.apache.bookkeeper.server.http.service.ListLedgerService
 
ListActiveLedgersCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ListActiveLedgersCmd
 
ListActiveLedgersCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
List active(exist in metadata storage) ledgers in a entry log file.
ListActiveLedgersCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand
 
ListActiveLedgersCommand(ListActiveLedgersCommand.ActiveLedgerFlags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand
 
ListActiveLedgersCommand(LedgerIdFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand
 
ListActiveLedgersCommand.ActiveLedgerFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for active ledger command.
ListBookieInfoService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper list bookie info related http request.
ListBookieInfoService(ServerConfiguration) - Constructor for class org.apache.bookkeeper.server.http.service.ListBookieInfoService
 
ListBookiesCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ListBookiesCmd
 
ListBookiesCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Command to list available bookies.
ListBookiesCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.ListBookiesCommand
 
ListBookiesCommand(ListBookiesCommand.Flags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.ListBookiesCommand
 
ListBookiesCommand.Flags - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Flags for list bookies command.
ListBookiesService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper list bookies related http request.
ListBookiesService(ServerConfiguration, BookKeeperAdmin) - Constructor for class org.apache.bookkeeper.server.http.service.ListBookiesService
 
ListDiskFilesCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ListDiskFilesCmd
 
ListDiskFilesService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper list disk files related http request.
ListDiskFilesService(ServerConfiguration) - Constructor for class org.apache.bookkeeper.server.http.service.ListDiskFilesService
 
listener - Variable in class org.apache.bookkeeper.client.ListenerBasedPendingReadOp
 
ListenerBasedPendingReadOp - Class in org.apache.bookkeeper.client
 
ListenerBasedPendingReadOp(LedgerHandle, ClientContext, long, long, BookkeeperInternalCallbacks.ReadEntryListener, Object, boolean) - Constructor for class org.apache.bookkeeper.client.ListenerBasedPendingReadOp
 
listeners - Variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
listeners - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
LISTENING_INTERFACE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
listEntries(long) - Method in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
Return iterator over pages for mapping entries to entry loggers.
listEntries(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
listEntries(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
listEntries(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
listFilesAndSort(File[], String...) - Static method in class org.apache.bookkeeper.bookie.BookieShell
Returns the sorted list of the files in the given folders with the given file extensions.
ListFilesOnDiscCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to list the files in JournalDirectories/LedgerDirectories/IndexDirectories.
ListFilesOnDiscCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListFilesOnDiscCommand
 
ListFilesOnDiscCommand(ListFilesOnDiscCommand.LFODFlags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListFilesOnDiscCommand
 
ListFilesOnDiscCommand.LFODFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for list files on disc command.
listJournalIds(File, Journal.JournalIdFilter) - Static method in class org.apache.bookkeeper.bookie.Journal
List all journal ids by a specified journal id filer.
listLedgers() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
This method returns an iterable object for the list of ledger identifiers of the ledgers currently available.
ListLedgersCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ListLedgersCmd
 
ListLedgersCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command for list all ledgers on the cluster.
ListLedgersCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListLedgersCommand
 
ListLedgersCommand(ListLedgersCommand.ListLedgersFlags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListLedgersCommand
 
ListLedgersCommand(LedgerIdFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListLedgersCommand
 
ListLedgersCommand.ListLedgersFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for ListLedgers command.
ListLedgerService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper list ledger related http request.
ListLedgerService(ServerConfiguration, LedgerManagerFactory) - Constructor for class org.apache.bookkeeper.server.http.service.ListLedgerService
 
ListLedgersFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ListLedgersCommand.ListLedgersFlags
 
ListLedgersResult - Interface in org.apache.bookkeeper.client.api
Utility container for listing ledgers.
ListLedgersResultBuilder - Interface in org.apache.bookkeeper.client.api
Builder-style interface to list exiting ledgers.
listLedgersToRereplicate(Predicate<List<String>>) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Get a list of all the underreplicated ledgers which have been marked for rereplication, filtered by the predicate on the missing replicas list.
listLedgersToRereplicate(Predicate<List<String>>) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
listLedgersToRereplicate(Predicate<List<String>>) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
Get a list of all the underreplicated ledgers which have been marked for rereplication, filtered by the predicate on the replicas list.
ListUnderreplicatedCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ListUnderreplicatedCmd
 
ListUnderReplicatedCommand - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Command to listing under replicated ledgers.
ListUnderReplicatedCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand
 
ListUnderReplicatedCommand(LedgerIdFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand
 
ListUnderReplicatedCommand.LURFlags - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Flags for list under replicated command.
ListUnderReplicatedLedgerService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper list under replicated ledger related http request.
ListUnderReplicatedLedgerService(ServerConfiguration, LedgerManagerFactory) - Constructor for class org.apache.bookkeeper.server.http.service.ListUnderReplicatedLedgerService
 
lmFactory - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
load(long, boolean) - Method in interface org.apache.bookkeeper.bookie.FileInfoBackingCache.FileLoader
 
loadConf(URL) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
Load configuration from a given confURL.
loadConf(URL) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
You can load configurations in precedence order.
loadConf(CompositeConfiguration) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
You can load configuration from other configuration.
loadConf(Configuration) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
loadFileInfo(long, byte[]) - Method in class org.apache.bookkeeper.bookie.FileInfoBackingCache
 
loadInitialDrivers() - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
 
loadLibrary() - Static method in class com.scurrilous.circe.checksum.NarSystem
Load jni library: circe-checksum
loadLibrary() - Static method in class org.apache.bookkeeper.util.nativeio.NarSystem
Load jni library: native-io
loadLibrary() - Static method in class org.apache.bookkeeper.utils.affinity.NarSystem
Load jni library: cpu-affinity
loadLibraryFromJar(String) - Static method in class com.scurrilous.circe.utils.NativeUtils
loads given library from the this jar.
loadLibraryFromJar(String) - Static method in class org.apache.bookkeeper.common.util.affinity.impl.NativeUtils
loads given library from the this jar.
loadLibraryFromJar(String) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeUtils
loads given library from the this jar.
loadServerComponents(String[], BookieConfiguration, StatsLogger) - Static method in class org.apache.bookkeeper.server.component.ServerLifecycleComponent
 
loadStatsProvider(String) - Static method in class org.apache.bookkeeper.stats.Stats
 
loadStatsProvider(Configuration) - Static method in class org.apache.bookkeeper.stats.Stats
 
LOCAL_CONSISTENCY_CHECK_ON_STARTUP - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
LOCAL_FAIL_MASK - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
LOCAL_MASK - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
LOCAL_SCRUB_PERIOD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
LOCAL_SCRUB_RATE_LIMIT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
LocalBookieEnsemblePlacementPolicy - Class in org.apache.bookkeeper.bookie
Special ensemble placement policy that always return local bookie.
LocalBookieEnsemblePlacementPolicy() - Constructor for class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
localBookies - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
localBookiesConfigDir - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
LocalBookiesRegistry - Class in org.apache.bookkeeper.proto
Local registry for embedded Bookies.
LocalBookiesRegistry() - Constructor for class org.apache.bookkeeper.proto.LocalBookiesRegistry
 
LocalBookKeeper - Class in org.apache.bookkeeper.util
Local Bookkeeper.
LocalBookKeeper(int, ServerConfiguration, String, boolean, String, String, int) - Constructor for class org.apache.bookkeeper.util.LocalBookKeeper
 
localConsistencyCheck(Optional<RateLimiter>) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
localConsistencyCheck(Optional<RateLimiter>) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Performs internal check of local storage logging any inconsistencies.
localConsistencyCheck(Optional<RateLimiter>) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
LocalConsistencyCheck() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.LocalConsistencyCheck
 
LocalConsistencyCheckCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to check local storage for inconsistencies.
LocalConsistencyCheckCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.LocalConsistencyCheckCommand
 
localNode - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
location - Variable in class org.apache.bookkeeper.bookie.EntryLocation
 
location - Variable in class org.apache.bookkeeper.net.NodeBase
 
LocationsIndexRebuildOp - Class in org.apache.bookkeeper.bookie.storage.ldb
Scan all entries in the entry log and rebuild the locations index.
LocationsIndexRebuildOp(ServerConfiguration) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.LocationsIndexRebuildOp
 
locationToDepth(String) - Static method in class org.apache.bookkeeper.net.NodeBase
 
lock - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
lock - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 
lock - Variable in class org.apache.bookkeeper.bookie.FileInfoBackingCache
 
lock - Variable in class org.apache.bookkeeper.util.SnapshotMap
 
LOCK_RELEASE_OF_FAILED_LEDGER_GRACE_PERIOD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
log(SloggableAccumulator) - Method in interface org.apache.bookkeeper.slogger.Sloggable
 
LOG - Static variable in class org.apache.bookkeeper.bookie.BookieShell
 
LOG - Static variable in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
LOG - Static variable in class org.apache.bookkeeper.bookie.ScanAndCompareGarbageCollector
 
LOG - Static variable in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
LOG - Static variable in class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
LOG - Static variable in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
LOG - Static variable in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
LOG - Static variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
LOG - Static variable in class org.apache.bookkeeper.client.LedgerDeleteOp
 
LOG - Static variable in class org.apache.bookkeeper.client.LedgerHandle
 
LOG - Static variable in class org.apache.bookkeeper.client.LedgerHandleAdv
 
LOG - Static variable in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
LOG - Static variable in class org.apache.bookkeeper.client.LedgerMetadataUtils
 
LOG - Static variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
LOG - Static variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
LOG - Static variable in class org.apache.bookkeeper.client.MetadataUpdateLoop
 
LOG - Static variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
LOG - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
LOG - Static variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
LOG - Static variable in class org.apache.bookkeeper.client.ReadLastConfirmedOp
 
LOG - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
LOG - Static variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
LOG - Static variable in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
LOG - Static variable in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
LOG - Static variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
LOG - Static variable in class org.apache.bookkeeper.meta.FlatLedgerManager
 
LOG - Static variable in class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
LOG - Static variable in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManager
 
LOG - Static variable in class org.apache.bookkeeper.meta.LongHierarchicalLedgerManager
 
LOG - Static variable in class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
LOG - Static variable in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
LOG - Static variable in class org.apache.bookkeeper.net.NetworkTopologyImpl
 
LOG - Static variable in class org.apache.bookkeeper.proto.AuthHandler
 
LOG - Static variable in class org.apache.bookkeeper.proto.BookieClientImpl
 
LOG - Static variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks
 
LOG - Static variable in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
LOG - Static variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.BookieSanityService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.DecommissionService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.DeleteLedgerService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.ExpandStorageService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.GCDetailsService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.GetLastLogMarkService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.GetLedgerMetaService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.ListBookieInfoService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.ListBookiesService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.ListDiskFilesService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.ListLedgerService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.ListUnderReplicatedLedgerService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.LostBookieRecoveryDelayService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.ReadLedgerEntryService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.RecoveryBookieService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.ResumeCompactionService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.SuspendCompactionService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.TriggerAuditService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.TriggerGCService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.TriggerLocationCompactService
 
LOG - Static variable in class org.apache.bookkeeper.server.http.service.WhoIsAuditorService
 
LOG - Static variable in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
LOG - Static variable in class org.apache.bookkeeper.stats.Stats
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.autorecovery.LostBookieRecoveryDelayCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.autorecovery.QueryAutoRecoveryStatusCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ToggleCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.autorecovery.WhoIsAuditorCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.CheckDBLedgersIndexCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.FormatCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.LedgerCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.LocalConsistencyCheckCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.RebuildDBLedgerLocationsIndexCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.RebuildDBLedgersIndexCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.RegenerateInterleavedStorageIndexFileCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookies.DecommissionCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookies.EndpointInfoCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookies.InstanceIdCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.bookies.NukeExistingClusterCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.cookie.AdminCommand
 
LOG - Static variable in class org.apache.bookkeeper.tools.cli.commands.health.SwitchOfHealthCheckCommand
 
LOG - Static variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
LOG - Static variable in class org.apache.bookkeeper.util.Shell
 
LOG_DELETED - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
A log file has been deleted.
LOG_FILE_SUFFIX - Static variable in interface org.apache.bookkeeper.bookie.storage.EntryLogger
 
LOG_ROLL - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
The entrylogger has started writing a new log file.
logAddEntry(long, long, ByteBuf, boolean, BookkeeperInternalCallbacks.WriteCallback, Object) - Method in class org.apache.bookkeeper.bookie.Journal
 
logAddEntry(ByteBuf, boolean, BookkeeperInternalCallbacks.WriteCallback, Object) - Method in class org.apache.bookkeeper.bookie.Journal
record an add entry operation in journal.
logErrorAndReattemptRead(int, BookieId, String, int) - Method in class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
logErrorAndReattemptRead(int, BookieId, String, int) - Method in class org.apache.bookkeeper.client.PendingReadOp.ParallelReadRequest
 
logErrorAndReattemptRead(int, BookieId, String, int) - Method in class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
 
logErrorAndReattemptRead(int, BookieId, String, int) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ParallelReadRequest
 
logErrorAndReattemptRead(int, BookieId, String, int) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
Log error errMsg and reattempt read from host.
logErrorAndReattemptRead(int, BookieId, String, int) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
logErrorAndReattemptRead(int, BookieId, String, int) - Method in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
Log error errMsg and reattempt read from host.
LogExceptionRunnable - Class in org.apache.bookkeeper.common.util
A simple wrapper for a Runnable that logs any exception thrown by it, before re-throwing it.
LogExceptionRunnable(Runnable) - Constructor for class org.apache.bookkeeper.common.util.LogExceptionRunnable
 
logExists(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Whether the log file exists or not.
logExists(long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
logExists(long) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Check whether an entrylog with the given ID exists.
logFile(File, int) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
LOGFILE_DIRECT_HEADER_SIZE - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
LOGFILE_HEADER_SIZE - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
The 1K block at the head of the entry logger file that contains the fingerprint and meta-data.
LOGFILE_LEGACY_HEADER_SIZE - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
logfileHeader - Variable in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
logFileId - Variable in class org.apache.bookkeeper.bookie.LogMark
 
logFilename(File, int) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
logFilename(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand.ReadLogMetadataFlags
 
logFileOffset - Variable in class org.apache.bookkeeper.bookie.LogMark
 
LOGGER - Static variable in interface org.apache.bookkeeper.common.util.SafeRunnable
 
logId() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
logId() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
logId() - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogReader
 
logId() - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogWriter
Return the ID of the log being written.
logId() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.WriterWithMetadata
 
logId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand.ActiveLedgerFlags
 
logId(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand.ReadLogMetadataFlags
 
logId2HexString(long) - Static method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Convert log Id to hex string.
logIdForOffset(long) - Static method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
logIdsInDirectory(File) - Static method in class org.apache.bookkeeper.util.LedgerDirUtil
 
LogMark - Class in org.apache.bookkeeper.bookie
Journal stream position.
LogMark() - Constructor for class org.apache.bookkeeper.bookie.LogMark
 
LogMark(long, long) - Constructor for class org.apache.bookkeeper.bookie.LogMark
 
LogMark(LogMark) - Constructor for class org.apache.bookkeeper.bookie.LogMark
 
LogMetadata - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
 
LogMetadata() - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.LogMetadata
 
logOpResult(int) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
LogReader - Interface in org.apache.bookkeeper.bookie.storage.directentrylogger
Interface for reading from a bookkeeper entry log.
LogReaderScan - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
 
LogReaderScan() - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.LogReaderScan
 
logRemovalListener - Variable in class org.apache.bookkeeper.bookie.AbstractLogCompactor
 
logResponse(BookkeeperProtocol.StatusCode, Object...) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
logSizeLimit - Variable in class org.apache.bookkeeper.bookie.EntryLogManagerBase
The maximum size of a entry logger file.
LogWriter - Interface in org.apache.bookkeeper.bookie.storage.directentrylogger
Interface for writing data to a bookkeeper entry log.
LONG - org.apache.bookkeeper.common.conf.Type
 
LONG_LEDGERID_FORMATTER - Static variable in class org.apache.bookkeeper.util.LedgerIdFormatter
 
LONG_SIZED - com.scurrilous.circe.HashSupport
Indicates that the hash algorithm is available as a StatefulLongHash and StatelessLongHash.
LongAdderCounter - Class in org.apache.bookkeeper.stats.prometheus
Counter implementation based on LongAdder.
LongAdderCounter(Map<String, String>) - Constructor for class org.apache.bookkeeper.stats.prometheus.LongAdderCounter
 
LONGHIERARCHICAL_LEDGER_PARENT_NODE_REGEX - Static variable in class org.apache.bookkeeper.util.StringUtils
 
LongHierarchicalLedgerManager - Class in org.apache.bookkeeper.meta
LongHierarchical Ledger Manager which manages ledger meta in zookeeper using 5-level hierarchical znodes.
LongHierarchicalLedgerManager(AbstractConfiguration, ZooKeeper) - Constructor for class org.apache.bookkeeper.meta.LongHierarchicalLedgerManager
Constructor.
LongHierarchicalLedgerManagerFactory - Class in org.apache.bookkeeper.meta
LongHierarchical Ledger Manager Factory.
LongHierarchicalLedgerManagerFactory() - Constructor for class org.apache.bookkeeper.meta.LongHierarchicalLedgerManagerFactory
 
LongLedgerIdFormatter() - Constructor for class org.apache.bookkeeper.util.LedgerIdFormatter.LongLedgerIdFormatter
 
longLM - Variable in class org.apache.bookkeeper.meta.HierarchicalLedgerManager
 
LongPair(long, long) - Constructor for class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.LongPair
 
LongPairWrapper - Class in org.apache.bookkeeper.bookie.storage.ldb
Recyclable wrapper that holds a pair of longs.
longPollPreWaitStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
LongPollReadEntryProcessorV3 - Class in org.apache.bookkeeper.proto
Processor handling long poll read entry request.
LongPollReadEntryProcessorV3(BookkeeperProtocol.Request, BookieRequestHandler, BookieRequestProcessor, ExecutorService, ExecutorService, HashedWheelTimer) - Constructor for class org.apache.bookkeeper.proto.LongPollReadEntryProcessorV3
 
longPollReadRequestStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
longPollReadStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
longPollWaitStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
LongVersion - Class in org.apache.bookkeeper.versioning
A version object holds integer version.
LongVersion(long) - Constructor for class org.apache.bookkeeper.versioning.LongVersion
 
LongWrapper - Class in org.apache.bookkeeper.bookie.storage.ldb
Wrapper for a long serialized into a byte array.
LongZkLedgerIdGenerator - Class in org.apache.bookkeeper.meta
ZooKeeper based ledger id generator class, which using EPHEMERAL_SEQUENTIAL with (ledgerIdGenPath)/HOB-[high-32-bits]/ID- prefix to generate ledger id.
LongZkLedgerIdGenerator(ZooKeeper, String, String, ZkLedgerIdGenerator, List<ACL>) - Constructor for class org.apache.bookkeeper.meta.LongZkLedgerIdGenerator
 
lookupClient(BookieId) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
LOST_BOOKIE_RECOVERY_DELAY - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
LOSTBOOKIERECOVERYDELAY_NODE - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
LostBookieRecoveryDelayCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.LostBookieRecoveryDelayCmd
 
LostBookieRecoveryDelayCommand - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Command to Setter and Getter for LostBookieRecoveryDelay value (in seconds) in metadata store.
LostBookieRecoveryDelayCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.LostBookieRecoveryDelayCommand
 
LostBookieRecoveryDelayCommand.LBRDFlags - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Flags for command LostBookieRecoveryDelay.
LostBookieRecoveryDelayService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper lost bookie recovery delay parameter related http request.
LostBookieRecoveryDelayService(ServerConfiguration, BookKeeperAdmin) - Constructor for class org.apache.bookkeeper.server.http.service.LostBookieRecoveryDelayService
 
LOWEST_COMPAT_PROTOCOL_VERSION - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Lowest protocol version which will work with the bookie.
lseek(int, long, int) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
lseek(int, long, int) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
lseek(int, long, int) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 
LURFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand.LURFlags
 

M

MAC - org.apache.bookkeeper.client.api.DigestType
Entries are verified by applied MAC algorithm.
MAC - org.apache.bookkeeper.client.BookKeeper.DigestType
 
MAC_CODE_LENGTH - Static variable in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
macCodeLength - Variable in class org.apache.bookkeeper.proto.checksum.DigestManager
 
MacDigestManager - Class in org.apache.bookkeeper.proto.checksum
A SHA-1 based digest manager.
MacDigestManager(long, byte[], boolean, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
macManager - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
magicWord - Variable in class org.apache.bookkeeper.bookie.JournalChannel
 
main(String[]) - Static method in class org.apache.bookkeeper.bookie.BookieShell
 
main(String[]) - Static method in class org.apache.bookkeeper.bookie.FileSystemUpgrade
 
main(String[]) - Static method in class org.apache.bookkeeper.proto.BookieClientImpl
 
main(String[]) - Static method in class org.apache.bookkeeper.proto.BookieServer
Legacy Method to run bookie server.
main(String[]) - Static method in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
main(String[]) - Static method in class org.apache.bookkeeper.server.Main
 
main(String[]) - Static method in class org.apache.bookkeeper.util.LocalBookKeeper
 
main(String[]) - Static method in class org.apache.bookkeeper.verifier.BookkeeperVerifierMain
 
Main - Class in org.apache.bookkeeper.server
A bookie server is a server that run bookie and serving rpc requests.
Main() - Constructor for class org.apache.bookkeeper.server.Main
 
mainWorkerPool - Variable in class org.apache.bookkeeper.client.BookKeeper
 
MAJOR_COMPACTION_COUNT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
MAJOR_COMPACTION_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAJOR_COMPACTION_MAX_TIME_MILLIS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAJOR_COMPACTION_THRESHOLD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
majorCompacting - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
majorCompacting(boolean) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
majorCompactionCounter(long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
majorCompactionInterval - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
majorCompactionMaxTimeMillis - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
majorCompactionThreshold - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
makeAdv() - Method in interface org.apache.bookkeeper.client.api.CreateBuilder
Switch the ledger into 'Advanced' mode.
makeAdv() - Method in class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
makeAvailable() - Method in interface org.apache.bookkeeper.bookie.storage.CompactionEntryLog
Make the log written by the compaction process available for reads.
makeAvailable() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
makeFeature(String) - Method in class org.apache.bookkeeper.feature.CacheableFeatureProvider
 
makeFeature(String) - Method in class org.apache.bookkeeper.feature.SettableFeatureProvider
 
makeName(String) - Method in class org.apache.bookkeeper.feature.CacheableFeatureProvider
 
makeProvider(String) - Method in class org.apache.bookkeeper.feature.CacheableFeatureProvider
 
makeProvider(String) - Method in class org.apache.bookkeeper.feature.SettableFeatureProvider
 
makeShellPath(File) - Static method in class org.apache.bookkeeper.util.HardLink
Convert a os-native filename to a path that works for the shell.
map - Variable in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
map - Variable in class org.apache.bookkeeper.util.collections.SynchronizedHashMultiMap
 
mapFillFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
mapFillFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
mapFillFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
mapFillFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
mapFillFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
mapFillFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
mapFillFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
mapFillFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
mapFillFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
mapFillFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
mapFillFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
mapFillFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
mapIdleFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
mapIdleFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
mapIdleFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
mapIdleFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
mapIdleFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
mapIdleFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
mapIdleFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
mapIdleFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
mapIdleFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
mapIdleFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
mapIdleFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
mapIdleFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
MARK_LIMBO - org.apache.bookkeeper.bookie.datainteg.Events
Mark a ledger as in-limbo.
markCompacted() - Method in interface org.apache.bookkeeper.bookie.storage.CompactionEntryLog
Mark the compaction log as compacted.
markDeleted() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
markLedgerReplicated(long) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Mark a ledger as fully replicated.
markLedgerReplicated(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
markLedgerReplicated(long) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
markLedgerUnderreplicated(long, String) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Mark a ledger as underreplicated.
markLedgerUnderreplicatedAsync(long, Collection<String>) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Mark a ledger as underreplicated with missing bookies.
markLedgerUnderreplicatedAsync(long, Collection<String>) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
markLedgerUnderreplicatedAsync(long, Collection<String>) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
markLog() - Method in class org.apache.bookkeeper.bookie.Journal.LastLogMark
 
markReaderIndex() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
markWriterIndex() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
MASK_BITS - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
MASTER_KEY_LENGTH - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The length of the master key in add packets.
masterKey - Variable in class org.apache.bookkeeper.bookie.FileInfo
 
masterKey - Variable in class org.apache.bookkeeper.bookie.LedgerCache.LedgerIndexMetadata
 
masterKey - Variable in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
masterKey - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
MASTERKEY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
MASTERKEY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
MASTERKEY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
MASTERKEY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
masterslave(StatsLogger, StatsLogger) - Static method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger
Create a broadcast stats logger of two stats loggers master and slave.
match(int, long, long, long, boolean) - Method in class com.scurrilous.circe.params.CrcParameters
Returns whether this object matches the given CRC parameters.
MathUtils - Class in org.apache.bookkeeper.common.util
Provides misc math functions that don't come standard.
MathUtils - Class in org.apache.bookkeeper.util
Provides misc math functions that don't come standard.
MathUtils() - Constructor for class org.apache.bookkeeper.common.util.MathUtils
 
MathUtils() - Constructor for class org.apache.bookkeeper.util.MathUtils
 
MAX - Static variable in interface org.apache.bookkeeper.bookie.CheckpointSource.Checkpoint
 
MAX_ADDS_IN_PROGRESS_LIMIT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAX_ALLOWED_ENSEMBLE_CHANGES - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
MAX_BACKUP_JOURNALS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAX_BATCH_READ_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAX_JOURNAL_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAX_LOG_SIZE_LIMIT - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
Set the max log size limit to 1GB.
MAX_OPERATION_NUMBERS_IN_SINGLE_ROCKSDB_WRITE_BATCH - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAX_PENDING_ADD_REQUESTS_PER_THREAD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAX_PENDING_READ_REQUESTS_PER_THREAD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAX_PRIORITY - Static variable in enum com.scurrilous.circe.HashSupport
The maximum priority value, indicating the lowest priority.
MAX_READS_IN_PROGRESS_LIMIT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MAX_SPECULATIVE_READ_LAC_TIMEOUT - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
MAX_SPECULATIVE_READ_TIMEOUT - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
MAX_THROTTLE_TIME_MILLIS - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
MAX_VALUE - Static variable in class org.apache.bookkeeper.bookie.LogMark
 
maxAddsInProgress - Variable in class org.apache.bookkeeper.proto.RequestStats
 
maxAddsInProgressCount() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
maxAddsInProgressCount() - Method in class org.apache.bookkeeper.proto.RequestStats
 
maxAlloc - Variable in class org.apache.bookkeeper.bookie.SkipListArena
 
maxAllowedEnsembleChanges - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
maxBackupJournals - Variable in class org.apache.bookkeeper.bookie.Journal
 
maxCapacity() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
maxCount - Variable in class org.apache.bookkeeper.client.BatchedReadOp.BatchedLedgerEntryRequest
 
maxCount - Variable in class org.apache.bookkeeper.client.BatchedReadOp
 
maxCount - Variable in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadRequest
 
maxEntriesPerScan - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
maxFrameSize - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
maxFrameSize - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
MAXIMUM_METADATA_FORMAT_VERSION - Static variable in class org.apache.bookkeeper.meta.LedgerMetadataSerDe
 
MAXIMUM_NUMBER_OF_ACTIVE_ENTRYLOGS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
maxJournalSize - Variable in class org.apache.bookkeeper.bookie.Journal
 
maxLac - Variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
MAXLAC_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
maxLatency - Variable in class org.apache.bookkeeper.proto.BKStats.OpStats
 
maxMissedReadsAllowed - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
maxOffset() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
maxOffset() - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogReader
 
maxOutstandingReads(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand.FlipBookieIdFlags
 
maxOutstandingReads(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags
 
maxProbabilityMultiplier - Variable in class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
maxProbabilityMultiplier - Variable in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
maxReadsInProgress - Variable in class org.apache.bookkeeper.proto.RequestStats
 
maxReadsInProgressCount() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
maxReadsInProgressCount() - Method in class org.apache.bookkeeper.proto.RequestStats
 
maxRecoveredData - Variable in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
maxSize - Variable in class org.apache.bookkeeper.client.BatchedReadOp.BatchedLedgerEntryRequest
 
maxSize - Variable in class org.apache.bookkeeper.client.BatchedReadOp
 
maxSize - Variable in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadRequest
 
maxSpeculativeRequestTimeout - Variable in class org.apache.bookkeeper.client.DefaultSpeculativeRequestExecutionPolicy
 
maxTasksInQueue - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
maxTasksInQueue - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
maxTasksInQueue(int) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
maxWeightMultiple - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
maxWeightMultiple - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
maxWritableBytes() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
maybeCopyEntry(WriteSets, NavigableMap<Long, Integer>, long, long, EntryCopier.Batch) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
maybeHandleDelayedWriteBookieFailure() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
maybeSendSpeculativeRead(BitSet) - Method in class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
maybeSendSpeculativeRead(BitSet) - Method in class org.apache.bookkeeper.client.PendingReadOp.ParallelReadRequest
 
maybeSendSpeculativeRead(BitSet) - Method in class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
Send to next replica speculatively, if required and possible.
maybeSendSpeculativeRead(BitSet) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ParallelReadRequest
 
maybeSendSpeculativeRead(BitSet) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
Send to next replica speculatively, if required and possible.
maybeSendSpeculativeRead(BitSet) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
Send to next replica speculatively, if required and possible.
maybeSendSpeculativeRead(BitSet) - Method in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
Send to next replica speculatively, if required and possible.
maybeTimeout() - Method in class org.apache.bookkeeper.client.PendingAddOp
 
maybeTimeout() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
maybeTimeout() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
maybeTimeout() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.GetBookieInfoCompletion
 
MB - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
MB - Static variable in class org.apache.bookkeeper.bookie.Journal
 
MB - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
md5() - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the MD5 algorithm (128 bits).
MD5 - Static variable in class com.scurrilous.circe.params.SimpleHashParameters
Represents the MD5 (128-bit) hash algorithm.
MdcUtils - Class in org.apache.bookkeeper.common.util
Utils for work with Slf4j MDC.
MdcUtils() - Constructor for class org.apache.bookkeeper.common.util.MdcUtils
 
MEETS_SOFT - org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementPolicyAdherence
 
MEETS_STRICT - org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementPolicyAdherence
 
memoryAddress() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
MemoryLimitController - Class in org.apache.bookkeeper.common.util
Controller for tracking the amount of memory used for some task.
MemoryLimitController(long) - Constructor for class org.apache.bookkeeper.common.util.MemoryLimitController
 
memTable - Variable in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
memTableStats - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 
merge(Value) - Method in class org.apache.bookkeeper.metastore.Value
Merge other value.
mergeAddRequest(BookkeeperProtocol.AddRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AddRequest addRequest = 101;
mergeAddResponse(BookkeeperProtocol.AddResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AddResponse addResponse = 101;
mergeAuthRequest(BookkeeperProtocol.AuthMessage) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AuthMessage authRequest = 102;
mergeAuthResponse(BookkeeperProtocol.AuthMessage) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AuthMessage authResponse = 102;
mergeForceLedgerRequest(BookkeeperProtocol.ForceLedgerRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ForceLedgerRequest forceLedgerRequest = 107;
mergeForceLedgerResponse(BookkeeperProtocol.ForceLedgerResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ForceLedgerResponse forceLedgerResponse = 107;
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
mergeFrom(Message) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
mergeFrom(DbLedgerStorageDataFormats.LedgerData) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
mergeFrom(BookkeeperProtocol.AddRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
mergeFrom(BookkeeperProtocol.AddResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
mergeFrom(BookkeeperProtocol.AuthMessage) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
mergeFrom(BookkeeperProtocol.BKPacketHeader) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
mergeFrom(BookkeeperProtocol.ContextPair) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
mergeFrom(BookkeeperProtocol.ForceLedgerRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
mergeFrom(BookkeeperProtocol.ForceLedgerResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
mergeFrom(BookkeeperProtocol.GetBookieInfoRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
mergeFrom(BookkeeperProtocol.GetBookieInfoResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
mergeFrom(BookkeeperProtocol.GetListOfEntriesOfLedgerRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
mergeFrom(BookkeeperProtocol.GetListOfEntriesOfLedgerResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
mergeFrom(BookkeeperProtocol.ReadLacRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
mergeFrom(BookkeeperProtocol.ReadLacResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
mergeFrom(BookkeeperProtocol.ReadRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
mergeFrom(BookkeeperProtocol.ReadResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
mergeFrom(BookkeeperProtocol.Request) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
mergeFrom(BookkeeperProtocol.Response) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
mergeFrom(BookkeeperProtocol.StartTLSRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
mergeFrom(BookkeeperProtocol.StartTLSResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
mergeFrom(BookkeeperProtocol.WriteLacRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
mergeFrom(BookkeeperProtocol.WriteLacResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
mergeFrom(DataFormats.AuditorVoteFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
mergeFrom(DataFormats.BookieServiceInfoFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
mergeFrom(DataFormats.BookieServiceInfoFormat.Endpoint) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
mergeFrom(DataFormats.CheckAllLedgersFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
mergeFrom(DataFormats.CookieFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
mergeFrom(DataFormats.LedgerMetadataFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
mergeFrom(DataFormats.LedgerMetadataFormat.cMetadataMapEntry) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
mergeFrom(DataFormats.LedgerMetadataFormat.Segment) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
mergeFrom(DataFormats.LedgerRereplicationLayoutFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
mergeFrom(DataFormats.LockDataFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
mergeFrom(DataFormats.PlacementPolicyCheckFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
mergeFrom(DataFormats.ReplicasCheckFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
mergeFrom(DataFormats.UnderreplicatedLedgerFormat) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
mergeGetBookieInfoRequest(BookkeeperProtocol.GetBookieInfoRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
mergeGetBookieInfoResponse(BookkeeperProtocol.GetBookieInfoResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
mergeGetListOfEntriesOfLedgerRequest(BookkeeperProtocol.GetListOfEntriesOfLedgerRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
mergeGetListOfEntriesOfLedgerResponse(BookkeeperProtocol.GetListOfEntriesOfLedgerResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
mergeHeader(BookkeeperProtocol.BKPacketHeader) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
required .BKPacketHeader header = 1;
mergeHeader(BookkeeperProtocol.BKPacketHeader) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
required .BKPacketHeader header = 1;
mergeIteratorsForPrimitiveLongIterator(Iterator<T>, Iterator<T>, Comparator<T>, ToLongFunction<T>) - Static method in class org.apache.bookkeeper.util.IteratorUtility
Merges two sorted iterators and returns merged iterator sorted using comparator.
mergePrimitiveLongIterator(PrimitiveIterator.OfLong, PrimitiveIterator.OfLong) - Static method in class org.apache.bookkeeper.util.IteratorUtility
Merges two long primitive sorted iterators and returns merged iterator.
mergeReadLacRequest(BookkeeperProtocol.ReadLacRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ReadLacRequest readLacRequest = 104;
mergeReadLacResponse(BookkeeperProtocol.ReadLacResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ReadLacResponse readLacResponse = 104;
mergeReadRequest(BookkeeperProtocol.ReadRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
Requests
mergeReadResponse(BookkeeperProtocol.ReadResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
Response
mergeStartTLSRequest(BookkeeperProtocol.StartTLSRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .StartTLSRequest startTLSRequest = 106;
mergeStartTLSResponse(BookkeeperProtocol.StartTLSResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .StartTLSResponse startTLSResponse = 106;
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
mergeWriteLacRequest(BookkeeperProtocol.WriteLacRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .WriteLacRequest writeLacRequest = 103;
mergeWriteLacResponse(BookkeeperProtocol.WriteLacResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .WriteLacResponse writeLacResponse = 103;
meta(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.LedgerCommand.LedgerFlags
 
meta(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListLedgersCommand.ListLedgersFlags
 
META_FIELD - Static variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
metadata - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
METADATA_CACHE - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
METADATA_FORMAT_VERSION_1 - Static variable in class org.apache.bookkeeper.meta.LedgerMetadataSerDe
Text based manual serialization.
METADATA_FORMAT_VERSION_2 - Static variable in class org.apache.bookkeeper.meta.LedgerMetadataSerDe
Protobuf based, serialized using TextFormat.
METADATA_FORMAT_VERSION_3 - Static variable in class org.apache.bookkeeper.meta.LedgerMetadataSerDe
Protobuf based, serialized in binary format.
METADATA_LENGTH - Static variable in class org.apache.bookkeeper.proto.checksum.DigestManager
 
METADATA_SERVICE_ERROR - org.apache.bookkeeper.meta.exceptions.Code
 
METADATA_SERVICE_URI - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
MetadataAsyncIterator - Class in org.apache.bookkeeper.bookie.datainteg
An rxjava ledger metadata iterator.
MetadataAsyncIterator(Scheduler, LedgerManager, int, int, TimeUnit) - Constructor for class org.apache.bookkeeper.bookie.datainteg.MetadataAsyncIterator
 
MetadataBookieDriver - Interface in org.apache.bookkeeper.meta
Driver to manage all the metadata managers required by a bookie server.
MetadataBookieDriverInfo(Class<? extends MetadataBookieDriver>) - Constructor for class org.apache.bookkeeper.meta.MetadataDrivers.MetadataBookieDriverInfo
 
MetadataClientDriver - Interface in org.apache.bookkeeper.meta
Driver to manage all the metadata managers required by a bookkeeper client.
MetadataClientDriver.SessionStateListener - Interface in org.apache.bookkeeper.meta
State Listener on listening the metadata client session states.
MetadataClientDriverInfo(Class<? extends MetadataClientDriver>) - Constructor for class org.apache.bookkeeper.meta.MetadataDrivers.MetadataClientDriverInfo
 
metadataDriver - Variable in class org.apache.bookkeeper.client.BookKeeper
 
metadataDriver(MetadataBookieDriver) - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
 
MetadataDrivers - Class in org.apache.bookkeeper.meta
A driver manager for managing a set of metadata drivers.
MetadataDrivers.MetadataBookieDriverInfo - Class in org.apache.bookkeeper.meta
 
MetadataDrivers.MetadataClientDriverInfo - Class in org.apache.bookkeeper.meta
 
MetadataException - Exception in org.apache.bookkeeper.meta.exceptions
Metadata Exception.
MetadataException(Code, String) - Constructor for exception org.apache.bookkeeper.meta.exceptions.MetadataException
 
MetadataException(Code, String, Throwable) - Constructor for exception org.apache.bookkeeper.meta.exceptions.MetadataException
 
MetadataException(Code, Throwable) - Constructor for exception org.apache.bookkeeper.meta.exceptions.MetadataException
 
metadataFormatVersion - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
metadataForRecovery - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
metadataLock - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
MetadataSerializationException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Failure to serialize metadata.
MetadataStoreException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
MetadataStoreException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.MetadataStoreException
 
MetadataStoreException(String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.MetadataStoreException
 
MetadataStoreException(String, Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.MetadataStoreException
 
MetadataStoreException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.MetadataStoreException
 
MetadataUpdateLoop - Class in org.apache.bookkeeper.client
Mechanism to safely update the metadata of a ledger.
MetadataUpdateLoop(LedgerManager, long, Supplier<Versioned<LedgerMetadata>>, MetadataUpdateLoop.NeedsUpdatePredicate, MetadataUpdateLoop.MetadataTransform, MetadataUpdateLoop.LocalValueUpdater) - Constructor for class org.apache.bookkeeper.client.MetadataUpdateLoop
 
MetadataUpdateLoop(LedgerManager, long, Supplier<Versioned<LedgerMetadata>>, MetadataUpdateLoop.NeedsUpdatePredicate, MetadataUpdateLoop.MetadataTransform, MetadataUpdateLoop.LocalValueUpdater, RateLimiter) - Constructor for class org.apache.bookkeeper.client.MetadataUpdateLoop
Construct the loop.
MetadataUpdateLoop.LocalValueUpdater - Interface in org.apache.bookkeeper.client
 
MetadataUpdateLoop.MetadataTransform - Interface in org.apache.bookkeeper.client
 
MetadataUpdateLoop.NeedsUpdatePredicate - Interface in org.apache.bookkeeper.client
 
MetadataUpdater(Versioned<LedgerMetadata>) - Constructor for class org.apache.bookkeeper.client.ReadOnlyLedgerHandle.MetadataUpdater
 
MetadataVersion(int) - Constructor for class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.MetadataVersion
 
MetadataVersion(InMemoryMetastoreTable.MetadataVersion) - Constructor for class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.MetadataVersion
 
MetadataVersionException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Bad version on executing metadata operations.
METAENTRY_ID_FENCE_KEY - Static variable in class org.apache.bookkeeper.bookie.BookieImpl
 
METAENTRY_ID_FORCE_LEDGER - Static variable in class org.apache.bookkeeper.bookie.BookieImpl
 
METAENTRY_ID_LEDGER_EXPLICITLAC - Static variable in class org.apache.bookkeeper.bookie.BookieImpl
 
METAENTRY_ID_LEDGER_KEY - Static variable in class org.apache.bookkeeper.bookie.BookieImpl
 
MetaFormatCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.MetaFormatCmd
 
MetaFormatCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Format the bookkeeper metadata present in zookeeper.
MetaFormatCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.MetaFormatCommand
 
MetaFormatCommand.MetaFormatFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Flags for command meta format.
MetaFormatFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.MetaFormatCommand.MetaFormatFlags
 
metastore - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
metastore - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
MetaStore - Interface in org.apache.bookkeeper.metastore
Metadata Store Interface.
METASTORE_IMPL_CLASS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
METASTORE_MAX_ENTRIES_PER_SCAN - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
MetastoreCallback<T> - Interface in org.apache.bookkeeper.metastore
Metastore callback.
MetastoreCursor - Interface in org.apache.bookkeeper.metastore
A Metastore Cursor.
MetastoreCursor.ReadEntriesCallback - Interface in org.apache.bookkeeper.metastore
A callback for reading entries.
MetastoreException - Exception in org.apache.bookkeeper.metastore
A marker for Metastore exceptions.
MetastoreException(String) - Constructor for exception org.apache.bookkeeper.metastore.MetastoreException
 
MetastoreException(String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MetastoreException
 
MetastoreException(Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MetastoreException
 
MetaStoreException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Meta store operations failed.
MetaStoreException() - Constructor for exception org.apache.bookkeeper.client.BKException.MetaStoreException
 
MetaStoreException(Throwable) - Constructor for exception org.apache.bookkeeper.client.BKException.MetaStoreException
 
MetastoreFactory - Class in org.apache.bookkeeper.metastore
Metastore Factory.
MetastoreFactory() - Constructor for class org.apache.bookkeeper.metastore.MetastoreFactory
 
MetastoreScannableTable - Interface in org.apache.bookkeeper.metastore
Metastore Scannable Table.
MetastoreScannableTable.Order - Enum in org.apache.bookkeeper.metastore
The order to loop over a table.
MetastoreTable - Interface in org.apache.bookkeeper.metastore
Metastore Table interface.
MetastoreTableItem - Class in org.apache.bookkeeper.metastore
Identify an item in a metastore table.
MetastoreTableItem(String, Versioned<Value>) - Constructor for class org.apache.bookkeeper.metastore.MetastoreTableItem
 
MetastoreUtils - Class in org.apache.bookkeeper.metastore
Provides utilities for metastore.
MetastoreUtils() - Constructor for class org.apache.bookkeeper.metastore.MetastoreUtils
 
MetastoreUtils.MultiMetastoreCallback<T> - Class in org.apache.bookkeeper.metastore
 
MetastoreUtils.SyncMetastoreCallback<T> - Class in org.apache.bookkeeper.metastore
 
MetastoreWatcher - Interface in org.apache.bookkeeper.metastore
Metastore watcher.
meter - Variable in class org.apache.bookkeeper.stats.otel.OtelMetricsProvider
 
metricNameSet - Variable in class org.apache.bookkeeper.stats.prometheus.PrometheusTextFormat
 
metrics - Variable in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
metrics - Variable in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
 
MetricsService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle exposing metrics.
MetricsService(ServerConfiguration, StatsProvider) - Constructor for class org.apache.bookkeeper.server.http.service.MetricsService
 
MIN - Static variable in interface org.apache.bookkeeper.bookie.CheckpointSource.Checkpoint
 
MIN_ALLOWABLE_ARGS - Static variable in class org.apache.bookkeeper.net.ScriptBasedMapping
Minimum number of arguments: 1.
MIN_COMPAT_JOURNAL_FORMAT_VERSION - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
MIN_NUM_RACKS_PER_WRITE_QUORUM - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
MIN_NUM_ZONES_PER_WRITE_QUORUM - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
MIN_PRIORITY - Static variable in enum com.scurrilous.circe.HashSupport
The minimum priority value, indicating the highest priority.
MIN_SANE_ENTRY_SIZE - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
MIN_USABLESIZE_FOR_ENTRYLOG_CREATION - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MIN_USABLESIZE_FOR_HIGH_PRIORITY_WRITES - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MIN_USABLESIZE_FOR_INDEXFILE_CREATION - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MINIMUM_REGIONS_FOR_DURABILITY_DEFAULT - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
minLatency - Variable in class org.apache.bookkeeper.proto.BKStats.OpStats
 
minNumRacksPerWriteQuorum - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
minNumRacksPerWriteQuorum - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
minNumZonesPerWriteQuorum - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
MINOR_COMPACTION_COUNT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
MINOR_COMPACTION_INTERVAL - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MINOR_COMPACTION_MAX_TIME_MILLIS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
MINOR_COMPACTION_THRESHOLD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
minorCompacting - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
minorCompacting(boolean) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
minorCompactionCounter(long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
minorCompactionInterval - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
minorCompactionMaxTimeMillis - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
minorCompactionThreshold - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
minRacksOrRegionsForDurability - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
minRegionsForDurability - Variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
missing(long) - Static method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult
 
MISSING - org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult.State
 
MissingEntryException(long, long, long, long) - Constructor for exception org.apache.bookkeeper.bookie.DefaultEntryLogger.EntryLookupException.MissingEntryException
 
MissingLogFileException(long, long, long, long) - Constructor for exception org.apache.bookkeeper.bookie.DefaultEntryLogger.EntryLookupException.MissingLogFileException
 
missingReplica(String) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand.LURFlags
 
mode - Variable in class org.apache.bookkeeper.bookie.FileInfo
 
mountLedgerStorageOffline(ServerConfiguration, LedgerStorage) - Static method in class org.apache.bookkeeper.bookie.BookieImpl
Initialize LedgerStorage instance without checkpointing for use within the shell and other RO users.
moveAndShift(int, int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
Move an index from one position to another, shifting the other indices accordingly.
moveToClosed() - Method in class org.apache.bookkeeper.common.component.Lifecycle
 
moveToNewLocation(File, long) - Method in class org.apache.bookkeeper.bookie.FileInfo
Copies current file contents upto specified size to the target file and deletes the current file.
moveToStarted() - Method in class org.apache.bookkeeper.common.component.Lifecycle
 
moveToStopped() - Method in class org.apache.bookkeeper.common.component.Lifecycle
 
MSException - Exception in org.apache.bookkeeper.metastore
Marker for metastore exceptions.
MSException(MSException.Code, String) - Constructor for exception org.apache.bookkeeper.metastore.MSException
 
MSException(MSException.Code, String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MSException
 
MSException.BadVersionException - Exception in org.apache.bookkeeper.metastore
A BadVersion exception.
MSException.Code - Enum in org.apache.bookkeeper.metastore
Return codes.
MSException.IllegalOpException - Exception in org.apache.bookkeeper.metastore
Illegal operation exception.
MSException.KeyExistsException - Exception in org.apache.bookkeeper.metastore
Key Exists Exception.
MSException.MSInterruptedException - Exception in org.apache.bookkeeper.metastore
Metastore interruption exception.
MSException.NoEntriesException - Exception in org.apache.bookkeeper.metastore
Exception would be thrown in a cursor if no entries found.
MSException.NoKeyException - Exception in org.apache.bookkeeper.metastore
Exception in cases where there is no key.
MSException.OperationFailureException - Exception in org.apache.bookkeeper.metastore
Operation failure exception.
MSException.ServiceDownException - Exception in org.apache.bookkeeper.metastore
Service down exception.
msg(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand.ReadJournalFlags
 
msg(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
msg(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
MSInterruptedException(String) - Constructor for exception org.apache.bookkeeper.metastore.MSException.MSInterruptedException
 
MSInterruptedException(String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MSException.MSInterruptedException
 
MsLedgerManager(AbstractConfiguration, ZooKeeper, MetaStore) - Constructor for class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
MSLedgerManagerFactory - Class in org.apache.bookkeeper.meta
Deprecated.
since 4.7.0
MSLedgerManagerFactory() - Constructor for class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
MSLedgerManagerFactory.MsLedgerManager - Class in org.apache.bookkeeper.meta
Deprecated.
 
MSLedgerManagerFactory.MsLedgerManager.MSLedgerRangeIterator - Class in org.apache.bookkeeper.meta
Deprecated.
 
MSLedgerManagerFactory.MsLedgerManager.ReadLedgerMetadataTask - Class in org.apache.bookkeeper.meta
Deprecated.
 
MSLedgerManagerFactory.SyncResult<T> - Class in org.apache.bookkeeper.meta
Deprecated.
 
MSLedgerRangeIterator() - Constructor for class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager.MSLedgerRangeIterator
Deprecated.
 
MSWatchedEvent - Class in org.apache.bookkeeper.metastore
A metastore watched event.
MSWatchedEvent(String, MSWatchedEvent.EventType) - Constructor for class org.apache.bookkeeper.metastore.MSWatchedEvent
 
MSWatchedEvent.EventType - Enum in org.apache.bookkeeper.metastore
The metastore event type.
multi(Iterable<Op>) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
multi(Iterable<Op>, AsyncCallback.MultiCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
MultiCallback(int, AsyncCallback.VoidCallback, Object, int, int) - Constructor for class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
MultiCallback(int, AsyncCallback.VoidCallback, Object, int, int, ExecutorService) - Constructor for class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
MultiMetastoreCallback(int) - Constructor for class org.apache.bookkeeper.metastore.MetastoreUtils.MultiMetastoreCallback
 
murmur3_128() - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the MurmurHash3 algorithm, 128-bit x64 variant, with a seed of 0.
murmur3_128(int) - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the MurmurHash3 algorithm, 128-bit x64 variant, with the given seed value.
murmur3_32() - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the MurmurHash3 algorithm, 32-bit x86 variant, with a seed of 0.
murmur3_32(int) - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the MurmurHash3 algorithm, 32-bit x86 variant, with the given seed value
MurmurHash3Parameters - Class in com.scurrilous.circe.params
Hash parameters for MurmurHash3.
MurmurHash3Parameters(MurmurHash3Variant) - Constructor for class com.scurrilous.circe.params.MurmurHash3Parameters
Constructs a MurmurHash3Parameters with the given variant and a seed value of zero.
MurmurHash3Parameters(MurmurHash3Variant, int) - Constructor for class com.scurrilous.circe.params.MurmurHash3Parameters
Constructs a MurmurHash3Parameters with the given variant and seed value.
MurmurHash3Variant - Enum in com.scurrilous.circe.params
Enumeration of MurmurHash3 variants.
MyCommand(String) - Constructor for class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
myNode - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
myRegion - Variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
myZone - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 

N

name - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
name - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
name - Variable in class org.apache.bookkeeper.feature.FixedValueFeature
 
name - Variable in class org.apache.bookkeeper.net.NodeBase
 
name() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Name of the configuration setting.
name() - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
Name of the key group.
name() - Method in interface org.apache.bookkeeper.feature.Feature
Returns a textual representation of the feature.
name() - Method in class org.apache.bookkeeper.feature.FixedValueFeature
 
name() - Method in annotation type org.apache.bookkeeper.stats.annotations.StatsDoc
The name of this stats.
name() - Method in class org.apache.bookkeeper.tools.framework.Cli
 
name() - Method in class org.apache.bookkeeper.tools.framework.CliCommand
 
name() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
name() - Method in interface org.apache.bookkeeper.tools.framework.Command
Return command name.
name() - Method in class org.apache.bookkeeper.tools.framework.HelpCommand
 
name(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
Name of the configuration setting.
name(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Name of the configuration setting.
name(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup.ConfigKeyGroupBuilder
Name of the key group.
name(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
Name of the key group.
name(String) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
NAME - Static variable in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
NAME - Static variable in class org.apache.bookkeeper.meta.HierarchicalLedgerManagerFactory
 
NAME - Static variable in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
NAME - Static variable in class org.apache.bookkeeper.meta.LongHierarchicalLedgerManagerFactory
 
NAME - Static variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
NAME - Static variable in class org.apache.bookkeeper.server.service.AutoRecoveryService
 
NAME - Static variable in class org.apache.bookkeeper.server.service.BookieService
 
NAME - Static variable in class org.apache.bookkeeper.server.service.HttpService
 
NAME - Static variable in class org.apache.bookkeeper.server.service.StatsProviderService
 
namespace - Variable in class org.apache.bookkeeper.tools.common.BKFlags
 
NarSystem - Class in com.scurrilous.circe.checksum
Generated class to load the correct version of the jni library
NarSystem - Class in org.apache.bookkeeper.util.nativeio
Generated class to load the correct version of the jni library
NarSystem - Class in org.apache.bookkeeper.utils.affinity
Generated class to load the correct version of the jni library
NATIVE - com.scurrilous.circe.HashSupport
Indicates that the hash algorithm is available in native code.
NATIVE_INCREMENTAL - com.scurrilous.circe.HashSupport
Indicates that the hash algorithm is available in native code as a IncrementalIntHash or IncrementalLongHash, depending on which of HashSupport.INT_SIZED or HashSupport.LONG_SIZED is set.
nativeBuffer - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
nativeIO - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
nativeIO - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
NativeIO - Interface in org.apache.bookkeeper.common.util.nativeio
NativeIO API.
NativeIOException - Exception in org.apache.bookkeeper.common.util.nativeio
NativeIOException.
NativeIOException(String) - Constructor for exception org.apache.bookkeeper.common.util.nativeio.NativeIOException
 
NativeIOException(String, int) - Constructor for exception org.apache.bookkeeper.common.util.nativeio.NativeIOException
 
NativeIOImpl - Class in org.apache.bookkeeper.common.util.nativeio
NativeIOImpl.
NativeIOImpl() - Constructor for class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
NativeIOJni - Class in org.apache.bookkeeper.common.util.nativeio
 
NativeIOJni() - Constructor for class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 
NativeUtils - Class in com.scurrilous.circe.utils
Utils for loading native checksum library.
NativeUtils - Class in org.apache.bookkeeper.common.util.affinity.impl
Utility class to load jni library from inside a JAR.
NativeUtils - Class in org.apache.bookkeeper.common.util.nativeio
Utility class to load jni library from inside a JAR.
NativeUtils() - Constructor for class com.scurrilous.circe.utils.NativeUtils
 
NEEDS_INTEGRITY_CHECK - org.apache.bookkeeper.bookie.LedgerStorage.StorageState
 
needsFullCheck() - Method in interface org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheck
Whether we need to run a full check.
needsFullCheck() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
needsUpdate(LedgerMetadata) - Method in interface org.apache.bookkeeper.client.MetadataUpdateLoop.NeedsUpdatePredicate
 
NET_TOPOLOGY_SCRIPT_FILE_NAME_KEY - Static variable in interface org.apache.bookkeeper.net.CommonConfigurationKeys
 
NET_TOPOLOGY_SCRIPT_NUMBER_ARGS_DEFAULT - Static variable in interface org.apache.bookkeeper.net.CommonConfigurationKeys
 
NET_TOPOLOGY_SCRIPT_NUMBER_ARGS_KEY - Static variable in interface org.apache.bookkeeper.net.CommonConfigurationKeys
 
netlock - Variable in class org.apache.bookkeeper.net.NetworkTopologyImpl
The lock used to manage access.
NETTY_EXCEPTION_CNT - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
NETTY_MAX_FRAME_SIZE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
NETTY_OPS - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
NETTY_USE_POOLED_BUFFERS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
NettyChannelUtil - Class in org.apache.bookkeeper.util
Contains utility methods for working with Netty Channels.
nettyMaxFrameSizeBytes - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
nettyServer - Variable in class org.apache.bookkeeper.proto.BookieServer
 
NetUtils - Class in org.apache.bookkeeper.net
Network Utilities.
NetUtils() - Constructor for class org.apache.bookkeeper.net.NetUtils
 
NETWORK_TOPOLOGY_STABILIZE_PERIOD_SECONDS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
NetworkTopology - Interface in org.apache.bookkeeper.net
Network Topology Interface.
NetworkTopologyImpl - Class in org.apache.bookkeeper.net
The class represents a cluster of computer with a tree hierarchical network topology.
NetworkTopologyImpl() - Constructor for class org.apache.bookkeeper.net.NetworkTopologyImpl
 
NetworkTopologyImpl.InnerNode - Class in org.apache.bookkeeper.net
InnerNode represents a switch/router of a data center or rack.
NetworkTopologyImpl.InvalidTopologyException - Exception in org.apache.bookkeeper.net
A marker for an InvalidTopology Exception.
NEW - Static variable in interface org.apache.bookkeeper.versioning.Version
Initial version.
NEW_ENSEMBLE_TIME - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
newBatch() - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
newBatch() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
 
newBatch() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
newBatch(long, LedgerMetadata) - Method in interface org.apache.bookkeeper.bookie.datainteg.EntryCopier
Start copying a new batch.
newBatch(long, LedgerMetadata) - Method in class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl
 
newBookieAuthProviderFactory(ServerConfiguration) - Static method in class org.apache.bookkeeper.auth.AuthProviderFactoryFactory
 
newBookieImpl(ServerConfiguration, RegistrationManager, LedgerStorage, DiskChecker, LedgerDirsManager, LedgerDirsManager, StatsLogger, ByteBufAllocator, Supplier<BookieServiceInfo>) - Static method in class org.apache.bookkeeper.bookie.BookieImpl
 
newBookieServer(ServerConfiguration, Bookie, StatsLogger, ByteBufAllocator, UncleanShutdownDetection) - Static method in class org.apache.bookkeeper.proto.BookieServer
 
newBookKeeperAdmin(ClientConfiguration) - Static method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
newBuilder() - Static method in class org.apache.bookkeeper.bookie.Cookie
Returns Cookie builder.
newBuilder() - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
newBuilder() - Static method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
newBuilder() - Static method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
newBuilder() - Static method in class org.apache.bookkeeper.tools.framework.CliSpec
Create a new builder to build the cli spec.
newBuilder() - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
newBuilder() - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
newBuilder() - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
newBuilder() - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
newBuilder() - Static method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
newBuilder() - Static method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
newBuilder() - Static method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
newBuilder(Cookie) - Static method in class org.apache.bookkeeper.bookie.Cookie
Returns Cookie builder with the copy of given oldCookie.
newBuilder(DbLedgerStorageDataFormats.LedgerData) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
newBuilder(ClientConfiguration) - Static method in interface org.apache.bookkeeper.client.api.BookKeeper
Create a new builder which can be used to boot a new BookKeeper client.
newBuilder(BookkeeperProtocol.AddRequest) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
newBuilder(BookkeeperProtocol.AddResponse) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
newBuilder(BookkeeperProtocol.AuthMessage) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
newBuilder(BookkeeperProtocol.BKPacketHeader) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
newBuilder(BookkeeperProtocol.ContextPair) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
newBuilder(BookkeeperProtocol.ForceLedgerRequest) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
newBuilder(BookkeeperProtocol.ForceLedgerResponse) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
newBuilder(BookkeeperProtocol.GetBookieInfoRequest) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
newBuilder(BookkeeperProtocol.GetBookieInfoResponse) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
newBuilder(BookkeeperProtocol.GetListOfEntriesOfLedgerRequest) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
newBuilder(BookkeeperProtocol.GetListOfEntriesOfLedgerResponse) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
newBuilder(BookkeeperProtocol.ReadLacRequest) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
newBuilder(BookkeeperProtocol.ReadLacResponse) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
newBuilder(BookkeeperProtocol.ReadRequest) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
newBuilder(BookkeeperProtocol.ReadResponse) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
newBuilder(BookkeeperProtocol.Request) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
newBuilder(BookkeeperProtocol.Response) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
newBuilder(BookkeeperProtocol.StartTLSRequest) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
newBuilder(BookkeeperProtocol.StartTLSResponse) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
newBuilder(BookkeeperProtocol.WriteLacRequest) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
newBuilder(BookkeeperProtocol.WriteLacResponse) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
newBuilder(DataFormats.AuditorVoteFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
newBuilder(DataFormats.BookieServiceInfoFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
newBuilder(DataFormats.BookieServiceInfoFormat.Endpoint) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
newBuilder(DataFormats.CheckAllLedgersFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
newBuilder(DataFormats.CookieFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
newBuilder(DataFormats.LedgerMetadataFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
newBuilder(DataFormats.LedgerMetadataFormat.cMetadataMapEntry) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
newBuilder(DataFormats.LedgerMetadataFormat.Segment) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
newBuilder(DataFormats.LedgerRereplicationLayoutFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
newBuilder(DataFormats.LockDataFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
newBuilder(DataFormats.PlacementPolicyCheckFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
newBuilder(DataFormats.ReplicasCheckFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
newBuilder(DataFormats.UnderreplicatedLedgerFormat) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
newBuilder(CliSpec<T>) - Static method in class org.apache.bookkeeper.tools.framework.CliSpec
Create a new builder to build the cli spec from an existing spec.
newBuilderForType() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
newBuilderForType() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
newCheckpoint() - Method in interface org.apache.bookkeeper.bookie.CheckpointSource
Request a new a checkpoint.
newCheckpoint() - Method in class org.apache.bookkeeper.bookie.CheckpointSourceList
 
newCheckpoint() - Method in class org.apache.bookkeeper.bookie.Journal
Application tried to schedule a checkpoint.
newClientAuthProviderFactory(ClientConfiguration) - Static method in class org.apache.bookkeeper.auth.AuthProviderFactoryFactory
 
newClusterInfoCommand() - Static method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand
 
newCompactionLog(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
newCompactionLog(long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
newCompactionLog(long) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Create a new entrylog into which compacted entries can be added.
newCompletionKey(long, BookkeeperProtocol.OperationType) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
newComponent(Class<? extends ServerLifecycleComponent>, BookieConfiguration, StatsLogger) - Static method in class org.apache.bookkeeper.server.component.ServerLifecycleComponent
 
newCreateLedgerOp() - Method in interface org.apache.bookkeeper.client.api.BookKeeper
Start the creation of a new ledger.
newCreateLedgerOp() - Method in class org.apache.bookkeeper.client.BookKeeper
 
newDeleteLedgerOp() - Method in interface org.apache.bookkeeper.client.api.BookKeeper
Delete an existing ledger.
newDeleteLedgerOp() - Method in class org.apache.bookkeeper.client.BookKeeper
 
newDirectBuffer(int, int) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorImpl
 
newDirectReader(int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
newEnsemble(int, int, int, Map<String, byte[]>) - Method in interface org.apache.bookkeeper.client.BookieWatcher
Create an ensemble with given ensembleSize and writeQuorumSize.
newEnsemble(int, int, int, Map<String, byte[]>) - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
 
newEnsemble(int, int, int, Map<String, byte[]>, Set<BookieId>) - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
newEnsemble(int, int, int, Map<String, byte[]>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
newEnsemble(int, int, int, Map<String, byte[]>, Set<BookieId>) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Choose numBookies bookies for ensemble.
newEnsemble(int, int, int, Map<String, byte[]>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
newEnsemble(int, int, int, Map<String, byte[]>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
newEnsemble(int, int, int, Map<String, byte[]>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
newEnsemble(int, int, int, Map<String, byte[]>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicy
 
newEnsemble(int, int, int, Map<String, byte[]>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
newEnsemble(int, int, int, Set<BookieId>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
newEnsemble(int, int, int, Set<BookieId>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
newEnsemble(int, int, int, Set<BookieId>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
newEnsemble(int, int, int, Set<BookieId>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<T>, ITopologyAwareEnsemblePlacementPolicy.Predicate<T>) - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy
Create an ensemble with parent ensemble.
newEnsembleEntry(long, List<BookieId>) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
newEnsembleInternal(int, int, int, Set<BookieId>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
newEntryFormatter(String, AbstractConfiguration) - Static method in class org.apache.bookkeeper.util.EntryFormatter
 
newEntryFormatter(AbstractConfiguration<?>) - Static method in class org.apache.bookkeeper.util.EntryFormatter
 
newExecutor() - Static method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
newExecutor() - Static method in class org.apache.bookkeeper.bookie.SyncThread
 
newFlags() - Static method in class org.apache.bookkeeper.tools.cli.commands.bookies.ListBookiesCommand.Flags
 
newFlags() - Static method in class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand.Flags
 
newHeapBuffer(int, int) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorImpl
 
newInstance() - Method in class org.apache.bookkeeper.common.collections.RecyclableArrayList.Recycler
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
newInstance(Class<T>) - Static method in class org.apache.bookkeeper.common.util.ReflectionUtils
Create an object for the given class.
newInstance(String, Class<T>) - Static method in class org.apache.bookkeeper.common.util.ReflectionUtils
Create an object using the given class name.
newInstance(StatsLogger) - Static method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
newJournal(int, File, ServerConfiguration, LedgerDirsManager, StatsLogger, ByteBufAllocator, JournalAliveListener) - Static method in class org.apache.bookkeeper.bookie.Journal
 
newKeyValueStorage(String, String, KeyValueStorageFactory.DbConfigType, ServerConfiguration) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageFactory
 
newLastMarkCommand() - Static method in class org.apache.bookkeeper.tools.cli.commands.bookie.LastMarkCommand
 
newLedgerAuditorManager() - Method in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
newLedgerAuditorManager() - Method in interface org.apache.bookkeeper.meta.LedgerManagerFactory
Return a ledger auditor manager, which is used to coordinate the auto-recovery process.
newLedgerAuditorManager() - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
newLedgerAuditorManager() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
newLedgerAuditorManager() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
newLedgerIdFormatter(String, AbstractConfiguration) - Static method in class org.apache.bookkeeper.util.LedgerIdFormatter
 
newLedgerIdFormatter(AbstractConfiguration<?>) - Static method in class org.apache.bookkeeper.util.LedgerIdFormatter
 
newLedgerIdGenerator() - Method in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
newLedgerIdGenerator() - Method in class org.apache.bookkeeper.meta.HierarchicalLedgerManagerFactory
 
newLedgerIdGenerator() - Method in interface org.apache.bookkeeper.meta.LedgerManagerFactory
Return the ledger id generator, which is used for global unique ledger id generation.
newLedgerIdGenerator() - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
newLedgerIdGenerator() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
newLedgerIdGenerator() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
newLedgerManager() - Method in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
newLedgerManager() - Method in class org.apache.bookkeeper.meta.HierarchicalLedgerManagerFactory
 
newLedgerManager() - Method in interface org.apache.bookkeeper.meta.LedgerManagerFactory
return ledger manager for client-side to manage ledger metadata.
newLedgerManager() - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
newLedgerManager() - Method in class org.apache.bookkeeper.meta.LongHierarchicalLedgerManagerFactory
 
newLedgerManager() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
newLedgerManager() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
newLedgerManagerFactory(AbstractConfiguration<?>, LayoutManager) - Static method in class org.apache.bookkeeper.meta.AbstractZkLedgerManagerFactory
Create new Ledger Manager Factory.
newLedgerUnderreplicationManager() - Method in class org.apache.bookkeeper.meta.FlatLedgerManagerFactory
Deprecated.
 
newLedgerUnderreplicationManager() - Method in interface org.apache.bookkeeper.meta.LedgerManagerFactory
Return a ledger underreplication manager, which is used to mark ledgers as unreplicated, and to retrieve a ledger which is underreplicated so that it can be rereplicated.
newLedgerUnderreplicationManager() - Method in class org.apache.bookkeeper.meta.LegacyHierarchicalLedgerManagerFactory
 
newLedgerUnderreplicationManager() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
newLedgerUnderreplicationManager() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
newLegacyCookieValidation(ServerConfiguration, RegistrationManager) - Static method in class org.apache.bookkeeper.bookie.LegacyCookieValidation
 
newListBookiesCommand(ListBookiesCommand.Flags) - Static method in class org.apache.bookkeeper.tools.cli.commands.bookies.ListBookiesCommand
 
newListLedgersOp() - Method in interface org.apache.bookkeeper.client.api.BookKeeper
List ledgers.
newListLedgersOp() - Method in class org.apache.bookkeeper.client.BookKeeper
 
newLog(int, int, File, long, ExecutorService, BufferPool, NativeIO, ByteBufAllocator, Slogger) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
newLogFile(long, Long) - Method in class org.apache.bookkeeper.bookie.Journal
 
newMetadata - Variable in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle.MetadataUpdater
 
newObject(Recycler.Handle<RecyclableArrayList<X>>) - Method in class org.apache.bookkeeper.common.collections.RecyclableArrayList.Recycler
 
newOpenLedgerOp() - Method in interface org.apache.bookkeeper.client.api.BookKeeper
Open an existing ledger.
newOpenLedgerOp() - Method in class org.apache.bookkeeper.client.BookKeeper
 
newProvider(String) - Static method in interface org.apache.bookkeeper.bookie.FileChannelProvider
 
newProvider(BookieConnectionPeer, AuthCallbacks.GenericCallback<Void>) - Method in interface org.apache.bookkeeper.auth.BookieAuthProvider.Factory
Create a new instance of a bookie auth provider.
newProvider(BookieConnectionPeer, AuthCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
newProvider(BookieConnectionPeer, AuthCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.tls.BookieAuthZFactory
 
newProvider(ClientConnectionPeer, AuthCallbacks.GenericCallback<Void>) - Method in interface org.apache.bookkeeper.auth.ClientAuthProvider.Factory
Create a new instance of a client auth provider.
newProvider(ClientConnectionPeer, AuthCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
newScanner(EntryLogMetadata) - Method in class org.apache.bookkeeper.bookie.EntryLogCompactor.CompactionScannerFactory
 
newScheduledExecutorService() - Static method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
newSchedulerBuilder() - Static method in class org.apache.bookkeeper.common.util.OrderedScheduler
Create a builder to build ordered scheduler.
newSimpleTestCommand(SimpleTestCommand.Flags) - Static method in class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand
 
newSingleDirectoryDbLedgerStorage(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, EntryLogger, StatsLogger, long, long, int, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
newSlogger(Optional<Class<?>>, Iterable<Object>) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
newSlogger(Optional<Class<?>>, Iterable<Object>) - Method in class org.apache.bookkeeper.slogger.ConsoleSlogger
 
newSlogger(Optional<Class<?>>, Iterable<Object>) - Method in class org.apache.bookkeeper.slogger.slf4j.Slf4jSlogger
 
newThread(Runnable) - Method in class org.apache.bookkeeper.util.DaemonThreadFactory
 
newTLSHandler() - Method in interface org.apache.bookkeeper.tls.SecurityHandlerFactory
 
newTLSHandler() - Method in class org.apache.bookkeeper.tls.TLSContextFactory
 
newTLSHandler(String, int) - Method in interface org.apache.bookkeeper.tls.SecurityHandlerFactory
 
newTLSHandler(String, int) - Method in class org.apache.bookkeeper.tls.TLSContextFactory
 
newTxnId() - Method in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
newZKRegistrationClient(ZooKeeper, String, ScheduledExecutorService, boolean) - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
newZKRegistrationManager(ServerConfiguration, ZooKeeper) - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataBookieDriver
 
next() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage.CloseableIterator
 
next() - Method in interface org.apache.bookkeeper.client.api.LedgersIterator
Return next ledger id.
next() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterator
 
next() - Method in interface org.apache.bookkeeper.meta.LedgerManager.LedgerRangeIterator
Get the next element.
next() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager.MSLedgerRangeIterator
Deprecated.
 
next() - Method in class org.apache.bookkeeper.slogger.AbstractSlogger.CtxIterator
 
next() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo.EntryIterator
 
nextAlignment(int) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
nextEntryId - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterator
 
nextFreePort() - Static method in class org.apache.bookkeeper.util.PortManager
Return an available port.
nextId() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.EntryLogIdsImpl
 
nextId() - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogIds
Get the next available entry log ID.
nextPrealloc - Variable in class org.apache.bookkeeper.bookie.JournalChannel
 
nextReplicaIndexToReadFrom - Variable in class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
nextReplicaIndexToReadFrom - Variable in class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
 
nextReplicaIndexToReadFrom - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
nextRetryWaitTime() - Method in class org.apache.bookkeeper.zookeeper.ZooWorker
 
nextRetryWaitTime(int, long) - Method in class org.apache.bookkeeper.zookeeper.BoundExponentialBackoffRetryPolicy
 
nextRetryWaitTime(int, long) - Method in class org.apache.bookkeeper.zookeeper.ExponentialBackoffRetryPolicy
 
nextRetryWaitTime(int, long) - Method in class org.apache.bookkeeper.zookeeper.ExponentialBackOffWithDeadlinePolicy
 
nextRetryWaitTime(int, long) - Method in interface org.apache.bookkeeper.zookeeper.RetryPolicy
Called before making an attempt to retry a failed operation.
nioBuffer() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
nioBuffer(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
nioBufferCount() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
nioBuffers() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
nioBuffers(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
NO_INFO - Static variable in class org.apache.bookkeeper.discover.BookieServiceInfo
Default empty implementation.
NO_MASTER_KEY - Static variable in class org.apache.bookkeeper.bookie.FileInfo
 
NO_SCRIPT - Static variable in class org.apache.bookkeeper.net.ScriptBasedMapping
Text used in the ScriptBasedMapping.toString() method if there is no string "no script".
NO_TASK_LIMIT - Static variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
NoBookieAvailableException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Unused.
Node - Interface in org.apache.bookkeeper.net
The interface defines a node in a network topology.
NODE_SEPARATOR - Static variable in class org.apache.bookkeeper.net.NetworkTopologyImpl
 
NodeBase - Class in org.apache.bookkeeper.net
A base class that implements interface Node.
NodeBase() - Constructor for class org.apache.bookkeeper.net.NodeBase
Default constructor.
NodeBase(String) - Constructor for class org.apache.bookkeeper.net.NodeBase
Construct a node from its path.
NodeBase(String, String) - Constructor for class org.apache.bookkeeper.net.NodeBase
Construct a node from its name and its location.
NodeBase(String, String, Node, int) - Constructor for class org.apache.bookkeeper.net.NodeBase
Construct a node from its name and its location.
NodeStatus() - Constructor for class org.apache.bookkeeper.net.StabilizeNetworkTopology.NodeStatus
 
nodeStatuses - Variable in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
NoEntries - org.apache.bookkeeper.metastore.MSException.Code
 
NoEntriesException(String) - Constructor for exception org.apache.bookkeeper.metastore.MSException.NoEntriesException
 
NoEntriesException(String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MSException.NoEntriesException
 
NoEntryException(long, long) - Constructor for exception org.apache.bookkeeper.bookie.Bookie.NoEntryException
 
NoEntryException(String, long, long) - Constructor for exception org.apache.bookkeeper.bookie.Bookie.NoEntryException
 
NoIndexForLedgerException(String, Exception) - Constructor for exception org.apache.bookkeeper.bookie.LedgerCache.NoIndexForLedgerException
 
NoKey - org.apache.bookkeeper.metastore.MSException.Code
 
NoKeyException(String) - Constructor for exception org.apache.bookkeeper.metastore.MSException.NoKeyException
 
NoKeyException(String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MSException.NoKeyException
 
NoLedgerException(long) - Constructor for exception org.apache.bookkeeper.bookie.Bookie.NoLedgerException
 
NON_FIELDS - Static variable in interface org.apache.bookkeeper.metastore.MetastoreTable
 
none - org.apache.bookkeeper.stats.codahale.FastTimer.Buckets
 
NONE - Static variable in enum org.apache.bookkeeper.client.api.WriteFlag
No flag is set, use default behaviour.
NONE - Static variable in interface org.apache.bookkeeper.common.util.Backoff.Policy
 
NonFatalPredicate - Static variable in class org.apache.bookkeeper.common.util.Retries
 
nonInteractive(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FormatCommand.Flags
 
NonRecoverableReplicationException(String) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException.NonRecoverableReplicationException
 
NonRecoverableReplicationException(String, Throwable) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException.NonRecoverableReplicationException
 
NoopCloseCallback() - Constructor for class org.apache.bookkeeper.client.LedgerHandle.NoopCloseCallback
 
NopWriteCallback() - Constructor for class org.apache.bookkeeper.bookie.BookieImpl.NopWriteCallback
 
NormalByteCrc - Class in com.scurrilous.circe.crc
Implements a "normal" MSB-first byte-width CRC function using a lookup table.
NormalByteCrc(String, int, int, int, int) - Constructor for class com.scurrilous.circe.crc.NormalByteCrc
 
NormalIntCrc - Class in com.scurrilous.circe.crc
Implements a "normal" MSB-first int-width CRC function using a lookup table.
NormalIntCrc(String, int, int, int, int) - Constructor for class com.scurrilous.circe.crc.NormalIntCrc
 
normalize(String) - Static method in class org.apache.bookkeeper.net.NodeBase
Normalize a path by stripping off any trailing NodeBase.PATH_SEPARATOR.
normalizeHostName(String) - Static method in class org.apache.bookkeeper.net.NetUtils
Given a string representation of a host, return its ip address in textual presentation.
normalizeHostNames(Collection<String>) - Static method in class org.apache.bookkeeper.net.NetUtils
Given a collection of string representation of hosts, return a list of corresponding IP addresses in the textual representation.
NormalLongCrc - Class in com.scurrilous.circe.crc
Implements a "normal" MSB-first long-width CRC function using a lookup table.
NormalLongCrc(String, int, long, long, long) - Constructor for class com.scurrilous.circe.crc.NormalLongCrc
 
NoSuchEntryException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
No such entry exists.
NoSuchLedgerExistsException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
No such ledger exists.
NoSuchLedgerExistsOnMetadataServerException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
No such ledger exists one metadata server.
NOT_ASSIGNED_LAC - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
NOT_FOUND - Static variable in class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
NOT_FOUND - Static variable in class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
 
NOT_FOUND - Static variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
NotEnoughBookiesException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Not enough bookies available to form an ensemble.
notifyBookieError(BookieId) - Method in class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl.BatchImpl
 
notifyLedgerReplicationEnabled(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Receive notification asynchronously when the ledger replication process is enabled.
notifyLedgerReplicationEnabled(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
notifyLedgerReplicationEnabled(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
notifyLostBookieRecoveryDelayChanged(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Receive notification asynchronously when the lostBookieRecoveryDelay value is Changed.
notifyLostBookieRecoveryDelayChanged(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
notifyLostBookieRecoveryDelayChanged(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
notifyRename(File, File) - Method in interface org.apache.bookkeeper.bookie.FileChannelProvider
Notify the rename source file name to the target file name operation.
notifyUnderReplicationLedgerChanged(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Deprecated.
notifyUnderReplicationLedgerChanged(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
notifyUnderReplicationLedgerChanged(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
notifyWatchers(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
notifyWatchers(Function<R, T>, R) - Method in class org.apache.bookkeeper.common.util.Watchable
Notify the watchers with the update value.
notifyWriteFailed(int, BookieId) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
notSupportBatch - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
nowInNano() - Static method in class org.apache.bookkeeper.common.util.MathUtils
Current time from some arbitrary time base in the past, counting in nanoseconds, and not affected by settimeofday or similar system clock changes.
NoWritableLedgerDirException(String) - Constructor for exception org.apache.bookkeeper.bookie.LedgerDirsManager.NoWritableLedgerDirException
 
nukeExistingCluster() - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Nukes existing cluster metadata.
nukeExistingCluster() - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
nukeExistingCluster() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
nukeExistingCluster(ServerConfiguration, String, String, boolean) - Static method in class org.apache.bookkeeper.client.BookKeeperAdmin
Nukes existing cluster metadata.
NukeExistingCluster() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.NukeExistingCluster
 
NukeExistingClusterCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Nuke bookkeeper metadata of existing cluster in zookeeper.
NukeExistingClusterCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.NukeExistingClusterCommand
 
NukeExistingClusterCommand.NukeExistingClusterFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Flags for nuke existing cluster command.
NukeExistingClusterFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.NukeExistingClusterCommand.NukeExistingClusterFlags
 
NULL - Static variable in class org.apache.bookkeeper.auth.AuthToken
 
NULL - Static variable in interface org.apache.bookkeeper.bookie.Checkpointer
 
NULL - Static variable in interface org.apache.bookkeeper.slogger.Slogger
 
NULL_WRITE_SET - Static variable in interface org.apache.bookkeeper.client.DistributionSchedule
 
nullCounter - Static variable in class org.apache.bookkeeper.stats.NullStatsLogger
 
NullCounter() - Constructor for class org.apache.bookkeeper.stats.NullStatsLogger.NullCounter
 
NullLayoutManager() - Constructor for class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLayoutManager
 
NullLedgerAuditorManager() - Constructor for class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerAuditorManager
 
NullLedgerIdGenerator() - Constructor for class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerIdGenerator
 
NullLedgerManager() - Constructor for class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
NullLedgerManagerFactory() - Constructor for class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
NullLedgerUnderreplicationManager() - Constructor for class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
NullMetadataBookieDriver - Class in org.apache.bookkeeper.meta
A no-op implementation of MetadataBookieDriver.
NullMetadataBookieDriver() - Constructor for class org.apache.bookkeeper.meta.NullMetadataBookieDriver
 
NullMetadataBookieDriver.NullLayoutManager - Class in org.apache.bookkeeper.meta
A no-op implementation of LayoutManager.
NullMetadataBookieDriver.NullLedgerAuditorManager - Class in org.apache.bookkeeper.meta
A no-op implementation of LedgerAuditorManager.
NullMetadataBookieDriver.NullLedgerIdGenerator - Class in org.apache.bookkeeper.meta
A no-op implementation of LedgerIdGenerator.
NullMetadataBookieDriver.NullLedgerManager - Class in org.apache.bookkeeper.meta
A no-op implementation of LedgerManager.
NullMetadataBookieDriver.NullLedgerManagerFactory - Class in org.apache.bookkeeper.meta
A no-op implementation of LedgerManagerFactory.
NullMetadataBookieDriver.NullLedgerUnderreplicationManager - Class in org.apache.bookkeeper.meta
A no-op implementation of LedgerUnderreplicationManager.
NullMetadataBookieDriver.NullRegistrationManager - Class in org.apache.bookkeeper.meta
A no-op implementation of RegistrationManager.
nullOpStats - Variable in class org.apache.bookkeeper.stats.NullStatsLogger.NullOpStatsLogger
 
nullOpStatsLogger - Static variable in class org.apache.bookkeeper.stats.NullStatsLogger
 
NullOpStatsLogger() - Constructor for class org.apache.bookkeeper.stats.NullStatsLogger.NullOpStatsLogger
 
NullRegistrationManager() - Constructor for class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
NullSlogger - Class in org.apache.bookkeeper.slogger
 
NullSlogger() - Constructor for class org.apache.bookkeeper.slogger.NullSlogger
 
nullStatsLogger - Variable in class org.apache.bookkeeper.stats.NullStatsProvider
 
NullStatsLogger - Class in org.apache.bookkeeper.stats
A no-op StatsLogger.
NullStatsLogger() - Constructor for class org.apache.bookkeeper.stats.NullStatsLogger
 
NullStatsLogger.NullCounter - Class in org.apache.bookkeeper.stats
A no-op Counter.
NullStatsLogger.NullOpStatsLogger - Class in org.apache.bookkeeper.stats
A no-op OpStatsLogger.
NullStatsProvider - Class in org.apache.bookkeeper.stats
A no-op stats provider implementation.
NullStatsProvider() - Constructor for class org.apache.bookkeeper.stats.NullStatsProvider
 
NullValidator - Class in org.apache.bookkeeper.common.conf.validators
A validator that does nothing.
NUM_ADD_WORKER_THREADS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
NUM_BOOKIE_AUDITS_DELAYED - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_BOOKIES_PER_LEDGER - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_BUCKETS - Static variable in class org.apache.bookkeeper.proto.BKStats.OpStats
 
NUM_BYTES_READ - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_BYTES_WRITTEN - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_CHANNELS_PER_BOOKIE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
NUM_DEFER_LEDGER_LOCK_RELEASE_OF_FAILED_LEDGER - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_DELAYED_BOOKIE_AUDITS_DELAYES_CANCELLED - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_ENTRIES_READ - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_ENTRIES_UNABLE_TO_READ_FOR_REPLICATION - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_ENTRIES_WRITTEN - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_FRAGMENTS_PER_LEDGER - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_FULL_OR_PARTIAL_LEDGERS_REPLICATED - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_HIGH_PRIORITY_WORKER_THREADS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
NUM_INDEX_PAGES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
NUM_IO_THREADS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
NUM_JOURNAL_CALLBACK_THREADS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
NUM_LEDGERS_CHECKED - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_LEDGERS_HAVING_LESS_THAN_AQ_REPLICAS_OF_AN_ENTRY - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_LEDGERS_HAVING_LESS_THAN_WQ_REPLICAS_OF_AN_ENTRY - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_LEDGERS_HAVING_MULTIPLE_ENTRYLOGS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
NUM_LEDGERS_HAVING_NO_REPLICA_OF_AN_ENTRY - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_LEDGERS_NOT_ADHERING_TO_PLACEMENT_POLICY - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_LEDGERS_SOFTLY_ADHERING_TO_PLACEMENT_POLICY - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_LONG_POLL_WORKER_THREADS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
NUM_NOT_ADHERING_PLACEMENT_LEDGERS_REPLICATED - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_OF_EXPONENTIAL_BACKOFF_RETRIALS - Static variable in class org.apache.bookkeeper.replication.ReplicationWorker
 
NUM_OF_WRITE_ACTIVE_LEDGERS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
NUM_OF_WRITE_LEDGERS_REMOVED_CACHE_EXPIRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
NUM_OF_WRITE_LEDGERS_REMOVED_CACHE_MAXSIZE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
NUM_READ_WORKER_THREADS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
NUM_SKIPPING_CHECK_TASK_TIMES - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_STATS - Static variable in class org.apache.bookkeeper.proto.BKStats
 
NUM_UNDER_REPLICATED_LEDGERS - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_UNDERREPLICATED_LEDGERS_ELAPSED_RECOVERY_GRACE_PERIOD - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
NUM_WORKER_THREADS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
NUM_WRITABLE_BOOKIES_IN_DEFAULT_FAULTDOMAIN - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
NUM_WRITABLE_BOOKIES_IN_DEFAULT_RACK - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
NUMBER_OF_MEMTABLE_FLUSH_THREADS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
numberOfBookies - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
numBookiesMissingEntry - Variable in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
numEnsembleChanges - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
numEntries - Variable in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.RecoveryStats
 
numEntries(int) - Method in class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand.Flags
 
numFailedOps - Variable in class org.apache.bookkeeper.proto.BKStats.OpStats
 
numFinished - Variable in class org.apache.bookkeeper.metastore.MetastoreUtils.MultiMetastoreCallback
 
numMissedEntryReads - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
numOfRacks - Variable in class org.apache.bookkeeper.net.NetworkTopologyImpl
Rack counter.
numOps - Variable in class org.apache.bookkeeper.metastore.MetastoreUtils.MultiMetastoreCallback
 
numPendingEntries - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
numPendings - Variable in class org.apache.bookkeeper.client.PendingReadOp.ParallelReadRequest
 
numPendings - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ParallelReadRequest
 
numResponsesPending - Variable in class org.apache.bookkeeper.client.PendingReadLacOp
 
numResponsesPending - Variable in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
numSuccessOps - Variable in class org.apache.bookkeeper.proto.BKStats.OpStats
 
numThreads - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
numThreads(int) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
numWritableBookiesInDefaultFaultDomain - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
numWritableBookiesInDefaultRack - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 

O

O_CREAT - Static variable in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
O_DIRECT - Static variable in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
O_DSYNC - Static variable in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
O_RDONLY - Static variable in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
O_TRUNC - Static variable in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
O_WRONLY - Static variable in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
obtain(BookkeeperInternalCallbacks.GenericCallback<PerChannelBookieClient>, long) - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
obtain(BookkeeperInternalCallbacks.GenericCallback<PerChannelBookieClient>, long) - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientPool
Obtain a channel from channel pool to execute operations.
obtain(BookkeeperInternalCallbacks.GenericCallback<PerChannelBookieClient>, long, boolean) - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
obtain(BookkeeperInternalCallbacks.GenericCallback<PerChannelBookieClient>, long, boolean) - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientPool
Obtain a channel from channel pool by version to execute operations.
of() - Static method in class org.apache.bookkeeper.common.conf.validators.NullValidator
Return the instance of NullValidator.
of(long) - Static method in class org.apache.bookkeeper.bookie.LastAddConfirmedUpdateNotification
 
of(long) - Static method in class org.apache.bookkeeper.common.util.Backoff.Constant
Create infinite constant backoff stream.
of(long, long) - Static method in class org.apache.bookkeeper.common.util.Backoff.Constant
 
of(long, long, int) - Static method in class org.apache.bookkeeper.common.util.Backoff.Exponential
Create an infinite exponential backoff policy.
of(long, long, int, int) - Static method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
of(Class) - Static method in class org.apache.bookkeeper.common.conf.ConfigDef
Build the config definitation of a config class.
of(Class<T>) - Static method in class org.apache.bookkeeper.common.conf.validators.ClassValidator
Create a validator to validate if a setting is returning a class that extends from interfaceClass.
of(Backoff.Jitter.Type, long, long) - Static method in class org.apache.bookkeeper.common.util.Backoff.Jitter
Create infinite jittered backoff stream.
of(Backoff.Jitter.Type, long, long, long) - Static method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
of(T, EnsemblePlacementPolicy.PlacementPolicyAdherence) - Static method in class org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementResult
 
offer(T) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
offer(T) - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
offer(T, long, TimeUnit) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
offer(T, long, TimeUnit) - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
offer(T, long, TimeUnit) - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
offset - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
offsets - Variable in class org.apache.bookkeeper.bookie.EntryLogCompactor.CompactionScannerFactory
 
offsets - Variable in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor
 
ok(long, LedgerMetadata) - Static method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult
 
OK - org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult.State
 
OK - org.apache.bookkeeper.metastore.MSException.Code
 
OK - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
OK - Static variable in class org.apache.bookkeeper.bookie.ExitCode
 
OK - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Everything is OK.
oldBookie2NewBookie - Variable in class org.apache.bookkeeper.client.LedgerFragmentReplicator.SingleFragmentCallback
 
onAddRequestFinish() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
onAddRequestStart(Channel) - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
onBookieRackChange(List<BookieId>) - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy
Handle rack change for the bookies.
onBookieRackChange(List<BookieId>) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
onBookieRackChange(List<BookieId>) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
onBookiesChanged(Versioned<Set<BookieId>>) - Method in interface org.apache.bookkeeper.discover.RegistrationClient.RegistrationListener
 
onChanged(long, Versioned<LedgerMetadata>) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
onChanged(long, Versioned<LedgerMetadata>) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.LedgerMetadataListener
Triggered each time ledger metadata changed.
onClusterChanged(Set<BookieId>, Set<BookieId>) - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
onClusterChanged(Set<BookieId>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
onClusterChanged(Set<BookieId>, Set<BookieId>) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
A consistent view of the cluster (what bookies are available as writable, what bookies are available as readonly) is updated when any changes happen in the cluster.
onClusterChanged(Set<BookieId>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
onClusterChanged(Set<BookieId>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
onClusterChanged(Set<BookieId>, Set<BookieId>) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicy
 
onEntryComplete(int, LedgerHandle, LedgerEntry, Object) - Method in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
onEntryComplete(int, LedgerHandle, LedgerEntry, Object) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.ReadEntryListener
On given entry completed.
onExit() - Method in class org.apache.bookkeeper.client.BookieInfoReader
 
onFailure(Throwable) - Method in interface org.apache.bookkeeper.common.concurrent.FutureEventListener
 
onFailure(Throwable) - Method in class org.apache.bookkeeper.common.stats.OpStatsListener
 
onJournalExit() - Method in interface org.apache.bookkeeper.bookie.JournalAliveListener
 
onLastOp - Variable in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
onLastOpComplete(Consumer<Integer>, Consumer<Consumer<Integer>>) - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
The idea here is that we may need to register an operation which needs to run whenever the final op completes on this Ledger (like deletion).
onLastWrite - Variable in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
onLastWriteComplete(Consumer<Integer>, Consumer<Consumer<Integer>>) - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
Very similar to onLastOpComplete, but gets called on the final call to closeWrite.
onlyDisplayLedgerCount(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand.LURFlags
 
onProtocolUpgrade() - Method in interface org.apache.bookkeeper.auth.BookieAuthProvider
Callback to let the provider know that the underlying protocol is changed.
onProtocolUpgrade() - Method in interface org.apache.bookkeeper.auth.ClientAuthProvider
Callback to let the provider know that the underlying protocol is changed.
onReadRequestFinish() - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
onReadRequestStart(Channel) - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
onRegistrationExpired() - Method in interface org.apache.bookkeeper.discover.RegistrationManager.RegistrationListener
Signal when registration is expired.
onResetInUse(LedgerEntryPage) - Method in interface org.apache.bookkeeper.bookie.LEPStateChangeCallback
 
onResponseTimeout - Variable in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
onRotateEntryLog() - Method in interface org.apache.bookkeeper.bookie.DefaultEntryLogger.EntryLogListener
Rotate a new entry log to write.
onRotateEntryLog() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
onRotateEntryLog() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
onSessionExpired() - Method in interface org.apache.bookkeeper.meta.MetadataClientDriver.SessionStateListener
Signal when client session is expired.
onSetClean(LedgerEntryPage) - Method in interface org.apache.bookkeeper.bookie.LEPStateChangeCallback
 
onSetDirty(LedgerEntryPage) - Method in interface org.apache.bookkeeper.bookie.LEPStateChangeCallback
 
onSetInUse(LedgerEntryPage) - Method in interface org.apache.bookkeeper.bookie.LEPStateChangeCallback
 
onSizeLimitReached(CheckpointSource.Checkpoint) - Method in interface org.apache.bookkeeper.bookie.CacheCallback
Process notification that cache size limit reached.
onSizeLimitReached(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
onSpinWait() - Static method in class org.apache.bookkeeper.common.collections.BusyWait
If available (Java 9+), use intrinsic Thread#onSpinWait which will reduce CPU consumption during the wait, otherwise fallback to regular spinning.
onSuccess(T) - Method in interface org.apache.bookkeeper.common.concurrent.FutureEventListener
 
onSuccess(T) - Method in class org.apache.bookkeeper.common.stats.OpStatsListener
 
OpBuilder<T> - Interface in org.apache.bookkeeper.client.api
Base interface for builders.
opCode - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
opCode - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
open(File, ServerConfiguration) - Method in class org.apache.bookkeeper.bookie.DefaultFileChannelProvider
 
open(File, ServerConfiguration) - Method in interface org.apache.bookkeeper.bookie.FileChannelProvider
Get the BookieFileChannel with the given file and configuration.
open(String, int, int) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
open(String, int, int) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
open(String, int, int) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 
OPEN - org.apache.bookkeeper.client.api.LedgerMetadata.State
The ledger is open.
OPEN - org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
OPEN = 1;
OPEN_FILE_LIMIT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
OPEN_LEDGER_REREPLICATION_GRACE_PERIOD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
OPEN_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
OPEN_VALUE - Static variable in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
OPEN = 1;
OpenBuilder - Interface in org.apache.bookkeeper.client.api
Builder-style interface to open exiting ledgers.
OpenBuilderBase - Class in org.apache.bookkeeper.client.impl
Base class for open builders which does the mundane builder stuff.
OpenBuilderBase() - Constructor for class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
OpenBuilderImpl(BookKeeper) - Constructor for class org.apache.bookkeeper.client.LedgerOpenOp.OpenBuilderImpl
 
openComplete(int, LedgerHandle) - Method in class org.apache.bookkeeper.client.LedgerOpenOp
 
openComplete(int, LedgerHandle, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.OpenCallback
Callback for asynchronous call to open ledger.
openComplete(int, LedgerHandle, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.SyncOpenCallback
Callback method for synchronous open operation.
openCursor(String, boolean, String, boolean, MetastoreScannableTable.Order, Set<String>, MetastoreCallback<MetastoreCursor>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
openCursor(String, boolean, String, boolean, MetastoreScannableTable.Order, Set<String>, MetastoreCallback<MetastoreCursor>, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreScannableTable
Open a cursor to loop over the entries belonging to a key range, which returns the specified fields for each entry.
openCursor(String, boolean, String, boolean, MetastoreScannableTable.Order, MetastoreCallback<MetastoreCursor>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
openCursor(String, boolean, String, boolean, MetastoreScannableTable.Order, MetastoreCallback<MetastoreCursor>, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreScannableTable
Open a cursor to loop over the entries belonging to a key range, which returns all fields for each entry.
openCursor(Set<String>, MetastoreCallback<MetastoreCursor>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
openCursor(Set<String>, MetastoreCallback<MetastoreCursor>, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreTable
Open a cursor to loop over all the entries of the table, which returns the specified fields for each entry.
openCursor(MetastoreCallback<MetastoreCursor>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
openCursor(MetastoreCallback<MetastoreCursor>, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreTable
Open a cursor to loop over all the entries of the table, which returns all fields for each entry.
openCursorLatch - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager.MSLedgerRangeIterator
Deprecated.
 
openFileLimit - Variable in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
openLedger(long) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Open a ledger as an administrator.
openLedger(long, BookKeeper.DigestType, byte[]) - Method in class org.apache.bookkeeper.client.BookKeeper
Synchronous open ledger call.
openLedgerNoRecovery(long) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Open a ledger as an administrator without recovering the ledger.
openLedgerNoRecovery(long, BookKeeper.DigestType, byte[]) - Method in class org.apache.bookkeeper.client.BookKeeper
Synchronous, unsafe open ledger call.
openOpLogger - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
openWrite(long) - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
OPERATION_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
operationComplete(int, Void) - Method in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler.AuthHandshakeCompleteCallback
 
operationComplete(int, Void) - Method in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthHandshakeCompleteCallback
 
operationComplete(int, Void) - Method in class org.apache.bookkeeper.replication.ReplicationEnableCb
 
operationComplete(int, AuthToken) - Method in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler.AuthRequestCallback
 
operationComplete(int, AuthToken) - Method in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthResponseCallback
 
operationComplete(int, AuthToken) - Method in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthResponseCallbackLegacy
 
operationComplete(int, PerChannelBookieClient) - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
operationComplete(int, T) - Method in interface org.apache.bookkeeper.auth.AuthCallbacks.GenericCallback
 
operationComplete(int, T) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.GenericCallback
 
operationComplete(int, T) - Method in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.GenericCallbackFuture
 
operationComplete(int, T) - Method in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.TimedGenericCallback
 
operationComplete(int, T) - Method in class org.apache.bookkeeper.util.OrderedGenericCallback
 
operationComplete(ChannelFuture) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ConnectionFutureListener
 
operationComplete(ChannelFuture) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ContextPreservingFutureListener
 
OperationFailure - org.apache.bookkeeper.metastore.MSException.Code
 
OperationFailureException(String) - Constructor for exception org.apache.bookkeeper.metastore.MSException.OperationFailureException
 
OperationFailureException(String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MSException.OperationFailureException
 
OperationRejectedException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
OperationRejectedException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.OperationRejectedException
 
operationRetryPolicy - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
operationRetryPolicy(RetryPolicy) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
operationType - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionKey
 
OPPORTUNISTIC_STRIPING - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
OpStatData(long, long, double, long, long, String) - Constructor for class org.apache.bookkeeper.proto.BKStats.OpStatData
 
opStats - Variable in class org.apache.bookkeeper.stats.otel.OtelMetricsProvider
 
opStats - Variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
OpStats() - Constructor for class org.apache.bookkeeper.proto.BKStats.OpStats
 
OpStatsData - Class in org.apache.bookkeeper.stats
This class provides a read view of operation specific stats.
OpStatsData(long, long, double, long[]) - Constructor for class org.apache.bookkeeper.stats.OpStatsData
 
OpStatsListener<T> - Class in org.apache.bookkeeper.common.stats
A FutureEventListener monitors the stats for a given operation.
OpStatsListener(OpStatsLogger) - Constructor for class org.apache.bookkeeper.common.stats.OpStatsListener
 
OpStatsListener(OpStatsLogger, Stopwatch) - Constructor for class org.apache.bookkeeper.common.stats.OpStatsListener
 
OpStatsLogger - Interface in org.apache.bookkeeper.stats
This interface handles logging of statistics related to each operation.
opStatsLoggers - Variable in class org.apache.bookkeeper.stats.CachingStatsLogger
 
optionValues() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The list of options for this setting.
optionValues(List<String>) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
The list of options for this setting.
optionValues(List<String>) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The list of options for this setting.
opts - Variable in class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
order() - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
The order of the key-group in a configuration.
order() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
order(int) - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup.ConfigKeyGroupBuilder
The order of the key-group in a configuration.
order(int) - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
The order of the key-group in a configuration.
order(ByteOrder) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
orderedEnsemble - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
OrderedExecutor - Class in org.apache.bookkeeper.common.util
This class supports submitting tasks with an ordering key, so that tasks submitted with the same key will always be executed in order, but tasks across different keys can be unordered.
OrderedExecutor(String, int, ThreadFactory, StatsLogger, boolean, boolean, long, int, boolean, boolean) - Constructor for class org.apache.bookkeeper.common.util.OrderedExecutor
Constructs Safe executor.
OrderedExecutor.AbstractBuilder<T extends OrderedExecutor> - Class in org.apache.bookkeeper.common.util
Abstract builder class to build OrderedScheduler.
OrderedExecutor.Builder - Class in org.apache.bookkeeper.common.util
A builder class for an OrderedExecutor.
OrderedExecutor.ContextPreservingCallable<T> - Class in org.apache.bookkeeper.common.util
Decorator class for a callable that preserves MDC context.
OrderedExecutor.ContextPreservingRunnable - Class in org.apache.bookkeeper.common.util
Decorator class for a runnable that preserves MDC context.
OrderedExecutor.TimedCallable<T> - Class in org.apache.bookkeeper.common.util
Decorator class for a callable that measure the execution time.
OrderedExecutor.TimedRunnable - Class in org.apache.bookkeeper.common.util
Decorator class for a runnable that measure the execution time.
OrderedGenericCallback<T> - Class in org.apache.bookkeeper.util
Generic callback implementation which will run the callback in the thread which matches the ordering key.
OrderedGenericCallback(OrderedExecutor, long) - Constructor for class org.apache.bookkeeper.util.OrderedGenericCallback
 
OrderedScheduler - Class in org.apache.bookkeeper.common.util
This class provides supports submitting tasks with an ordering key, so that tasks submitted with the same key will always be executed in order, but tasks across different keys can be unordered.
OrderedScheduler.OrderedSchedulerDecoratedThread - Class in org.apache.bookkeeper.common.util
 
OrderedScheduler.SchedulerBuilder - Class in org.apache.bookkeeper.common.util
Builder to build ordered scheduler.
ORDERING - Static variable in class org.apache.bookkeeper.common.conf.ConfigKey
 
ORDERING - Static variable in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
Ordering the key groups in a configuration.
orderInGroup() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The order of the setting in the key-group.
orderInGroup(int) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
The order of the setting in the key-group.
orderInGroup(int) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The order of the setting in the key-group.
ordinal - Variable in class org.apache.bookkeeper.stats.ThreadRegistry.ThreadPoolThread
 
org.apache.bookkeeper.auth - package org.apache.bookkeeper.auth
Classes used to handle authentication in bookies and clients.
org.apache.bookkeeper.bookie - package org.apache.bookkeeper.bookie
Provides a Bookie server that stores entries for clients.
org.apache.bookkeeper.bookie.datainteg - package org.apache.bookkeeper.bookie.datainteg
Package of the classes for defining bookie stats.
org.apache.bookkeeper.bookie.stats - package org.apache.bookkeeper.bookie.stats
Package of the classes for defining bookie stats.
org.apache.bookkeeper.bookie.storage - package org.apache.bookkeeper.bookie.storage
Provides a Bookie server that stores entries for clients.
org.apache.bookkeeper.bookie.storage.directentrylogger - package org.apache.bookkeeper.bookie.storage.directentrylogger
Support for bookie entry logs using Direct IO.
org.apache.bookkeeper.bookie.storage.ldb - package org.apache.bookkeeper.bookie.storage.ldb
Classes related to DB based ledger storage.
org.apache.bookkeeper.client - package org.apache.bookkeeper.client
BookKeeper Client.
org.apache.bookkeeper.client.api - package org.apache.bookkeeper.client.api
BookKeeper Client Public API.
org.apache.bookkeeper.client.impl - package org.apache.bookkeeper.client.impl
BookKeeper Client implementation package.
org.apache.bookkeeper.common - package org.apache.bookkeeper.common
Common functions and utils used across the project.
org.apache.bookkeeper.common.allocator - package org.apache.bookkeeper.common.allocator
defines the utilities for allocator used across the project.
org.apache.bookkeeper.common.allocator.impl - package org.apache.bookkeeper.common.allocator.impl
Implements the utilities for allocator used across the project.
org.apache.bookkeeper.common.annotation - package org.apache.bookkeeper.common.annotation
Annotations used across the whole project.
org.apache.bookkeeper.common.collections - package org.apache.bookkeeper.common.collections
Bookkeeper common collections.
org.apache.bookkeeper.common.component - package org.apache.bookkeeper.common.component
Component and lifecycle management.
org.apache.bookkeeper.common.concurrent - package org.apache.bookkeeper.common.concurrent
Utility classes commonly useful in concurrent programming.
org.apache.bookkeeper.common.conf - package org.apache.bookkeeper.common.conf
Configuration related utilities.
org.apache.bookkeeper.common.conf.validators - package org.apache.bookkeeper.common.conf.validators
A collection of validators that validate configuration settings.
org.apache.bookkeeper.common.net - package org.apache.bookkeeper.common.net
Classes for resolving service uris in bookkeeper.
org.apache.bookkeeper.common.stats - package org.apache.bookkeeper.common.stats
Stats Related Utils.
org.apache.bookkeeper.common.util - package org.apache.bookkeeper.common.util
Util functions used across the project.
org.apache.bookkeeper.common.util.affinity - package org.apache.bookkeeper.common.util.affinity
Util functions for CPU affinity.
org.apache.bookkeeper.common.util.affinity.impl - package org.apache.bookkeeper.common.util.affinity.impl
Implementation of util functions for CPU affinity.
org.apache.bookkeeper.common.util.nativeio - package org.apache.bookkeeper.common.util.nativeio
Utiltiies to access I/O using JNI.
org.apache.bookkeeper.conf - package org.apache.bookkeeper.conf
Configurations used by bookkeeper.
org.apache.bookkeeper.discover - package org.apache.bookkeeper.discover
Classes related to service discovery.
org.apache.bookkeeper.feature - package org.apache.bookkeeper.feature
A feature-flag system that is used to proportionally control what features are enabled for the system.
org.apache.bookkeeper.meta - package org.apache.bookkeeper.meta
Classes for interacting with bookkeeper ledgers and ledger metadata.
org.apache.bookkeeper.meta.exceptions - package org.apache.bookkeeper.meta.exceptions
Exceptions for metadata service.
org.apache.bookkeeper.meta.zk - package org.apache.bookkeeper.meta.zk
ZooKeeper based metadata implementation.
org.apache.bookkeeper.metastore - package org.apache.bookkeeper.metastore
MetaStore-related classes.
org.apache.bookkeeper.net - package org.apache.bookkeeper.net
Network-related classes.
org.apache.bookkeeper.processor - package org.apache.bookkeeper.processor
Define the processors used by bookie from processing requests.
org.apache.bookkeeper.proto - package org.apache.bookkeeper.proto
Classes related to the Bookkeeper protocol.
org.apache.bookkeeper.proto.checksum - package org.apache.bookkeeper.proto.checksum
Classes related to the Bookkeeper checksum.
org.apache.bookkeeper.replication - package org.apache.bookkeeper.replication
Classes for replicating Bookkeeper data.
org.apache.bookkeeper.sasl - package org.apache.bookkeeper.sasl
SASL and JAAS Authentication classes.
org.apache.bookkeeper.server - package org.apache.bookkeeper.server
BookKeeper Server (Bookie) related components.
org.apache.bookkeeper.server.component - package org.apache.bookkeeper.server.component
The lifecycle components that run on a bookie server.
org.apache.bookkeeper.server.conf - package org.apache.bookkeeper.server.conf
Server component related configuration.
org.apache.bookkeeper.server.http - package org.apache.bookkeeper.server.http
Package for bookkeeper http service.
org.apache.bookkeeper.server.http.service - package org.apache.bookkeeper.server.http.service
Define the services running in bookkeeper admin http server.
org.apache.bookkeeper.server.service - package org.apache.bookkeeper.server.service
Services running in a storage server (bookie).
org.apache.bookkeeper.shims.zk - package org.apache.bookkeeper.shims.zk
A shim layer to adopt different zookeeper versions.
org.apache.bookkeeper.slogger - package org.apache.bookkeeper.slogger
Structured logging.
org.apache.bookkeeper.slogger.slf4j - package org.apache.bookkeeper.slogger.slf4j
Structured logging (slf4j implementation).
org.apache.bookkeeper.stats - package org.apache.bookkeeper.stats
A lightweight stats library used for exporting bookkeeper stats.
org.apache.bookkeeper.stats.annotations - package org.apache.bookkeeper.stats.annotations
Annotations for bookkeeper stats api.
org.apache.bookkeeper.stats.codahale - package org.apache.bookkeeper.stats.codahale
A lightweight stats library implemention based on Codahale metrics library.
org.apache.bookkeeper.stats.otel - package org.apache.bookkeeper.stats.otel
A stats provider implementation based on OpenTelemetry.
org.apache.bookkeeper.stats.prometheus - package org.apache.bookkeeper.stats.prometheus
A stats provider implementation based on {@link https://prometheus.io/}.
org.apache.bookkeeper.streaming - package org.apache.bookkeeper.streaming
A java io stream wrapper over bookkeeper ledgers.
org.apache.bookkeeper.tls - package org.apache.bookkeeper.tls
Security and TLS-related classes.
org.apache.bookkeeper.tools.cli - package org.apache.bookkeeper.tools.cli
BookKeeper CLI that interacts with bookkeeper cluster.
org.apache.bookkeeper.tools.cli.commands - package org.apache.bookkeeper.tools.cli.commands
This package provides all the actual commands in bookie shell.
org.apache.bookkeeper.tools.cli.commands.autorecovery - package org.apache.bookkeeper.tools.cli.commands.autorecovery
 
org.apache.bookkeeper.tools.cli.commands.bookie - package org.apache.bookkeeper.tools.cli.commands.bookie
Commands to operate a single bookie.
org.apache.bookkeeper.tools.cli.commands.bookies - package org.apache.bookkeeper.tools.cli.commands.bookies
Commands on operating a cluster of bookies.
org.apache.bookkeeper.tools.cli.commands.client - package org.apache.bookkeeper.tools.cli.commands.client
This package contains all client related commands.
org.apache.bookkeeper.tools.cli.commands.cookie - package org.apache.bookkeeper.tools.cli.commands.cookie
Cookie related cli commands.
org.apache.bookkeeper.tools.cli.commands.health - package org.apache.bookkeeper.tools.cli.commands.health
 
org.apache.bookkeeper.tools.cli.helpers - package org.apache.bookkeeper.tools.cli.helpers
This classes provides some helper mixins for easily to add commands to bookie shell.
org.apache.bookkeeper.tools.common - package org.apache.bookkeeper.tools.common
Common classes used across multiple tools.
org.apache.bookkeeper.tools.framework - package org.apache.bookkeeper.tools.framework
BookKeeper Tool Framework.
org.apache.bookkeeper.util - package org.apache.bookkeeper.util
Bookkeeper utilities.
org.apache.bookkeeper.util.collections - package org.apache.bookkeeper.util.collections
Bookkeeper collection utilities.
org.apache.bookkeeper.util.nativeio - package org.apache.bookkeeper.util.nativeio
 
org.apache.bookkeeper.utils.affinity - package org.apache.bookkeeper.utils.affinity
 
org.apache.bookkeeper.verifier - package org.apache.bookkeeper.verifier
Simple self-verifying workload generator.
org.apache.bookkeeper.versioning - package org.apache.bookkeeper.versioning
a versioning library provides an abstraction over versioned data.
org.apache.bookkeeper.zookeeper - package org.apache.bookkeeper.zookeeper
A simple retryable zookeeper wrapper provided in bookkeeper.
originalCallback - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
OS_NAME - Static variable in class com.scurrilous.circe.utils.NativeUtils
 
OS_TYPE - Static variable in class org.apache.bookkeeper.util.HardLink
 
OS_TYPE_MAC - org.apache.bookkeeper.util.HardLink.OSType
 
OS_TYPE_SOLARIS - org.apache.bookkeeper.util.HardLink.OSType
 
OS_TYPE_UNIX - org.apache.bookkeeper.util.HardLink.OSType
 
OS_TYPE_WINXP - org.apache.bookkeeper.util.HardLink.OSType
 
OtelCounter - Class in org.apache.bookkeeper.stats.otel
 
OtelCounter(Meter, ScopeContext) - Constructor for class org.apache.bookkeeper.stats.otel.OtelCounter
 
OtelMetricsProvider - Class in org.apache.bookkeeper.stats.otel
 
OtelMetricsProvider() - Constructor for class org.apache.bookkeeper.stats.otel.OtelMetricsProvider
 
OtelOpStatsLogger - Class in org.apache.bookkeeper.stats.otel
 
OtelOpStatsLogger(Meter, ScopeContext) - Constructor for class org.apache.bookkeeper.stats.otel.OtelOpStatsLogger
 
OtelStatsLogger - Class in org.apache.bookkeeper.stats.otel
 
OtelStatsLogger(OtelMetricsProvider, String, Attributes) - Constructor for class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
OU_CLUSTER_NAME_CODE - Static variable in class org.apache.bookkeeper.util.CertUtils
 
OU_CODE_SEPARATOR - Static variable in class org.apache.bookkeeper.util.CertUtils
 
OU_GENERAL_NAME_REGEX - Static variable in class org.apache.bookkeeper.util.CertUtils
 
OU_NAME_SEPARATOR - Static variable in class org.apache.bookkeeper.util.CertUtils
 
OU_NAME_SPLITTER - Static variable in class org.apache.bookkeeper.util.CertUtils
 
OU_ROLE_NAME_CODE - Static variable in class org.apache.bookkeeper.util.CertUtils
 
OU_VALUES_SEPARATOR - Static variable in class org.apache.bookkeeper.util.CertUtils
 
OU_VALUES_SPLITTER - Static variable in class org.apache.bookkeeper.util.CertUtils
 
outOfMemoryListener - Variable in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
outOfMemoryListener(Consumer<OutOfMemoryError>) - Method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorBuilder
Add a listener that is triggered whenever there is an allocation failure.
outOfMemoryListener(Consumer<OutOfMemoryError>) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
outOfMemoryPolicy - Variable in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
outOfMemoryPolicy(OutOfMemoryPolicy) - Method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorBuilder
Define the OutOfMemory handling policy.
outOfMemoryPolicy(OutOfMemoryPolicy) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
OutOfMemoryPolicy - Enum in org.apache.bookkeeper.common.allocator
Represents the action to take when it's not possible to allocate memory.
outputFile(String) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.GenerateCookieCommand.Flags
 
outstandingWrites - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
ownEventLoopGroup - Variable in class org.apache.bookkeeper.client.BookKeeper
 
ownTimer - Variable in class org.apache.bookkeeper.client.BookKeeper
 
ownZKHandle - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 

P

PacketHeader() - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.PacketHeader
 
PacketProcessorBase<T extends BookieProtocol.Request> - Class in org.apache.bookkeeper.proto
A base class for bookeeper packet processors.
PacketProcessorBase() - Constructor for class org.apache.bookkeeper.proto.PacketProcessorBase
 
PacketProcessorBaseV3 - Class in org.apache.bookkeeper.proto
A base class for bookkeeper protocol v3 packet processors.
PacketProcessorBaseV3(BookkeeperProtocol.Request, BookieRequestHandler, BookieRequestProcessor) - Constructor for class org.apache.bookkeeper.proto.PacketProcessorBaseV3
 
PADDING - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
PADDING_BYTE - Static variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
PADDING_MASK - Static variable in class org.apache.bookkeeper.bookie.Journal
 
padToAlignment() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
Pad the buffer to the next alignment position.
PAGE_LIMIT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
PAGE_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
PageCacheUtil - Class in org.apache.bookkeeper.util
Native I/O operations.
pageLimit - Variable in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
pageMapAndList - Variable in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
pageSize - Variable in class org.apache.bookkeeper.bookie.BookieShell
 
pageSize - Variable in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
pageSize - Variable in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
parallelRead - Variable in class org.apache.bookkeeper.client.PendingReadOp
 
parallelRead - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
parallelRead(boolean) - Method in class org.apache.bookkeeper.client.PendingReadOp
 
parallelRead(boolean) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
ParallelReadRequest(List<BookieId>, long, long) - Constructor for class org.apache.bookkeeper.client.PendingReadOp.ParallelReadRequest
 
ParallelReadRequest(List<BookieId>, long, long) - Constructor for class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ParallelReadRequest
 
Paranoid - org.apache.bookkeeper.common.allocator.LeakDetectionPolicy
Instruments 100% of the allocated buffer to track for leaks, reporting stack traces of places where the buffer was used.
parent - Variable in class org.apache.bookkeeper.net.NodeBase
 
parent() - Method in annotation type org.apache.bookkeeper.stats.annotations.StatsDoc
The parent metric name.
parent() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
parentEnsemble - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
parentPredicate - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
parse(BufferedReader) - Method in class org.apache.bookkeeper.bookie.BookieStatus
Parse the bookie status object using appropriate layout version.
parse(String) - Static method in class org.apache.bookkeeper.net.BookieId
Parses the given serialized representation of a BookieId.
parseBookieRegion(BookieId) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
parseConfig(byte[], long, Optional<Long>) - Method in class org.apache.bookkeeper.meta.LedgerMetadataSerDe
Parses a given byte array and transforms into a LedgerConfig object.
parseCpuInfo() - Static method in class org.apache.bookkeeper.common.util.affinity.impl.ProcessorsInfo
 
parseCpuInfo(String) - Static method in class org.apache.bookkeeper.common.util.affinity.impl.ProcessorsInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseExecResult(BufferedReader) - Method in class org.apache.bookkeeper.util.Shell
Parse the execution result.
parseExecResult(BufferedReader) - Method in class org.apache.bookkeeper.util.Shell.ShellCommandExecutor
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(byte[]) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(ByteString) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(CodedInputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(InputStream) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(ByteBuffer) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
parseFromBytes(byte[]) - Static method in class org.apache.bookkeeper.bookie.Cookie
 
ParseJsonException(String) - Constructor for exception org.apache.bookkeeper.common.util.JsonUtil.ParseJsonException
 
ParseJsonException(String, Throwable) - Constructor for exception org.apache.bookkeeper.common.util.JsonUtil.ParseJsonException
 
parseLayout(byte[]) - Static method in class org.apache.bookkeeper.meta.LedgerLayout
Parses a given byte array and transforms into a LedgerLayout object.
parseLevel(String) - Static method in enum org.apache.bookkeeper.common.allocator.LeakDetectionPolicy
 
parseProcessorRange(String) - Static method in class org.apache.bookkeeper.common.util.affinity.impl.IsolatedProcessors
 
parser() - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
parser() - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
parser() - Static method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
PARSER - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
Deprecated.
PARSER - Static variable in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
Deprecated.
PARTIAL - org.apache.bookkeeper.client.BookieInfoReader.State
 
passwd - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
passwd - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
passwd - Variable in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
PASSWD - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
PASSWD - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
password - Variable in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
password(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.RegenerateInterleavedStorageIndexFileCommand.RISIFFlags
 
PASSWORD_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
path() - Method in class org.apache.bookkeeper.tools.framework.CliCommand
 
path() - Method in interface org.apache.bookkeeper.tools.framework.Command
Return command path in a cli path.
PATH_SEPARATOR - Static variable in class org.apache.bookkeeper.net.NodeBase
Path separator 47.
PATH_SEPARATOR_STR - Static variable in class org.apache.bookkeeper.net.NodeBase
Path separator as a string "/".
payload - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
PCBC_TIMEOUT_TIMER_NUM_TICKS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
PCBC_TIMEOUT_TIMER_TICK_DURATION_MS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
peek() - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
peek() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
PEM - org.apache.bookkeeper.tls.TLSContextFactory.KeyStoreType
 
PENDING_ADDS - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
PENDING_GET_FILE_INFO - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
PendingAddOp - Class in org.apache.bookkeeper.client
This represents a pending add operation.
pendingAddOps - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
pendingAddsSequenceHead - Variable in class org.apache.bookkeeper.client.LedgerHandle
Next entryId which is expected to move forward during LedgerHandle.sendAddSuccessCallbacks().
PendingOpsComparator() - Constructor for class org.apache.bookkeeper.client.LedgerHandleAdv.PendingOpsComparator
 
PendingReadLacOp - Class in org.apache.bookkeeper.client
This represents a pending ReadLac operation.
PendingReadLacOp(LedgerHandle, BookieClient, List<BookieId>, PendingReadLacOp.LacCallback) - Constructor for class org.apache.bookkeeper.client.PendingReadLacOp
 
PendingReadLacOp.LacCallback - Interface in org.apache.bookkeeper.client
 
PendingReadOp - Class in org.apache.bookkeeper.client
Sequence of entries of a ledger that represents a pending read operation.
PendingReadOp(LedgerHandle, ClientContext, long, long, boolean) - Constructor for class org.apache.bookkeeper.client.PendingReadOp
 
PendingReadOp.ParallelReadRequest - Class in org.apache.bookkeeper.client
 
PendingReadOp.SequenceReadRequest - Class in org.apache.bookkeeper.client
 
PendingReadOp.SingleLedgerEntryRequest - Class in org.apache.bookkeeper.client
 
PENDINGREQ_NOTWRITABLE_MASK - Static variable in interface org.apache.bookkeeper.proto.BookieClient
 
pendingWatchers - Variable in class org.apache.bookkeeper.util.SubTreeCache
 
PendingWriteLacOp - Class in org.apache.bookkeeper.client
This represents a pending WriteLac operation.
PendingWriteLacOp(LedgerHandle, ClientContext, List<BookieId>, AsyncCallback.AddLacCallback, Object) - Constructor for class org.apache.bookkeeper.client.PendingWriteLacOp
 
pendingWriteRequests - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
PerChannelBookieClient - Class in org.apache.bookkeeper.proto
This class manages all details of connection to a particular bookie.
PerChannelBookieClient(OrderedExecutor, EventLoopGroup, BookieId, ClientAuthProvider.Factory, ExtensionRegistry, BookieAddressResolver) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient
 
PerChannelBookieClient(OrderedExecutor, EventLoopGroup, BookieId, BookieAddressResolver) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient
 
PerChannelBookieClient(ClientConfiguration, OrderedExecutor, EventLoopGroup, ByteBufAllocator, BookieId, StatsLogger, ClientAuthProvider.Factory, ExtensionRegistry, PerChannelBookieClientPool, SecurityHandlerFactory, BookieAddressResolver) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient
 
PerChannelBookieClient(ClientConfiguration, OrderedExecutor, EventLoopGroup, BookieId, StatsLogger, ClientAuthProvider.Factory, ExtensionRegistry, PerChannelBookieClientPool, BookieAddressResolver) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient
 
PerChannelBookieClient.AddCompletion - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.BatchedReadCompletion - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.CompletionKey - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.CompletionValue - Class in org.apache.bookkeeper.proto
Boiler-plate wrapper classes follow.
PerChannelBookieClient.ConnectionFutureListener - Class in org.apache.bookkeeper.proto
Connection listener.
PerChannelBookieClient.ConnectionState - Enum in org.apache.bookkeeper.proto
 
PerChannelBookieClient.ContextPreservingFutureListener - Class in org.apache.bookkeeper.proto
Decorator to preserve MDC for connection listener.
PerChannelBookieClient.ForceLedgerCompletion - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.GetBookieInfoCompletion - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.GetListOfEntriesOfLedgerCompletion - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.ReadCompletion - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.ReadLacCompletion - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.StartTLSCompletion - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.TxnCompletionKey - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClient.WriteLacCompletion - Class in org.apache.bookkeeper.proto
 
PerChannelBookieClientFactory - Interface in org.apache.bookkeeper.proto
Factory to create PerChannelBookieClient.
PerChannelBookieClientPool - Interface in org.apache.bookkeeper.proto
An interface to manage channel pooling for bookie client.
PERMITTED_STARTUP_USERS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
perRegionPlacement - Variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
PERSIST_BOOKIE_STATUS_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
PersistentEntryLogMetadataMap - Class in org.apache.bookkeeper.bookie.storage.ldb
Persistent entryLogMetadata-map that stores entry-loggers metadata into rocksDB.
PersistentEntryLogMetadataMap(String, ServerConfiguration) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
 
pickRandomDir(File) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Return one dir from all dirs, regardless writable or not.
pickRandomDir(List<File>, File) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
 
pickRandomWritableDir() - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Returns one of the ledger dir from writable dirs list randomly.
pickRandomWritableDir(File) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Pick up a writable dir from available dirs list randomly.
pickRandomWritableDirForNewIndexFile(File) - Method in class org.apache.bookkeeper.bookie.LedgerDirsManager
Pick up a dir randomly from writableLedgerDirectories.
piggyBackedLac - Variable in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
PKCS12 - org.apache.bookkeeper.tls.TLSContextFactory.KeyStoreType
 
PLACEMENT_POLICY_CHECK_CTIME - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
PLACEMENT_POLICY_CHECK_TIME - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
placementPolicy - Variable in class org.apache.bookkeeper.client.BookKeeper
 
placementPolicyCheck() - Method in class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
PLACEMENTPOLICYCHECKCTIME_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
PLUGIN_NAME - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
pluginName - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler.AuthRequestCallback
 
pluginName - Variable in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthResponseCallback
 
pointer - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
pointer() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
The data pointer object for the native buffer.
pointer(long, long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
poll() - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
poll() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
poll(long, TimeUnit) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
poll(long, TimeUnit) - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
poll(long, TimeUnit) - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
pollAll(T[], long, TimeUnit) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
pollAll(T[], long, TimeUnit) - Method in interface org.apache.bookkeeper.common.collections.BatchedBlockingQueue
Removes multiple items from the queue.
pollAll(T[], long, TimeUnit) - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
pollLedgerToRereplicate() - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Poll for a underreplicated ledger to rereplicate.
pollLedgerToRereplicate() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
pollLedgerToRereplicate() - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
polynomial() - Method in class com.scurrilous.circe.params.CrcParameters
Returns the binary form of polynomial that defines the CRC function (with the implicit top bit omitted).
pooledAllocator - Variable in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
pooledAllocator(ByteBufAllocator) - Method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorBuilder
Specify a custom allocator where the allocation requests should be forwarded to.
pooledAllocator(ByteBufAllocator) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
PooledDirect - org.apache.bookkeeper.common.allocator.PoolingPolicy
Use Direct memory for all buffers and pool the memory.
poolingConcurrency - Variable in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
poolingConcurrency(int) - Method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorBuilder
Controls the amount of concurrency for the memory pool.
poolingConcurrency(int) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
poolingPolicy - Variable in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
poolingPolicy(PoolingPolicy) - Method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorBuilder
Define the memory pooling policy.
poolingPolicy(PoolingPolicy) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
PoolingPolicy - Enum in org.apache.bookkeeper.common.allocator
Define a policy for allocating buffers.
populateValueAndReset(int, ByteBuf) - Method in class org.apache.bookkeeper.proto.checksum.CRC32CDigestManager
 
populateValueAndReset(int, ByteBuf) - Method in class org.apache.bookkeeper.proto.checksum.CRC32DigestManager
 
populateValueAndReset(int, ByteBuf) - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
populateValueAndReset(int, ByteBuf) - Method in class org.apache.bookkeeper.proto.checksum.DummyDigestManager
 
populateValueAndReset(int, ByteBuf) - Method in class org.apache.bookkeeper.proto.checksum.MacDigestManager
 
PORT_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
PortManager - Class in org.apache.bookkeeper.util
Port manager provides free ports to allows multiple instances of the bookkeeper tests to run at once.
PortManager() - Constructor for class org.apache.bookkeeper.util.PortManager
 
posForOffset(long) - Static method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
position - Variable in class org.apache.bookkeeper.bookie.BufferedChannel
The absolute position of the next write operation.
position() - Method in class org.apache.bookkeeper.bookie.BufferedChannel
Get the position where the next write operation will begin writing from.
position() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
position() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
position() - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogWriter
The current offset within the log at which the next call to #writeDelimited will start writing.
position(long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
position(long) - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogWriter
Set the offset within the log at which the next call to #writeDelimited will start writing.
posix_fadvise(int, long, long, int) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
posix_fadvise is a linux-only syscall, so callers must handle the possibility that it does not exist.
posix_fadvise(int, long, long, int) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
posix_fadvise(int, long, long, int) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 
posix_memalign(int, int) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
posix_memalign(int, int) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
posix_memalign(int, int) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 
pread(int, long, long, long) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
pread(int, long, long, long) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
pread(int, long, long, long) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 
preallocation - Variable in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
preAllocIfNeeded(long) - Method in class org.apache.bookkeeper.bookie.JournalChannel
 
PREBOOT_END - org.apache.bookkeeper.bookie.datainteg.Events
The preboot check has completed successfully.
PREBOOT_ERROR - org.apache.bookkeeper.bookie.datainteg.Events
An error occurred during the preboot check.
PREBOOT_START - org.apache.bookkeeper.bookie.datainteg.Events
Start the preboot check.
preferArrayOrMemoryAddress(T) - Method in interface org.apache.bookkeeper.util.ByteBufVisitor.ByteBufVisitorCallback
 
preferredBookieIndices(BookieId, LedgerMetadata, Set<BookieId>, long) - Static method in class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl
Generate a map of preferred bookie indices.
prepareEntryMemTableFlush() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
prepareEntryMemTableFlush() - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
prepareEntryMemTableFlush() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
prepareEntryMemTableFlush() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
prepareFormat() - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Prepare ledgers root node, availableNode, readonly node..
prepareFormat() - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
prepareFormat() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
prepareSendResponseV2(int, BookieProtocol.ParsedAddRequest) - Method in class org.apache.bookkeeper.proto.BookieRequestHandler
 
prepareSortedLedgerStorageCheckpoint(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
prepareSortedLedgerStorageCheckpoint(long) - Method in interface org.apache.bookkeeper.bookie.EntryLogManager
 
prepareSortedLedgerStorageCheckpoint(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
prepareSortedLedgerStorageCheckpoint(long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
prepend(ByteBuf) - Method in class org.apache.bookkeeper.util.ByteBufList
Prepend a ByteBuf at the beginning of this ByteBufList.
PRESERVE_MDC_FOR_TASK_EXECUTION - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
preserveMdc() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
Flag describing executor's expectation in regards of MDC.
preserveMdcForTaskExecution - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
preserveMdcForTaskExecution - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
preserveMdcForTaskExecution(boolean) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
PREVIOUSLAC_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
printActiveLedgerOnEntryLog(long, List<Long>) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand
 
printAvailableCommands(Map<String, Command>, PrintStream) - Static method in class org.apache.bookkeeper.tools.framework.CommandUtils
Print the available commands in commander.
printAvailableFlags(JCommander, PrintStream) - Static method in class org.apache.bookkeeper.tools.framework.CommandUtils
Print the available flags in commander.
printDescription(PrintStream, int, int, String) - Static method in class org.apache.bookkeeper.tools.framework.CommandUtils
 
printEntryLogMetadata(long) - Method in class org.apache.bookkeeper.bookie.BookieShell
 
printErrorLine(String) - Method in class org.apache.bookkeeper.bookie.BookieShell
 
printInfoLine(String) - Method in class org.apache.bookkeeper.bookie.BookieShell
 
printLedgerMetadata(long, LedgerMetadata, boolean) - Method in class org.apache.bookkeeper.bookie.BookieShell
 
printMissingReplica(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand.LURFlags
 
printProgress(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand.FlipBookieIdFlags
 
printProgress(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags
 
printReplicationWorkerId(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ListUnderReplicatedCommand.LURFlags
 
printUsage() - Method in interface org.apache.bookkeeper.bookie.BookieShell.Command
 
printUsage() - Method in class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
printUsage() - Method in class org.apache.bookkeeper.tools.cli.helpers.BookieShellCommand
 
printUsage(PrintStream, String) - Static method in class org.apache.bookkeeper.tools.framework.CommandUtils
 
printUsage(CliSpec<CliOptsT>) - Static method in class org.apache.bookkeeper.tools.framework.Cli
 
PRIORITY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
process(int, long, ByteBuffer) - Method in interface org.apache.bookkeeper.bookie.Journal.JournalScanner
Process a journal entry.
process(long, long, long) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage.LedgerLoggerProcessor
 
process(long, long, ByteBuf) - Method in interface org.apache.bookkeeper.bookie.SkipListFlusher
Process an entry.
process(long, long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
process(long, long, ByteBuf) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogScanner
Process an entry.
process(ObjectHashSet<BookieRequestHandler>) - Method in class org.apache.bookkeeper.bookie.Journal.ForceWriteRequest
 
process(AuthToken, AuthCallbacks.GenericCallback<AuthToken>) - Method in interface org.apache.bookkeeper.auth.BookieAuthProvider
Process a request from the client.
process(AuthToken, AuthCallbacks.GenericCallback<AuthToken>) - Method in interface org.apache.bookkeeper.auth.ClientAuthProvider
Process a response from the server.
process(AuthToken, AuthCallbacks.GenericCallback<AuthToken>) - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProvider
 
process(AuthToken, AuthCallbacks.GenericCallback<AuthToken>) - Method in class org.apache.bookkeeper.sasl.SASLClientAuthProvider
 
process(MSWatchedEvent) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
process(MSWatchedEvent) - Method in interface org.apache.bookkeeper.metastore.MetastoreWatcher
 
process(WatchedEvent) - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
process(WatchedEvent) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
process(WatchedEvent) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
process(WatchedEvent) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperWatcherBase
 
process(T, AsyncCallback.VoidCallback) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.Processor
Process a specific element.
processEntry(long, long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
processEntry(long, long, ByteBuf, boolean) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
processList(List<T>, Function<T, CompletableFuture<R>>, ExecutorService) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
Process the list of items one by one using the process function processFunc.
ProcessorsInfo - Class in org.apache.bookkeeper.common.util.affinity.impl
Discover the list of processors from /proc/cpuinfo.
ProcessorsInfo() - Constructor for class org.apache.bookkeeper.common.util.affinity.impl.ProcessorsInfo
 
processPacket() - Method in class org.apache.bookkeeper.proto.PacketProcessorBase
 
processPacket() - Method in class org.apache.bookkeeper.proto.ReadEntryProcessor
 
processPacket() - Method in class org.apache.bookkeeper.proto.WriteEntryProcessor
 
processRequest(Object, BookieRequestHandler) - Method in interface org.apache.bookkeeper.processor.RequestProcessor
Process request.
processRequest(Object, BookieRequestHandler) - Method in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
processResult(int, String, Object) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin.ResultCallBack
 
processResult(int, String, Object) - Method in class org.apache.bookkeeper.client.LedgerFragmentReplicator.SingleFragmentCallback
 
processResult(int, String, Object) - Method in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
progress(long, long) - Method in interface org.apache.bookkeeper.bookie.BookieShell.UpdateLedgerNotifier
 
project(Set<String>) - Method in class org.apache.bookkeeper.metastore.Value
Select parts of fields.
PROMETHEUS_STATS_HTTP_ADDRESS - Static variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
PROMETHEUS_STATS_HTTP_ENABLE - Static variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
PROMETHEUS_STATS_HTTP_PORT - Static variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
PROMETHEUS_STATS_LATENCY_ROLLOVER_SECONDS - Static variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
PrometheusMetricsProvider - Class in org.apache.bookkeeper.stats.prometheus
A Prometheus based StatsProvider implementation.
PrometheusMetricsProvider() - Constructor for class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
PrometheusMetricsProvider(CollectorRegistry) - Constructor for class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
PrometheusServlet - Class in org.apache.bookkeeper.stats.prometheus
Servlet used to export metrics in prometheus text format.
PrometheusServlet(PrometheusMetricsProvider) - Constructor for class org.apache.bookkeeper.stats.prometheus.PrometheusServlet
 
PrometheusStatsLogger - Class in org.apache.bookkeeper.stats.prometheus
A Prometheus based StatsLogger implementation.
PrometheusStatsLogger(PrometheusMetricsProvider, String, Map<String, String>) - Constructor for class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
PrometheusTextFormat - Class in org.apache.bookkeeper.stats.prometheus
Logic to write metrics in Prometheus text format.
PrometheusTextFormat() - Constructor for class org.apache.bookkeeper.stats.prometheus.PrometheusTextFormat
 
promise - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
PROPERTIES_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
PROTOCOL_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
protocolVersion - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
protocolVersion - Variable in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
ProtocolVersionException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Protocol version is wrong (operations are absolutely not executed).
prov - Static variable in class org.apache.bookkeeper.stats.Stats
 
provideHttpEndpointService(HttpServer.ApiType) - Method in class org.apache.bookkeeper.server.http.BKHttpServiceProvider
 
provider - Variable in class org.apache.bookkeeper.util.SubTreeCache
 
proxyTo(CompletableFuture<T>, CompletableFuture<T>) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
pseudoSortByDistance(Node, Node[]) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Sort nodes array by their distances to reader It linearly scans the array, if a local node is found, swap it with the first element of the array.
publishEndpoint(ComponentInfoPublisher.EndpointInfo) - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher
 
publishInfo(ComponentInfoPublisher) - Method in interface org.apache.bookkeeper.common.component.LifecycleComponent
 
publishInfo(ComponentInfoPublisher) - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
publishInfo(ComponentInfoPublisher) - Method in class org.apache.bookkeeper.server.service.BookieService
 
publishInfo(ComponentInfoPublisher) - Method in class org.apache.bookkeeper.server.service.HttpService
 
publishProperty(String, String) - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher
Publish an information about the system, like an endpoint address.
publishSuspectedLedgersAsync(Collection<String>, Set<Long>) - Method in class org.apache.bookkeeper.replication.AuditorTask
 
put(byte[], byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage.Batch
 
put(byte[], byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
 
put(byte[], byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
put(long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
put(long, long, long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
put(long, long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.ldb.ReadCache
 
put(long, long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
put(long, EntryLogMetadata) - Method in interface org.apache.bookkeeper.bookie.EntryLogMetadataMap
Adds entryLogMetadata record into the map.
put(long, EntryLogMetadata) - Method in class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
put(long, EntryLogMetadata) - Method in class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
 
put(long, V) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
put(String, Value, Version, MetastoreCallback<Version>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
put(String, Value, Version, MetastoreCallback<Version>, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreTable
Update a key according to its version.
put(ByteBuffer) - Static method in class org.apache.bookkeeper.util.ZeroBuffer
Fill zeros into given buffer.
put(ByteBuffer, int) - Static method in class org.apache.bookkeeper.util.ZeroBuffer
Fill zeros into given buffer up to given length.
put(K, V) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
put(K, V) - Method in class org.apache.bookkeeper.util.collections.SynchronizedHashMultiMap
 
put(K, V) - Method in class org.apache.bookkeeper.util.SnapshotMap
Associates the specified value with the specified key in this map.
put(EntryKey, EntryKeyValue) - Method in class org.apache.bookkeeper.bookie.EntryMemTable.EntrySkipList
 
put(T) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
put(T) - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
put(T) - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
putAll(List<T>) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
putAll(T[], int, int) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
putAll(T[], int, int) - Method in interface org.apache.bookkeeper.common.collections.BatchedBlockingQueue
 
putAll(T[], int, int) - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
putAllProperties(Map<String, String>) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
map<string, string> properties = 7;
putEntryOffset(long, long, long) - Method in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
putEntryOffset(long, long, long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
putEntryOffset(long, long, long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
putEntryOffset(long, long, long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
putIfAbsent(long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
putIfAbsent(long, long, long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
putIfAbsent(long, V) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
putIfAbsent(K, V) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
putIfAbsent(EntryKey, EntryKeyValue) - Method in class org.apache.bookkeeper.bookie.EntryMemTable.EntrySkipList
 
putInReadChannels(long, BufferedReadChannel) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Put the logId, bc pair in the map responsible for the current thread.
putProperties(String, String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
map<string, string> properties = 7;
pwrite(int, long, int, long) - Method in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
pwrite(int, long, int, long) - Method in class org.apache.bookkeeper.common.util.nativeio.NativeIOImpl
 
pwrite(int, long, int, long) - Static method in class org.apache.bookkeeper.common.util.nativeio.NativeIOJni
 

Q

QFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.QueryAutoRecoveryStatusCommand.QFlags
 
quarantineBookie(BookieId) - Method in interface org.apache.bookkeeper.client.BookieWatcher
Quarantine bookie so it will not be preferred to be chosen for new ensembles.
quarantineBookie(BookieId) - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
Quarantine bookie so it will not be preferred to be chosen for new ensembles.
quarantinedBookies - Variable in class org.apache.bookkeeper.client.BookieWatcherImpl
 
query(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
QueryAutoRecoveryStatusCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.QueryAutoRecoveryStatusCmd
 
QueryAutoRecoveryStatusCommand - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Command to Query current auto recovery status.
QueryAutoRecoveryStatusCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.QueryAutoRecoveryStatusCommand
 
QueryAutoRecoveryStatusCommand.QFlags - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Flags for list under replicated command.
querySupport(HashParameters) - Method in interface com.scurrilous.circe.HashProvider
Returns information about the available implementations corresponding to the given hash algorithm parameters.
querySupport(HashParameters) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
 
querySupportTyped(HashParameters) - Method in class com.scurrilous.circe.checksum.Crc32cSse42Provider
 
querySupportTyped(CrcParameters) - Method in class com.scurrilous.circe.crc.StandardCrcProvider
 
querySupportTyped(P) - Method in class com.scurrilous.circe.impl.AbstractHashProvider
Implemented by subclasses to provide information about the available implementations corresponding to the given hash algorithm parameters.
queue - Variable in class org.apache.bookkeeper.bookie.Journal
 
QuorumException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Unused.
QUORUMSIZE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
qwcLatency - Variable in class org.apache.bookkeeper.client.PendingAddOp
 

R

RackawareEnsemblePlacementPolicy - Class in org.apache.bookkeeper.client
A placement policy implementation use rack information for placing ensembles.
RackawareEnsemblePlacementPolicy() - Constructor for class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
RackawareEnsemblePlacementPolicy(boolean) - Constructor for class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
RackawareEnsemblePlacementPolicyImpl - Class in org.apache.bookkeeper.client
Simple rackware ensemble placement policy.
RackawareEnsemblePlacementPolicyImpl() - Constructor for class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
RackawareEnsemblePlacementPolicyImpl(boolean) - Constructor for class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
RackChangeNotifier - Interface in org.apache.bookkeeper.client
Notifier used by the RackawareEnsemblePlacementPolicy to get notified if a rack changes for a bookie.
RACKNAME_DISTANCE_FROM_LEAVES - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
RackOrRegionDurabilityCoverageSet() - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackOrRegionDurabilityCoverageSet
 
RackQuorumCoverageSet(int) - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackQuorumCoverageSet
 
racksOrRegions - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
racksOrRegionsInQuorum - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackQuorumCoverageSet
 
raise(String, Object...) - Method in class org.apache.bookkeeper.stats.AlertStatsLogger
Report an alertable condition".
rand - Variable in class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
rand - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
rand - Variable in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo.EntryIterator
 
randomMax - Variable in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
RANGE_ADD_ENTRY - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
RANGE_ADD_ENTRY = 4;
RANGE_ADD_ENTRY_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
RANGE_ADD_ENTRY = 4;
RANGE_READ_ENTRY - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
Not supported yet.
RANGE_READ_ENTRY_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
Not supported yet.
rangeToString(Long, boolean, Long, boolean) - Static method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
RangeValidator - Class in org.apache.bookkeeper.common.conf.validators
Validator that validates a configuration value is in a numeric range.
RangeValidator(Number, Number) - Constructor for class org.apache.bookkeeper.common.conf.validators.RangeValidator
 
rateLimiter - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.ZkRetryRunnable
 
rawMapping - Variable in class org.apache.bookkeeper.net.CachedDNSToSwitchMapping
The uncached mapping.
rc - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.SyncObject
 
rc - Variable in class org.apache.bookkeeper.client.LedgerHandle.LastConfirmedCtx
 
rc - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
rc - Variable in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
rc - Variable in class org.apache.bookkeeper.client.SyncCounter
 
rc - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.SyncResult
Deprecated.
 
rc - Variable in class org.apache.bookkeeper.metastore.MetastoreUtils.MultiMetastoreCallback
 
rc - Variable in class org.apache.bookkeeper.metastore.MetastoreUtils.SyncMetastoreCallback
 
reachEntryLogLimit(DefaultEntryLogger.BufferedLogChannel, long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
read() - Method in class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
read() - Method in class org.apache.bookkeeper.client.PendingReadOp.ParallelReadRequest
 
read() - Method in class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
 
read() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ParallelReadRequest
 
read() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
Execute the read request.
read() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
read() - Method in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
Execute the read request.
read() - Method in class org.apache.bookkeeper.streaming.LedgerInputStream
 
read(byte[]) - Method in class org.apache.bookkeeper.streaming.LedgerInputStream
 
read(byte[], int, int) - Method in class org.apache.bookkeeper.streaming.LedgerInputStream
 
read(long, long) - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Read a sequence of entries synchronously.
read(ByteBuf, long) - Method in class org.apache.bookkeeper.bookie.BufferedReadChannel
Read as many bytes into dest as dest.capacity() starting at position pos in the FileChannel.
read(ByteBuf, long) - Method in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
read(ByteBuf, long, int) - Method in class org.apache.bookkeeper.bookie.BufferedChannel
 
read(ByteBuf, long, int) - Method in class org.apache.bookkeeper.bookie.BufferedReadChannel
 
read(ByteBuffer) - Method in class org.apache.bookkeeper.bookie.JournalChannel
 
read(ByteBuffer, long, boolean) - Method in class org.apache.bookkeeper.bookie.FileInfo
 
read(LogReader) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.LogMetadata
 
READ_AHEAD_CACHE_BATCH_BYTES_SIZE - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
READ_AHEAD_CACHE_BATCH_SIZE - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
READ_AHEAD_CACHE_MAX_SIZE_MB - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
READ_BUFFER_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
READ_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_DATA_LATENCY - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
READ_ENTRY - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
READ_ENTRY = 1;
READ_ENTRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_BLOCKED - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_BLOCKED_WAIT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_FENCE_READ - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_FENCE_REQUEST - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_FENCE_WAIT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_IN_PROGRESS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_LONG_POLL_PRE_WAIT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_LONG_POLL_READ - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_LONG_POLL_REQUEST - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_LONG_POLL_WAIT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_REJECTED - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_REQUEST - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_SCHEDULING_DELAY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_ENTRY_TIMEOUT_SEC - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
READ_ENTRY_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
READ_ENTRY = 1;
READ_FILE_INFO_CACHE_SIZE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_LAC - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
READ_LAC = 7;
READ_LAC - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_LAC - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
 
READ_LAC_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
READ_LAC_REQUEST - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_LAC_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
READ_LAC = 7;
READ_LAST_CONFIRMED_AND_ENTRY - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
READ_LAST_CONFIRMED_AND_ENTRY_RESPONSE - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
READ_LAST_ENTRY_NOENTRY_ERROR - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
READ_METADATA_FALLBACK - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
An attempt to read entrylog metadata failed.
READ_ONLY - org.apache.bookkeeper.bookie.BookieStatus.BookieMode
 
READ_ONLY_MASK - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
READ_ONLY_MODE_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
READ_ONLY_MODE_ON_ANY_DISK_FULL_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
READ_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
READ_OP_DM - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
READ_OP_OUTSTANDING - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
READ_REORDER_THRESHOLD_PENDING_REQUESTS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
READ_REQUESTS_REORDERED - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
READ_SYSTEM_PROPERTIES_PROPERTY - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
READ_TIMEOUT - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
READ_WORKER_THREADS_THROTTLING_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
READ_WRITE - org.apache.bookkeeper.bookie.BookieStatus.BookieMode
 
readableBytes() - Method in class org.apache.bookkeeper.util.ByteBufList
 
readableBytes() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readAsync(long, long) - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Read a sequence of entries asynchronously.
readAsync(long, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries asynchronously.
readBlock(long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
readBoolean() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBuffer - Variable in class org.apache.bookkeeper.bookie.BufferedReadChannel
 
readBufferAt(long, int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
readBufferAt(long, int) - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogReader
Read a buffer from the file.
readBufferStartPosition - Variable in class org.apache.bookkeeper.bookie.BufferedReadChannel
 
readByte() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readByteBuf(ByteBuf, int, int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
Read a bytebuf of size from the buffer at the given offset.
readBytes(byte[]) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBytes(byte[], int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBytes(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBytes(ByteBuf) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBytes(ByteBuf, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBytes(ByteBuf, int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBytes(OutputStream, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBytes(ByteBuffer) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBytes(FileChannel, long, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readBytes(GatheringByteChannel, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
ReadCache - Class in org.apache.bookkeeper.bookie.storage.ldb
Read cache implementation.
ReadCache(ByteBufAllocator, long) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.ReadCache
 
ReadCache(ByteBufAllocator, long, int) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.ReadCache
 
readCapacity - Variable in class org.apache.bookkeeper.bookie.BufferedReadChannel
 
readChar() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readCharSequence(int, Charset) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readComplete(int, LedgerHandle, Enumeration<LedgerEntry>, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.ReadCallback
Callback declaration.
readComplete(int, LedgerHandle, Enumeration<LedgerEntry>, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.SyncReadCallback
Implementation of callback interface for synchronous read method.
ReadCompletion(PerChannelBookieClient.CompletionKey, BookkeeperInternalCallbacks.ReadEntryCallback, Object, long, long) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadCompletion
 
ReadContext(int, BookieId, ReadOpBase.LedgerEntryRequest) - Constructor for class org.apache.bookkeeper.client.ReadOpBase.ReadContext
 
readCookie(BookieId) - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Read the cookie data, which will be used for verifying the integrity of the bookie environment.
readCookie(BookieId) - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
readCookie(BookieId) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
readCookieDataFromFile(String) - Method in class org.apache.bookkeeper.tools.cli.commands.cookie.CookieCommand
 
readCount - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
readData() - Method in class org.apache.bookkeeper.proto.BatchedReadEntryProcessor
 
readData() - Method in class org.apache.bookkeeper.proto.ReadEntryProcessor
 
readDone - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
readDouble() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readEntries(int) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreCursor
 
readEntries(int) - Method in interface org.apache.bookkeeper.metastore.MetastoreCursor
Read entries from the cursor, up to the specified numEntries.
readEntries(long, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries synchronously.
readEntries(long, long, long) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Read entries from a ledger synchronously.
readEntries(long, long, long, BiConsumer<Integer, ArrayList<byte[]>>) - Method in interface org.apache.bookkeeper.verifier.BookkeeperVerifier.BookkeeperDriver
 
readEntries(long, long, long, BiConsumer<Integer, ArrayList<byte[]>>) - Method in class org.apache.bookkeeper.verifier.DirectBookkeeperDriver
 
readEntriesComplete(int, long, long, ByteBufList, Object) - Method in class org.apache.bookkeeper.client.BatchedReadOp
 
readEntriesComplete(int, long, long, ByteBufList, Object) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.BatchedReadEntryCallback
 
readEntriesInternalAsync(long, long, boolean) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
readEntry(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
readEntry(long) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
readEntry(long) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
readEntry(long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
readEntry(long) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Read an entry from an entrylog location.
readEntry(long, long) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
readEntry(long, long) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
readEntry(long, long, long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
readEntry(long, long, long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
readEntry(long, long, long) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Read an entry from an entrylog location, and verify that is matches the expected ledger and entry ID.
readEntry(long, long, BookkeeperInternalCallbacks.ReadEntryCallback, Object, int, byte[], boolean) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
Normal Reads.
readEntry(BookieId, long, long, BookkeeperInternalCallbacks.ReadEntryCallback, Object, int) - Method in interface org.apache.bookkeeper.proto.BookieClient
Read entry with a null masterkey, disallowing failfast.
readEntry(BookieId, long, long, BookkeeperInternalCallbacks.ReadEntryCallback, Object, int) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
readEntry(BookieId, long, long, BookkeeperInternalCallbacks.ReadEntryCallback, Object, int, byte[]) - Method in interface org.apache.bookkeeper.proto.BookieClient
Read entry, disallowing failfast.
readEntry(BookieId, long, long, BookkeeperInternalCallbacks.ReadEntryCallback, Object, int, byte[]) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
readEntry(BookieId, long, long, BookkeeperInternalCallbacks.ReadEntryCallback, Object, int, byte[], boolean) - Method in interface org.apache.bookkeeper.proto.BookieClient
Read an entry from bookie at address address.
readEntry(BookieId, long, long, BookkeeperInternalCallbacks.ReadEntryCallback, Object, int, byte[], boolean) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
readEntry(BookkeeperProtocol.ReadResponse.Builder, long, boolean, Stopwatch) - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
Read a specific entry.
readEntry(BookkeeperProtocol.ReadResponse.Builder, long, Stopwatch) - Method in class org.apache.bookkeeper.proto.LongPollReadEntryProcessorV3
 
readEntry(BookkeeperProtocol.ReadResponse.Builder, long, Stopwatch) - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
Read a specific entry.
READENTRY - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The Read entry request payload will be the ledger number and entry number to read.
readEntryAt(int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
readEntryAt(int) - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogReader
Read an entry at a given offset.
readEntryBlockedStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
readEntryComplete(int, long, long, ByteBuf, Object) - Method in class org.apache.bookkeeper.client.PendingReadOp
 
readEntryComplete(int, long, long, ByteBuf, Object) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
readEntryComplete(int, long, long, ByteBuf, Object) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedOp
 
readEntryComplete(int, long, long, ByteBuf, Object) - Method in class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
readEntryComplete(int, long, long, ByteBuf, Object) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.ReadEntryCallback
 
readEntryLogHardLimit(DefaultEntryLogger.BufferedLogChannel, long) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
readEntryLogIndex(long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
ReadEntryProcessor - Class in org.apache.bookkeeper.proto
 
ReadEntryProcessor() - Constructor for class org.apache.bookkeeper.proto.ReadEntryProcessor
 
ReadEntryProcessorV3 - Class in org.apache.bookkeeper.proto
 
ReadEntryProcessorV3(BookkeeperProtocol.Request, BookieRequestHandler, BookieRequestProcessor, ExecutorService) - Constructor for class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
readEntrySchedulingDelayStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
readEntryStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
readEntryTimeoutNanos - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
readEntryWaitForLACUpdate(long, long, long, long, boolean, BookkeeperInternalCallbacks.ReadEntryCallback, Object) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
Long Poll Reads.
readEntryWaitForLACUpdate(BookieId, long, long, long, long, boolean, BookkeeperInternalCallbacks.ReadEntryCallback, Object) - Method in interface org.apache.bookkeeper.proto.BookieClient
Send a long poll request to bookie, waiting for the last add confirmed to be updated.
readEntryWaitForLACUpdate(BookieId, long, long, long, long, boolean, BookkeeperInternalCallbacks.ReadEntryCallback, Object) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
READER_CLOSE_ERROR - org.apache.bookkeeper.bookie.storage.directentrylogger.Events
An error occurred closing an entrylog reader.
readerIndex() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readerIndex(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
ReadException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Read operations failed (bookie error).
readExplicitLastConfirmed() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
readFileInfoCache - Variable in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
readFloat() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readFromDirectories(List<File>) - Method in class org.apache.bookkeeper.bookie.BookieStatus
Read bookie status from the status files, and update the bookie status if read succeed.
readFromDirectory(File) - Static method in class org.apache.bookkeeper.bookie.Cookie
Returns cookie from the given directory.
readFromRegistrationManager(RegistrationManager, ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.Cookie
Read cookie from registration manager.
readFromRegistrationManager(RegistrationManager, BookieId) - Static method in class org.apache.bookkeeper.bookie.Cookie
Read cookie from registration manager for a given bookie address.
ReadHandle - Interface in org.apache.bookkeeper.client.api
Provide read access to a ledger.
readHeader() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
readInt() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readInt(int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
Read an integer from the buffer at the given offset.
readIntAt(long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
readIntAt(long) - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogReader
Read an integer at a given offset.
readIntLE() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readIntoBufferAt(ByteBuf, long, int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
readIntoBufferAt(ByteBuf, long, int) - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogReader
 
readJournal() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
ReadJournalCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ReadJournalCmd
 
ReadJournalCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to scan a journal file and format the entries into readable format.
ReadJournalCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand
 
ReadJournalCommand(ReadJournalCommand.ReadJournalFlags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand
 
ReadJournalCommand(LedgerIdFormatter, EntryFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand
 
ReadJournalCommand.ReadJournalFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flag for read journal command.
ReadJournalFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadJournalCommand.ReadJournalFlags
 
readLac(long, BookkeeperInternalCallbacks.ReadLacCallback, Object) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
readLac(BookieId, long, BookkeeperInternalCallbacks.ReadLacCallback, Object) - Method in interface org.apache.bookkeeper.proto.BookieClient
Read the last add confirmed for ledger ledgerId from the bookie at address.
readLac(BookieId, long, BookkeeperInternalCallbacks.ReadLacCallback, Object) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
ReadLACAndEntryRequest(List<BookieId>, long, long) - Constructor for class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
readLacComplete(int, long, ByteBuf, ByteBuf, Object) - Method in class org.apache.bookkeeper.client.PendingReadLacOp
 
readLacComplete(int, long, ByteBuf, ByteBuf, Object) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.ReadLacCallback
 
ReadLacCompletion(PerChannelBookieClient.CompletionKey, BookkeeperInternalCallbacks.ReadLacCallback, Object, long) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadLacCompletion
 
ReadLacProcessorV3 - Class in org.apache.bookkeeper.proto
A read processor for v3 last add confirmed messages.
ReadLacProcessorV3(BookkeeperProtocol.Request, BookieRequestHandler, BookieRequestProcessor) - Constructor for class org.apache.bookkeeper.proto.ReadLacProcessorV3
 
READLACREQUEST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
readLacRequestStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
READLACRESPONSE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
readLACSpeculativeRequestPolicy - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
readLacStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
readLastAddConfirmed() - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Obtains asynchronously the last confirmed write from a quorum of bookies.
readLastAddConfirmed(long) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
readLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
readLastAddConfirmedAndEntry(long, long, boolean) - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Asynchronous read specific entry and the latest last add confirmed.
readLastAddConfirmedAndEntryAsync(long, long, boolean) - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Asynchronous read specific entry and the latest last add confirmed.
readLastAddConfirmedAndEntryAsync(long, long, boolean) - Method in class org.apache.bookkeeper.client.LedgerHandle
Asynchronous read specific entry and the latest last add confirmed.
readLastAddConfirmedAsync() - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Obtains asynchronously the last confirmed write from a quorum of bookies.
readLastAddConfirmedAsync() - Method in class org.apache.bookkeeper.client.LedgerHandle
Obtains asynchronously the last confirmed write from a quorum of bookies.
readLastConfirmed() - Method in class org.apache.bookkeeper.client.LedgerHandle
Obtains synchronously the last confirmed write from a quorum of bookies.
readLastConfirmedAndEntryComplete(int, long, LedgerEntry) - Method in interface org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.LastConfirmedAndEntryCallback
 
readLastConfirmedAndEntryComplete(int, long, LedgerEntry, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.ReadLastConfirmedAndEntryCallback
Callback definition for bookie operation that allows reading the last add confirmed along with an entry within the last add confirmed range.
readLastConfirmedAndEntryComplete(int, long, LedgerEntry, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.FutureReadLastConfirmedAndEntry
 
ReadLastConfirmedAndEntryContext - Class in org.apache.bookkeeper.proto
ReadLastConfirmedAndEntryContext(int, BookieId) - Constructor for class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
ReadLastConfirmedAndEntryOp - Class in org.apache.bookkeeper.client
Long poll read operation.
ReadLastConfirmedAndEntryOp(LedgerHandle, ClientContext, List<BookieId>, ReadLastConfirmedAndEntryOp.LastConfirmedAndEntryCallback, long, long) - Constructor for class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
ReadLastConfirmedAndEntryOp.LastConfirmedAndEntryCallback - Interface in org.apache.bookkeeper.client
Wrapper to get all recovered data from the request.
ReadLastConfirmedAndEntryOp.ParallelReadRequest - Class in org.apache.bookkeeper.client
 
ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest - Class in org.apache.bookkeeper.client
 
ReadLastConfirmedAndEntryOp.SequenceReadRequest - Class in org.apache.bookkeeper.client
 
readLastConfirmedComplete(int, long, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.ReadLastConfirmedCallback
Callback definition for bookie recover operations.
readLastConfirmedComplete(int, long, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.FutureReadLastConfirmed
 
readLastConfirmedComplete(int, long, Object) - Method in class org.apache.bookkeeper.client.SyncCallbackUtils.SyncReadLastConfirmedCallback
Implementation of callback interface for synchronous read last confirmed method.
readLastConfirmedDataComplete(int, DigestManager.RecoveryData) - Method in interface org.apache.bookkeeper.client.ReadLastConfirmedOp.LastConfirmedDataCallback
 
ReadLastConfirmedOp - Class in org.apache.bookkeeper.client
This class encapsulated the read last confirmed operation.
ReadLastConfirmedOp(BookieClient, DistributionSchedule, DigestManager, long, List<BookieId>, byte[], ReadLastConfirmedOp.LastConfirmedDataCallback) - Constructor for class org.apache.bookkeeper.client.ReadLastConfirmedOp
 
ReadLastConfirmedOp.LastConfirmedDataCallback - Interface in org.apache.bookkeeper.client
Wrapper to get all recovered data from the request.
readLastEntry() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
readLastEntryNoEntryErrorCounter - Variable in class org.apache.bookkeeper.proto.RequestStats
 
ReadLedgerCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to read ledger entries.
ReadLedgerCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand
 
ReadLedgerCommand(EntryFormatter, LedgerIdFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand
 
ReadLedgerCommand.ReadLedgerFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for read ledger command.
ReadLedgerEntriesCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ReadLedgerEntriesCmd
 
ReadLedgerEntryService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper read ledger entry related http request.
ReadLedgerEntryService(ServerConfiguration, BookKeeperAdmin) - Constructor for class org.apache.bookkeeper.server.http.service.ReadLedgerEntryService
 
ReadLedgerFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLedgerCommand.ReadLedgerFlags
 
readLedgerId(String) - Method in class org.apache.bookkeeper.util.LedgerIdFormatter.HexLedgerIdFormatter
 
readLedgerId(String) - Method in class org.apache.bookkeeper.util.LedgerIdFormatter.LongLedgerIdFormatter
 
readLedgerId(String) - Method in class org.apache.bookkeeper.util.LedgerIdFormatter
converts the ledgeridString, which is in format of the type of formatter, to the long value.
readLedgerId(String) - Method in class org.apache.bookkeeper.util.LedgerIdFormatter.UUIDLedgerIdFormatter
 
readLedgerIndexEntries(long, ServerConfiguration, SingleDirectoryDbLedgerStorage.LedgerLoggerProcessor) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
Reads ledger index entries to get list of entry-logger that contains given ledgerId.
readLedgerIndexMetadata(long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
Read ledger meta.
readLedgerIndexMetadata(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
Read implementation metadata for index file.
readLedgerIndexMetadata(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
readLedgerIndexMetadata(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
readLedgerIndexMetadata(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
readLedgerLayout() - Method in interface org.apache.bookkeeper.meta.LayoutManager
Return the ledger layout.
readLedgerLayout() - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLayoutManager
 
readLedgerLayout() - Method in class org.apache.bookkeeper.meta.ZkLayoutManager
Read ledger layout from zookeeper.
readLedgerMetadata(long) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
readLedgerMetadata(long) - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
readLedgerMetadata(long) - Method in interface org.apache.bookkeeper.meta.LedgerManager
Read ledger metadata of a specified ledger.
readLedgerMetadata(long) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
readLedgerMetadata(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
readLedgerMetadata(long, Watcher) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
ReadLedgerMetadataTask(long) - Constructor for class org.apache.bookkeeper.meta.AbstractZkLedgerManager.ReadLedgerMetadataTask
 
ReadLedgerMetadataTask(long) - Constructor for class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager.ReadLedgerMetadataTask
Deprecated.
 
readLog() - Method in class org.apache.bookkeeper.bookie.Journal.LastLogMark
Read last mark from lastMark file.
ReadLogCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ReadLogCmd
 
ReadLogCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to read entry log files.
ReadLogCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand
 
ReadLogCommand(LedgerIdFormatter, EntryFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand
 
ReadLogCommand.ReadLogFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for read log command.
ReadLogFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
readLogMark(ByteBuffer) - Method in class org.apache.bookkeeper.bookie.LogMark
 
readLogMetadata(ServerConfiguration, ReadLogMetadataCommand.ReadLogMetadataFlags) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand
 
ReadLogMetadataCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.ReadLogMetadataCmd
 
ReadLogMetadataCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to print metadata of entry log.
ReadLogMetadataCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand
 
ReadLogMetadataCommand(LedgerIdFormatter) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand
 
ReadLogMetadataCommand.ReadLogMetadataFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for read log metadata command.
ReadLogMetadataFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogMetadataCommand.ReadLogMetadataFlags
 
readLong() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readLong(int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
Read a long from the buffer at the given offset.
readLongAt(long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectReader
 
readLongAt(long) - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogReader
Read an long at a given offset.
readLongLE() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readMasterKey(long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
readMasterKey(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
readMasterKey(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
readMasterKey(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
readMasterKey(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
readMasterKey(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Get the master key for a ledger.
readMasterKey(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
readMasterKey(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
readMasterKey(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
readMedium() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readMediumLE() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readonly(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ListBookiesCommand.Flags
 
READONLY - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
ReadOnlyBookie - Class in org.apache.bookkeeper.bookie
Implements a read only bookie.
ReadOnlyBookie(ServerConfiguration, RegistrationManager, LedgerStorage, DiskChecker, LedgerDirsManager, LedgerDirsManager, StatsLogger, ByteBufAllocator, Supplier<BookieServiceInfo>) - Constructor for class org.apache.bookkeeper.bookie.ReadOnlyBookie
 
readOnlyBookies - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
readOnlyBuffer(int) - Static method in class org.apache.bookkeeper.util.ZeroBuffer
Returns read-only zero-filled buffer.
ReadOnlyDefaultEntryLogger - Class in org.apache.bookkeeper.bookie
Read Only Entry Logger.
ReadOnlyDefaultEntryLogger(ServerConfiguration) - Constructor for class org.apache.bookkeeper.bookie.ReadOnlyDefaultEntryLogger
 
ReadOnlyFileInfo - Class in org.apache.bookkeeper.bookie
Provide a readonly file info.
ReadOnlyFileInfo(File, byte[]) - Constructor for class org.apache.bookkeeper.bookie.ReadOnlyFileInfo
 
ReadOnlyLedgerHandle - Class in org.apache.bookkeeper.client
Read only ledger handle.
ReadOnlyLedgerHandle(ClientContext, long, Versioned<LedgerMetadata>, BookKeeper.DigestType, byte[], boolean) - Constructor for class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
ReadOnlyLedgerHandle.MetadataUpdater - Class in org.apache.bookkeeper.client
 
ReadOnlyState() - Constructor for class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService.ReadOnlyState
 
ReadOnlyState(boolean) - Constructor for class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService.ReadOnlyState
 
ReadOpBase - Class in org.apache.bookkeeper.client
 
ReadOpBase(LedgerHandle, ClientContext, long, long, boolean) - Constructor for class org.apache.bookkeeper.client.ReadOpBase
 
ReadOpBase.LedgerEntryRequest - Class in org.apache.bookkeeper.client
 
ReadOpBase.ReadContext - Class in org.apache.bookkeeper.client
 
readPage(FileInfo) - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
readReorderedCounter - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
readRequest - Variable in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
ReadRequest() - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.ReadRequest
 
READREQUEST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
readRequestStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
ReadResponse(byte, int, long, long) - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
ReadResponse(byte, int, long, long, ByteBuf) - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
READRESPONSE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
readRetainedSlice(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readsBlocked - Variable in class org.apache.bookkeeper.proto.RequestStats
 
readShort() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readShortLE() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readsInProgress - Variable in class org.apache.bookkeeper.proto.RequestStats
 
readsInProgress - Variable in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
readSlice(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readSpeculativeRequestPolicy - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
readsSemaphore - Variable in class org.apache.bookkeeper.proto.BookieRequestProcessor
 
readStats - Variable in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
readUnconfirmed(long, long) - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Read a sequence of entries synchronously.
readUnconfirmedAsync(long, long) - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Read a sequence of entries asynchronously, allowing to read after the LastAddConfirmed range.
readUnconfirmedAsync(long, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries asynchronously, allowing to read after the LastAddConfirmed range.
readUnconfirmedEntries(long, 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.asyncReadUnconfirmedEntries(long, long, ReadCallback, Object)
readUnsignedByte() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readUnsignedInt() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readUnsignedIntLE() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readUnsignedMedium() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readUnsignedMediumLE() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readUnsignedShort() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readUnsignedShortLE() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
readwrite(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ListBookiesCommand.Flags
 
ready() - Method in class org.apache.bookkeeper.client.LedgerHandle.LastConfirmedCtx
 
RebuildDbLedgerLocationsIndexCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgerLocationsIndexCmd
 
RebuildDBLedgerLocationsIndexCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to rebuild DBLedgerStorage locations index.
RebuildDBLedgerLocationsIndexCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.RebuildDBLedgerLocationsIndexCommand
 
RebuildDbLedgersIndexCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgersIndexCmd
 
RebuildDBLedgersIndexCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to rebuild DBLedgerStorage ledgers index.
RebuildDBLedgersIndexCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.RebuildDBLedgersIndexCommand
 
RebuildDBLedgersIndexCommand(RebuildDBLedgersIndexCommand.RebuildLedgersIndexFlags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.RebuildDBLedgersIndexCommand
 
RebuildDBLedgersIndexCommand.RebuildLedgersIndexFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for read log command.
RebuildLedgersIndexFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.RebuildDBLedgersIndexCommand.RebuildLedgersIndexFlags
 
receivedResponseSet - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
RecentEntryLogsStatus(long) - Constructor for class org.apache.bookkeeper.bookie.DefaultEntryLogger.RecentEntryLogsStatus
 
recentlyCreatedEntryLogsStatus - Variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
RECLAIM_FAILED_TO_DELETE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
RECLAIMED_COMPACTION_SPACE_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
RECLAIMED_DELETION_SPACE_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
recordError() - Method in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
recordError() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
recordError() - Method in interface org.apache.bookkeeper.proto.PerChannelBookieClientPool
record any read/write error on PerChannelBookieClientPool.
recordReadErrorOnBookie(int) - Method in class org.apache.bookkeeper.client.LedgerHandle
Notify the LedgerHandle that a read operation was failed on a particular bookie.
recover(BookkeeperInternalCallbacks.GenericCallback<Void>) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
recover(BookkeeperInternalCallbacks.GenericCallback<Void>, BookkeeperInternalCallbacks.ReadEntryListener, boolean) - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
Recover the ledger.
RECOVER_LIMBO_LEDGER - org.apache.bookkeeper.bookie.datainteg.Events
Recover a ledger that has been marked as in limbo.
RECOVER_LIMBO_LEDGER_CLOSE_ERROR - org.apache.bookkeeper.bookie.datainteg.Events
An error occurred when trying to close the ledger handle of a recovered ledger.
RECOVER_LIMBO_LEDGER_ERROR - org.apache.bookkeeper.bookie.datainteg.Events
An error occurred during recovery.
RECOVER_LIMBO_LEDGER_MISSING - org.apache.bookkeeper.bookie.datainteg.Events
The ledger has been deleted from the ledger metadata store, so we don't need to continue any processing on it.
RECOVER_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
recoverBookieData(long, Set<BookieId>, boolean, boolean) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
recoverBookieData(Set<BookieId>) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
recoverBookieData(Set<BookieId>, boolean, boolean) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
recoverBookieData(Set<BookieId>, boolean, boolean, boolean) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
recoverBookieData(BookieId) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Synchronous method to rebuild and recover the ledger fragments data that was stored on the source bookie.
RecoverCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.RecoverCmd
 
RecoverCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Command to ledger data recovery for failed bookie.
RecoverCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand
 
RecoverCommand.RecoverFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookies
Flags for recover command.
recoverComplete(int, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.RecoverCallback
Callback definition for bookie recover operations.
RecoverFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
recoverLedger(long, String) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
recoverLedgerFragmentEntry(Long, LedgerHandle, AsyncCallback.VoidCallback, Set<BookieId>, BiConsumer<Long, Long>) - Method in class org.apache.bookkeeper.client.LedgerFragmentReplicator
This method asynchronously recovers a specific ledger entry by reading the values via the BookKeeper Client (which would read it from the other replicas) and then writing it to the chosen new bookie.
recoverLedgerIfInLimbo(long, LedgerMetadata, String) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
Run ledger recovery on all a ledger if it has been marked as in limbo.
recoverLog(int, int, File, int, int, NativeIO, ByteBufAllocator, OpStatsLogger, Slogger) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
recovery - Variable in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
RECOVERY_ADD - org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
RECOVERY_ADD = 1;
RECOVERY_ADD_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
RECOVERY_ADD = 1;
RECOVERY_BATCH_READ_ENABLED - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
RECOVERY_READ_BATCH_SIZE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
recoveryAddEntry(ByteBuf, BookkeeperInternalCallbacks.WriteCallback, Object, byte[]) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
recoveryAddEntry(ByteBuf, BookkeeperInternalCallbacks.WriteCallback, Object, byte[]) - Method in class org.apache.bookkeeper.bookie.BookieImpl
Add entry to a ledger, even if the ledger has previous been fenced.
RecoveryBookieService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper recovery related http request.
RecoveryBookieService(ServerConfiguration, BookKeeperAdmin, ExecutorService) - Constructor for class org.apache.bookkeeper.server.http.service.RecoveryBookieService
 
RecoveryBookieService.RecoveryRequestJsonBody - Class in org.apache.bookkeeper.server.http.service
 
RecoveryData(long, long) - Constructor for class org.apache.bookkeeper.proto.checksum.DigestManager.RecoveryData
 
recoveryReadBatchSize - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
RecoveryReadOp(LedgerHandle, ClientContext, long, long, BookkeeperInternalCallbacks.ReadEntryListener, Object) - Constructor for class org.apache.bookkeeper.client.LedgerRecoveryOp.RecoveryReadOp
 
RecoveryRequestJsonBody() - Constructor for class org.apache.bookkeeper.server.http.service.RecoveryBookieService.RecoveryRequestJsonBody
 
RecoveryStats() - Constructor for class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.RecoveryStats
 
Recyclable - Interface in org.apache.bookkeeper.common.util
An interface represents an object that is recyclable.
RecyclableArrayList<T> - Class in org.apache.bookkeeper.common.collections
A simple list which is recyclable.
RecyclableArrayList() - Constructor for class org.apache.bookkeeper.common.collections.RecyclableArrayList
Default non-pooled instance.
RecyclableArrayList.Recycler<X> - Class in org.apache.bookkeeper.common.collections
An ArrayList recycler.
recycle() - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata.EntryLogMetadataRecyclable
 
recycle() - Method in class org.apache.bookkeeper.bookie.LastAddConfirmedUpdateNotification
 
recycle() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LongPairWrapper
 
recycle() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LongWrapper
 
recycle() - Method in interface org.apache.bookkeeper.client.DistributionSchedule.AckSet
Recycle this ack set when not used anymore.
recycle() - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
Recycle write set object when not in use.
recycle() - Method in class org.apache.bookkeeper.common.collections.RecyclableArrayList
 
recycle() - Method in interface org.apache.bookkeeper.common.util.Recyclable
Recycle the instance.
recycle() - Method in class org.apache.bookkeeper.common.util.Watchable
 
recycle() - Method in class org.apache.bookkeeper.proto.BatchedReadEntryProcessor
 
recycle() - Method in class org.apache.bookkeeper.proto.BookieProtocol.AddResponse
 
recycle() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadRequest
 
recycle() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ParsedAddRequest
 
recycle() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadRequest
 
recycle() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
recycle() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
recycle() - Method in class org.apache.bookkeeper.proto.ReadEntryProcessor
 
recycle() - Method in class org.apache.bookkeeper.proto.WriteEntryProcessor
 
recyclePendAddOpObject() - Method in class org.apache.bookkeeper.client.PendingAddOp
 
Recycler() - Constructor for class org.apache.bookkeeper.common.collections.RecyclableArrayList.Recycler
 
refCnt() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
refCnt() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
refCnt() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
refCount - Variable in class org.apache.bookkeeper.bookie.FileInfoBackingCache.CachedFileInfo
 
ReferenceCounted - Interface in org.apache.bookkeeper.common.util
An interface for indicating an object is reference counted.
reflect(int) - Method in class com.scurrilous.circe.crc.AbstractIntCrc
 
reflect(long) - Method in class com.scurrilous.circe.crc.AbstractLongCrc
 
reflected() - Method in class com.scurrilous.circe.params.CrcParameters
Returns whether the CRC function is "reflected".
ReflectedIntCrc - Class in com.scurrilous.circe.crc
Implements a "reflected" LSB-first int-width CRC function using a lookup table.
ReflectedIntCrc(String, int, int, int, int) - Constructor for class com.scurrilous.circe.crc.ReflectedIntCrc
 
ReflectedLongCrc - Class in com.scurrilous.circe.crc
Implements a "reflected" LSB-first long-width CRC function using a lookup table.
ReflectedLongCrc(String, int, long, long, long) - Constructor for class com.scurrilous.circe.crc.ReflectedLongCrc
 
ReflectionUtils - Class in org.apache.bookkeeper.common.util
General Class Reflection Utils.
ReflectionUtils() - Constructor for class org.apache.bookkeeper.common.util.ReflectionUtils
 
REFRESH_METADATA - org.apache.bookkeeper.bookie.datainteg.Events
The full check will read the metadata from the metadata store.
regClient - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
RegenerateInterleavedStorageIndexFile() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.RegenerateInterleavedStorageIndexFile
 
RegenerateInterleavedStorageIndexFileCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to regenerate an index file for interleaved storage.
RegenerateInterleavedStorageIndexFileCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.RegenerateInterleavedStorageIndexFileCommand
 
RegenerateInterleavedStorageIndexFileCommand.RISIFFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for regenerate interleaved storage index file command.
REGION_AWARE_ANOMALOUS_ENSEMBLE - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
RegionAwareEnsemblePlacementPolicy - Class in org.apache.bookkeeper.client
A placement policy use region information in the network topology for placing ensembles.
RegionAwareEnsemblePlacementPolicy() - Constructor for class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
REGIONID_DISTANCE_FROM_LEAVES - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
register(String, int) - Static method in class org.apache.bookkeeper.stats.ThreadRegistry
 
register(String, int, long) - Static method in class org.apache.bookkeeper.stats.ThreadRegistry
 
register(Watcher) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.bookkeeper.proto.DataFormats
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.BookkeeperProtocol
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.bookkeeper.proto.DataFormats
 
registerBookie(boolean) - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
registerBookie(boolean) - Method in interface org.apache.bookkeeper.bookie.StateManager
Register the bookie to RegistrationManager.
registerBookie(BookieId, boolean, BookieServiceInfo) - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Registering the bookie server as bookieId.
registerBookie(BookieId, boolean, BookieServiceInfo) - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
registerBookie(BookieId, boolean, BookieServiceInfo) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
registerBookieDriver(String, Class<? extends MetadataBookieDriver>) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Register the metadata bookie driver.
registerBookieDriver(String, Class<? extends MetadataBookieDriver>, boolean) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
 
registerCleanShutdown() - Method in interface org.apache.bookkeeper.bookie.UncleanShutdownDetection
 
registerCleanShutdown() - Method in class org.apache.bookkeeper.bookie.UncleanShutdownDetectionImpl
 
registerClientDriver(String, Class<? extends MetadataClientDriver>) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Register the metadata client driver.
registerClientDriver(String, Class<? extends MetadataClientDriver>, boolean) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
 
registerEntry(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.RecoveryStats
 
registerEvent(boolean, OpStatsLogger, Stopwatch) - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
registerFailedEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleOpStatsLogger
 
registerFailedEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullOpStatsLogger
 
registerFailedEvent(long, TimeUnit) - Method in interface org.apache.bookkeeper.stats.OpStatsLogger
Increment the failed op counter with the given eventLatency.
registerFailedEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.otel.OtelOpStatsLogger
 
registerFailedEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
registerFailedEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedDataSketchesStatsLogger
 
registerFailedEvent(OpStatsLogger, Stopwatch) - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
registerFailedValue(long) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleOpStatsLogger
 
registerFailedValue(long) - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullOpStatsLogger
 
registerFailedValue(long) - Method in interface org.apache.bookkeeper.stats.OpStatsLogger
An operation with the given value failed.
registerFailedValue(long) - Method in class org.apache.bookkeeper.stats.otel.OtelOpStatsLogger
 
registerFailedValue(long) - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
registerFailedValue(long) - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedDataSketchesStatsLogger
 
registerGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.MasterSlave
 
registerGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
 
registerGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
 
registerGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
 
registerGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.NullStatsLogger
 
registerGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
registerGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
registerGauge(String, Gauge<T>) - Method in interface org.apache.bookkeeper.stats.StatsLogger
Register given gauge as name name.
registerLedgerDeletionListener(LedgerStorage.LedgerDeletionListener) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
registerLedgerDeletionListener(LedgerStorage.LedgerDeletionListener) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Register a listener for ledgers deletion notifications.
registerLedgerDeletionListener(LedgerStorage.LedgerDeletionListener) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
registerLedgerDeletionListener(LedgerStorage.LedgerDeletionListener) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
registerLedgerDeletionListener(LedgerStorage.LedgerDeletionListener) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
registerLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
registerLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
registerLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in interface org.apache.bookkeeper.meta.LedgerManager
Register the ledger metadata listener on ledgerId.
registerLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
registerLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
registerLocalBookieAddress(BookieId) - Static method in class org.apache.bookkeeper.proto.LocalBookiesRegistry
 
registerMetrics(StatsLogger) - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
registerOperationFailureOnBookie(BookieId, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
registerPendingAddsGauge(Gauge<Integer>) - Method in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
registerPendingAddsGauge(Gauge<Integer>) - Method in class org.apache.bookkeeper.client.impl.BookKeeperClientStatsImpl
 
registerRackChangeListener(ITopologyAwareEnsemblePlacementPolicy<BookieNode>) - Method in interface org.apache.bookkeeper.client.RackChangeNotifier
Register a listener for the rack-aware placement policy.
registerSlowBookie(BookieId, long) - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
registerSlowBookie(BookieId, long) - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
registerSlowBookie(BookieId, long) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Register a bookie as slow so that it is tried after available and read-only bookies.
registerSlowBookie(BookieId, long) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
registerSlowBookie(BookieId, long) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
registerStartUp() - Method in interface org.apache.bookkeeper.bookie.UncleanShutdownDetection
 
registerStartUp() - Method in class org.apache.bookkeeper.bookie.UncleanShutdownDetectionImpl
 
registerSuccessfulEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleOpStatsLogger
 
registerSuccessfulEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullOpStatsLogger
 
registerSuccessfulEvent(long, TimeUnit) - Method in interface org.apache.bookkeeper.stats.OpStatsLogger
An operation succeeded with the given eventLatency.
registerSuccessfulEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.otel.OtelOpStatsLogger
 
registerSuccessfulEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
registerSuccessfulEvent(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedDataSketchesStatsLogger
 
registerSuccessfulEvent(OpStatsLogger, Stopwatch) - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
registerSuccessfulValue(long) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleOpStatsLogger
 
registerSuccessfulValue(long) - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullOpStatsLogger
 
registerSuccessfulValue(long) - Method in interface org.apache.bookkeeper.stats.OpStatsLogger
An operation with the given value succeeded.
registerSuccessfulValue(long) - Method in class org.apache.bookkeeper.stats.otel.OtelOpStatsLogger
 
registerSuccessfulValue(long) - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
registerSuccessfulValue(long) - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedDataSketchesStatsLogger
 
registerWatcher(Watcher) - Method in class org.apache.bookkeeper.util.SubTreeCache
Register a watcher.
registerWatcherWithGuard(Watcher) - Method in class org.apache.bookkeeper.util.SubTreeCache
Register watcher and get interest guard object which can be used with try-with-resources.
registerWrittenEntry(long, long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.BufferedLogChannel
 
REGISTRATION_CLIENT_CLASS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
REGISTRATION_MANAGER_CLASS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
RegistrationClient - Interface in org.apache.bookkeeper.discover
A registration client, which the bookkeeper client will use to interact with registration service.
RegistrationClient.RegistrationListener - Interface in org.apache.bookkeeper.discover
Listener to receive changes from the registration service.
registrationManager - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
registrationManager(RegistrationManager) - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
 
RegistrationManager - Interface in org.apache.bookkeeper.discover
Registration manager interface, which a bookie server will use to do the registration process.
RegistrationManager.RegistrationListener - Interface in org.apache.bookkeeper.discover
Registration Listener on listening the registration state.
registry - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
registry - Variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
release() - Method in class org.apache.bookkeeper.bookie.FileInfoBackingCache.CachedFileInfo
 
release() - Method in interface org.apache.bookkeeper.common.util.ReferenceCounted
Release the reference.
release() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
release() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ParsedAddRequest
 
release() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
release() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
release() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionKey
 
release() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
release(int) - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
release(int) - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
release(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
release(Buffer) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.BufferPool
 
release(SharedResourceManager.Resource<T>, T) - Method in class org.apache.bookkeeper.common.util.SharedResourceManager
 
releaseAllQuarantinedBookies() - Method in interface org.apache.bookkeeper.client.BookieWatcher
Release all quarantined bookies, let it can be chosen for new ensembles.
releaseAllQuarantinedBookies() - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
 
releaseMemory(long) - Method in class org.apache.bookkeeper.common.util.MemoryLimitController
 
releasePage() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
releasePageNoCallback() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
releasePermit() - Method in class org.apache.bookkeeper.client.LedgerChecker
Release a given permit.
releaseUnderreplicatedLedger(long) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Release a previously acquired ledger.
releaseUnderreplicatedLedger(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
releaseUnderreplicatedLedger(long) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
reloadCachedMappings() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DefaultResolver
 
reloadCachedMappings() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DNSResolverDecorator
 
reloadCachedMappings() - Method in class org.apache.bookkeeper.net.CachedDNSToSwitchMapping
 
reloadCachedMappings() - Method in interface org.apache.bookkeeper.net.DNSToSwitchMapping
Reload all of the cached mappings.
remainingCapacity() - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
remainingCapacity() - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
remainingCapacity() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
remainingSize - Variable in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
REMOTE_FAIL_MASK - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
REMOTE_MASK - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
REMOTE_NODE_IN_REORDER_SEQUENCE - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
remoteBookieIdToDecommission(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.DecommissionCommand.DecommissionFlags
 
remove() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin.LedgerEntriesIterator
 
remove() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
remove(byte[]) - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage.Batch
 
remove(long) - Method in interface org.apache.bookkeeper.bookie.EntryLogMetadataMap
Removes entryLogMetadata record from the map.
remove(long) - Method in class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
remove(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
 
remove(long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
remove(long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
Remove an existing entry if found.
remove(long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
Remove an existing entry if found.
remove(long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
remove(long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
Remove an existing entry if found.
remove(long, long, long, long) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
remove(long, Object) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
remove(String, Version, MetastoreCallback<Void>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
remove(String, Version, MetastoreCallback<Void>, Object) - Method in interface org.apache.bookkeeper.metastore.MetastoreTable
Remove a key by its version.
remove(K) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
remove(K) - Method in class org.apache.bookkeeper.util.SnapshotMap
Removes the mapping for the key from this map if it is present.
remove(K, Object) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
remove(Node) - Method in interface org.apache.bookkeeper.net.NetworkTopology
Remove a node from nework topology.
remove(Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl.InnerNode
Remove node n from the subtree of this node.
remove(Node) - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Remove a node.
remove(Node) - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
remove(V) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
removeAny(K) - Method in class org.apache.bookkeeper.util.collections.SynchronizedHashMultiMap
 
removeBookie() - Method in class org.apache.bookkeeper.util.LocalBookKeeper
 
removeBookieAndCheck(int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.AckSet
Invalidate a previous bookie response.
removeChildWatcher(Watcher) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperWatcherBase
 
removeCookie(BookieId, Version) - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Remove the cookie data.
removeCookie(BookieId, Version) - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
removeCookie(BookieId, Version) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
removeCustomMetadata(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
REMOVED - org.apache.bookkeeper.metastore.MSWatchedEvent.EventType
 
removeDeletedLedgers() - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
removeEndpoints(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
removeEntryLog(long) - Method in interface org.apache.bookkeeper.bookie.AbstractLogCompactor.LogRemovalListener
 
removeEntryLog(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Remove entry log.
removeEntryLog(long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
Remove entry log.
removeEntryLog(long) - Method in class org.apache.bookkeeper.bookie.ReadOnlyDefaultEntryLogger
 
removeEntryLog(long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
removeEntryLog(long) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Delete the entrylog with the given ID.
removeFromChannelsAndClose(long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Remove all entries for this log file in each thread's cache.
removeIf(BiPredicate<K, V>) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
removeIf(BiPredicate<K, V>) - Method in class org.apache.bookkeeper.util.collections.SynchronizedHashMultiMap
 
removeIf(LongPredicate) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
removeIf(ConcurrentLongHashMap.LongObjectPredicate<V>) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
removeIf(ConcurrentLongLongHashMap.LongLongPredicate) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
removeLedger(Long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
This method is called whenever a ledger is deleted by the BookKeeper Client and we want to remove all relevant data for it stored in the LedgerCache.
removeLedgerIf(LongPredicate) - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
removeLedgerMetadata(long, Version) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
removeLedgerMetadata(long, Version) - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
removeLedgerMetadata(long, Version) - Method in interface org.apache.bookkeeper.meta.LedgerManager
Remove a specified ledger metadata by ledgerId and version.
removeLedgerMetadata(long, Version) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
removeLedgerMetadata(long, Version) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
removeLifecycleListener(LifecycleListener) - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
removeLifecycleListener(LifecycleListener) - Method in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
removeLifecycleListener(LifecycleListener) - Method in interface org.apache.bookkeeper.common.component.LifecycleComponent
 
removeLifecycleListener(LifecycleListener) - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
removeListener(RegistrationClient.RegistrationListener) - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
removeOffsetFromDeletedLedgers() - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
removePagesForLedger(long) - Method in class org.apache.bookkeeper.bookie.IndexInMemPageMgr
 
removeProperties(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
map<string, string> properties = 7;
removeRequestContext(int) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
removeScope(String, StatsLogger) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
 
removeScope(String, StatsLogger) - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
 
removeScope(String, StatsLogger) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
 
removeScope(String, StatsLogger) - Method in class org.apache.bookkeeper.stats.NullStatsLogger
 
removeScope(String, StatsLogger) - Method in class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
removeScope(String, StatsLogger) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
removeScope(String, StatsLogger) - Method in interface org.apache.bookkeeper.stats.StatsLogger
Remove the given statsLogger for scope name.
removeSegment(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
renameJournalFile(File, File) - Static method in class org.apache.bookkeeper.bookie.JournalChannel
 
REORDER_READ_SEQUENCE_ENABLED - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
reorderReadLACSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
reorderReadLACSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
reorderReadLACSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Reorder the read last add confirmed sequence of a given write quorum writeSet.
reorderReadLACSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
reorderReadLACSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
reorderReadLACSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
reorderReadLACSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
reorderReadSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
reorderReadSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
reorderReadSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Reorder the read sequence of a given write quorum writeSet.
reorderReadSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
reorderReadSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
reorderReadSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
reorderReadSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
reorderReadSequence(List<BookieId>, BookiesHealthInfo, DistributionSchedule.WriteSet) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
reorderReadSequenceWithRegion(List<BookieId>, DistributionSchedule.WriteSet, Map<Integer, String>, BookiesHealthInfo, boolean, String, int) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
This function orders the read sequence with a given region.
reorderReadsRandom - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
reorderReadsRandom - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
reorderThresholdPendingRequests - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
reorderThresholdPendingRequests - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
REPAIRED_PLACEMENT_POLICY_NOT_ADHERING_BOOKIE_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
REPLACE_BOOKIE_TIME - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, int, Set<BookieId>) - Method in interface org.apache.bookkeeper.client.BookieWatcher
Choose a bookie to replace bookie bookieIdx in existingBookies.
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, int, Set<BookieId>) - Method in class org.apache.bookkeeper.client.BookieWatcherImpl
 
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, BookieId, Set<BookieId>) - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, BookieId, Set<BookieId>) - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, BookieId, Set<BookieId>) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Choose a new bookie to replace bookieToReplace.
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, BookieId, Set<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, BookieId, Set<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, BookieId, Set<BookieId>) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, BookieId, Set<BookieId>) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicy
 
replaceBookie(int, int, int, Map<String, byte[]>, List<BookieId>, BookieId, Set<BookieId>) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
replaceBookiesInEnsemble(BookieWatcher, LedgerMetadata, List<BookieId>, Map<Integer, BookieId>, String) - Static method in class org.apache.bookkeeper.client.EnsembleUtils
 
replaceEnsembleEntry(long, List<BookieId>) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
replaceFromRack(BookieNode, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
replaceNotAdheringPlacementPolicyBookie(List<BookieId>, int, int) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
 
replaceToAdherePlacementPolicy(int, int, int, Set<BookieId>, List<BookieId>) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Returns placement result.
replaceToAdherePlacementPolicy(int, int, int, Set<BookieId>, List<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
replaceToAdherePlacementPolicy(int, int, int, Set<BookieId>, List<BookieId>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
REPLICA_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
REPLICAS_CHECK_CTIME - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
REPLICAS_CHECK_TIME - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
replicasCheck() - Method in class org.apache.bookkeeper.replication.AuditorReplicasCheckTask
 
REPLICASCHECKCTIME_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
replicate(LedgerHandle, LedgerFragment, AsyncCallback.VoidCallback, Set<BookieId>, BiConsumer<Long, Long>) - Method in class org.apache.bookkeeper.client.LedgerFragmentReplicator
This method replicate a ledger fragment which is a contiguous portion of a ledger that was stored in an ensemble that included the failed bookie.
REPLICATE_EXCEPTION - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
replicateLedgerFragment(LedgerHandle, LedgerFragment, BiConsumer<Long, Long>) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Replicate the Ledger fragment to target Bookie passed.
replicateRate(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
REPLICATION_RATE_BY_BYTES - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
REPLICATION_SCOPE - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
REPLICATION_WORKER_SCOPE - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
ReplicationEnableCb - Class in org.apache.bookkeeper.replication
Callback which is getting notified when the replication process is enabled.
ReplicationEnableCb() - Constructor for class org.apache.bookkeeper.replication.ReplicationEnableCb
 
ReplicationException - Exception in org.apache.bookkeeper.replication
Exceptions for use within the replication service.
ReplicationException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Generic exception code used to propagate in replication pipeline.
ReplicationException(String) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException
 
ReplicationException(String, Throwable) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException
 
ReplicationException.BKAuditException - Exception in org.apache.bookkeeper.replication
Exception while auditing bookie-ledgers.
ReplicationException.CompatibilityException - Exception in org.apache.bookkeeper.replication
Compatibility error.
ReplicationException.NonRecoverableReplicationException - Exception in org.apache.bookkeeper.replication
The replication service encountered an error that requires service restart.
ReplicationException.UnavailableException - Exception in org.apache.bookkeeper.replication
The replication service has become unavailable.
replicationFailedLedgers - Variable in class org.apache.bookkeeper.replication.ReplicationWorker
 
ReplicationStats - Interface in org.apache.bookkeeper.replication
Replication statistics.
replicationThrottle - Variable in class org.apache.bookkeeper.client.LedgerFragmentReplicator
 
replicationWorker - Variable in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
ReplicationWorker - Class in org.apache.bookkeeper.replication
ReplicationWorker will take the fragments one by one from ZKLedgerUnderreplicationManager and replicates to it.
ReplicationWorker(ServerConfiguration) - Constructor for class org.apache.bookkeeper.replication.ReplicationWorker
Replication worker for replicating the ledger fragments from UnderReplicationManager to the targetBookie.
ReplicationWorker(ServerConfiguration, BookKeeper, boolean, StatsLogger) - Constructor for class org.apache.bookkeeper.replication.ReplicationWorker
 
ReplicationWorker(ServerConfiguration, StatsLogger) - Constructor for class org.apache.bookkeeper.replication.ReplicationWorker
Replication worker for replicating the ledger fragments from UnderReplicationManager to the targetBookie.
report() - Method in class org.apache.bookkeeper.util.HardLink.LinkStats
 
reporters - Variable in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
REPP_DISABLE_DURABILITY_ENFORCEMENT_FEATURE - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
REPP_DISABLE_DURABILITY_FEATURE_NAME - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
REPP_DISALLOW_BOOKIE_PLACEMENT_IN_REGION_FEATURE_NAME - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
REPP_DNS_RESOLVER_CLASS - Static variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
REPP_ENABLE_DURABILITY_ENFORCEMENT_IN_REPLACE - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
REPP_ENABLE_VALIDATION - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
REPP_MINIMUM_REGIONS_FOR_DURABILITY - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
REPP_RANDOM_READ_REORDERING - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
REPP_REGIONS_TO_WRITE - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
repPreV3 - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseDecoder
 
repPreV3 - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEncoder
 
repV3 - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseDecoder
 
repV3 - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEncoder
 
req - Variable in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthResponseCallback
 
req - Variable in class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler.AuthResponseCallbackLegacy
 
reqPreV3 - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestDecoder
 
reqPreV3 - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEncoder
 
reqStats - Variable in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
request - Variable in class org.apache.bookkeeper.client.BatchedReadOp
 
request - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
request - Variable in class org.apache.bookkeeper.proto.PacketProcessorBase
 
request - Variable in class org.apache.bookkeeper.proto.PacketProcessorBaseV3
 
Request() - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.Request
 
REQUEST_TIMER_NO_OF_TICKS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
REQUEST_TIMER_TICK_DURATION_MILLISEC - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
requestComplete - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
REQUESTCONTEXT_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
RequestDecoder(ExtensionRegistry) - Constructor for class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestDecoder
 
REQUESTED_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
RequestEncoder(ExtensionRegistry) - Constructor for class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEncoder
 
RequestEnDeCoderPreV3(ExtensionRegistry) - Constructor for class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEnDeCoderPreV3
 
RequestEnDecoderV3(ExtensionRegistry) - Constructor for class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEnDecoderV3
 
requestFlush() - Method in class org.apache.bookkeeper.bookie.SyncThread
 
requestHandler - Variable in class org.apache.bookkeeper.proto.PacketProcessorBase
 
requestHandler - Variable in class org.apache.bookkeeper.proto.PacketProcessorBaseV3
 
requestId - Variable in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadRequest
 
requestId - Variable in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
requestProcessor - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
requestProcessor - Variable in class org.apache.bookkeeper.proto.PacketProcessorBase
 
requestProcessor - Variable in class org.apache.bookkeeper.proto.PacketProcessorBaseV3
 
RequestProcessor - Interface in org.apache.bookkeeper.processor
A request processor that is used for processing requests at bookie side.
requestRateLimit - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
requestRateLimit(double) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
RequestStats - Class in org.apache.bookkeeper.proto
A umbrella class for request related stats.
RequestStats(StatsLogger) - Constructor for class org.apache.bookkeeper.proto.RequestStats
 
requestTimeNano - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
requestTimeNanos - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
requestTimeNanos - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
requestTimer - Variable in class org.apache.bookkeeper.client.BookKeeper.Builder
 
requestTimer - Variable in class org.apache.bookkeeper.client.BookKeeper
 
requestTimer(HashedWheelTimer) - Method in interface org.apache.bookkeeper.client.api.BookKeeperBuilder
Configure the bookkeeper client to use a provided Netty HashedWheelTimer.
requestTimer(HashedWheelTimer) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
Configure the bookkeeper client to use a provided HashedWheelTimer.
requestTimer(HashedWheelTimer) - Method in class org.apache.bookkeeper.client.impl.BookKeeperBuilderImpl
 
requestToString(Object) - Static method in class org.apache.bookkeeper.util.StringUtils
Builds string representation of teh request without extra (i.e.
RequestUtils - Class in org.apache.bookkeeper.proto
Utilities for requests.
RequestUtils() - Constructor for class org.apache.bookkeeper.proto.RequestUtils
 
required() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Flag indicates whether the setting is required.
required(boolean) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
Flag indicates whether the setting is required.
required(boolean) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Flag indicates whether the setting is required.
requiredBookiesMissingEntryForRecovery - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
reqV3 - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestDecoder
 
reqV3 - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEncoder
 
REREPLICATE_OP - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
REREPLICATION_ENTRY_BATCH_SIZE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
rescue(CompletableFuture<T>, Function<Throwable, CompletableFuture<T>>) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
reserveMemory(long) - Method in class org.apache.bookkeeper.common.util.MemoryLimitController
 
reset() - Method in class com.scurrilous.circe.crc.JavaCrc32
 
reset() - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
reset() - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
reset() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
reset() - Method in interface com.scurrilous.circe.StatefulHash
Resets this hash function to its initial state.
reset() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
Clear the bytes written.
reset() - Static method in class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
reset() - Method in class org.apache.bookkeeper.proto.PacketProcessorBase
 
reset() - Method in class org.apache.bookkeeper.proto.WriteEntryProcessor
 
reset(PerChannelBookieClient.CompletionKey, BookkeeperInternalCallbacks.WriteCallback, Object, long, long) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
resetPage() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
resetRate(int) - Method in class org.apache.bookkeeper.client.LedgerFragmentReplicator.Throttler
 
resetReaderIndex() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
resetWriterIndex() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
resolve(List<String>) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DefaultResolver
 
resolve(List<String>) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DNSResolverDecorator
 
resolve(List<String>) - Method in class org.apache.bookkeeper.net.CachedDNSToSwitchMapping
 
resolve(List<String>) - Method in interface org.apache.bookkeeper.net.DNSToSwitchMapping
Resolves a list of DNS-names/IP-addresses and returns back a list of switch information (network paths).
resolve(BookieId) - Method in class org.apache.bookkeeper.client.BookieAddressResolverDisabled
 
resolve(BookieId) - Method in class org.apache.bookkeeper.client.DefaultBookieAddressResolver
 
resolve(BookieId) - Method in interface org.apache.bookkeeper.proto.BookieAddressResolver
Maps a logical address to a network address.
resolveLedgerManagerFactory(URI) - Static method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
resolveLegacyBookieId(BookieId) - Static method in class org.apache.bookkeeper.net.BookieSocketAddress
Use legacy resolver to resolve a bookieId.
resolveNetworkLocation(BookieId) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
resolveNetworkLocation(DNSToSwitchMapping, BookieSocketAddress) - Static method in class org.apache.bookkeeper.net.NetUtils
 
resolver - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DNSResolverDecorator
 
resolveZkLedgersRootPath(AbstractConfiguration<?>) - Static method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
resolveZkServers(AbstractConfiguration<?>) - Static method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
response - Variable in class org.apache.bookkeeper.client.LedgerHandle.LastConfirmedCtx
 
response(byte[]) - Method in class org.apache.bookkeeper.sasl.SaslServerState
 
Response() - Constructor for class org.apache.bookkeeper.proto.BookieProtocol.Response
 
ResponseBuilder - Class in org.apache.bookkeeper.proto
 
ResponseBuilder() - Constructor for class org.apache.bookkeeper.proto.ResponseBuilder
 
ResponseDecoder(ExtensionRegistry, boolean, boolean) - Constructor for class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseDecoder
 
ResponseEncoder(ExtensionRegistry) - Constructor for class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEncoder
 
ResponseEnDeCoderPreV3(ExtensionRegistry) - Constructor for class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEnDeCoderPreV3
 
ResponseEnDecoderV3(ExtensionRegistry) - Constructor for class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEnDecoderV3
 
restoreContext(Map<String, String>) - Static method in class org.apache.bookkeeper.common.util.MdcUtils
 
restoreFromFile(String) - Method in class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand.LedgerMetadataFlag
 
restoreMdcContext() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
result - Variable in class org.apache.bookkeeper.metastore.MetastoreUtils.SyncMetastoreCallback
 
result(CompletableFuture<T>) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
result(CompletableFuture<T>, long, TimeUnit) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
result(CompletableFuture<T>, Function<Throwable, ExceptionT>) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
result(CompletableFuture<T>, Function<Throwable, ExceptionT>, long, TimeUnit) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
Result(MSException.Code, T) - Constructor for class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.Result
 
ResultCallBack(CompletableFuture<Void>) - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin.ResultCallBack
 
resume(int, byte[]) - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
resume(int, byte[]) - Method in interface com.scurrilous.circe.IncrementalIntHash
Evaluates this hash function as if the entire given input array were appended to the previously hashed input.
resume(int, byte[], int, int) - Method in interface com.scurrilous.circe.checksum.IntHash
 
resume(int, byte[], int, int) - Method in class com.scurrilous.circe.checksum.Java8IntHash
 
resume(int, byte[], int, int) - Method in class com.scurrilous.circe.checksum.Java9IntHash
 
resume(int, byte[], int, int) - Method in class com.scurrilous.circe.checksum.JniIntHash
 
resume(int, byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
resume(int, byte[], int, int) - Method in interface com.scurrilous.circe.IncrementalIntHash
Evaluates this hash function as if the given range of the given input array were appended to the previously hashed input.
resume(int, long, long) - Method in class com.scurrilous.circe.crc.Sse42Crc32C
 
resume(int, long, long) - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
resume(int, long, long) - Method in interface com.scurrilous.circe.IncrementalIntHash
Evaluates this hash function as if the memory with the given address and length were appended to the previously hashed input.
resume(int, ByteBuf) - Method in interface com.scurrilous.circe.checksum.IntHash
 
resume(int, ByteBuf) - Method in class com.scurrilous.circe.checksum.Java8IntHash
 
resume(int, ByteBuf) - Method in class com.scurrilous.circe.checksum.Java9IntHash
 
resume(int, ByteBuf) - Method in class com.scurrilous.circe.checksum.JniIntHash
 
resume(int, ByteBuf, int, int) - Method in interface com.scurrilous.circe.checksum.IntHash
 
resume(int, ByteBuf, int, int) - Method in class com.scurrilous.circe.checksum.Java8IntHash
 
resume(int, ByteBuf, int, int) - Method in class com.scurrilous.circe.checksum.Java9IntHash
 
resume(int, ByteBuf, int, int) - Method in class com.scurrilous.circe.checksum.JniIntHash
 
resume(int, ByteBuffer) - Method in class com.scurrilous.circe.crc.Sse42Crc32C
 
resume(int, ByteBuffer) - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
resume(int, ByteBuffer) - Method in interface com.scurrilous.circe.IncrementalIntHash
Evaluates this hash function as if the remaining contents of the given input buffer were appended to the previously hashed input.
resume(long, byte[]) - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
resume(long, byte[]) - Method in interface com.scurrilous.circe.IncrementalLongHash
Evaluates this hash function as if the entire given input array were appended to the previously hashed input.
resume(long, byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
resume(long, byte[], int, int) - Method in interface com.scurrilous.circe.IncrementalLongHash
Evaluates this hash function as if the given range of the given input array were appended to the previously hashed input.
resume(long, long, long) - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
resume(long, long, long) - Method in interface com.scurrilous.circe.IncrementalLongHash
Evaluates this hash function as if the memory with the given address and length were appended to the previously hashed input.
resume(long, ByteBuffer) - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
resume(long, ByteBuffer) - Method in interface com.scurrilous.circe.IncrementalLongHash
Evaluates this hash function as if the remaining contents of the given input buffer were appended to the previously hashed input.
resumeChecksum(int, byte[], int, int) - Static method in class com.scurrilous.circe.checksum.Crc32cIntChecksum
Computes incremental checksum with input previousChecksum and input payload
resumeChecksum(int, ByteBuf) - Static method in class com.scurrilous.circe.checksum.Crc32cIntChecksum
Computes incremental checksum with input previousChecksum and input payload
resumeChecksum(int, ByteBuf, int, int) - Static method in class com.scurrilous.circe.checksum.Crc32cIntChecksum
Computes incremental checksum with input previousChecksum and input payload
ResumeCompactionService - Class in org.apache.bookkeeper.server.http.service
 
ResumeCompactionService(BookieServer) - Constructor for class org.apache.bookkeeper.server.http.service.ResumeCompactionService
 
resumeMajorGC() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
resumeMajorGC() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
resumeMajorGC() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
resumeMajorGC() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
resumeMajorGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
resumeMajorGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
resumeMinorGC() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
resumeMinorGC() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
resumeMinorGC() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
resumeMinorGC() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
resumeMinorGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
resumeMinorGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
resumeProcessing() - Method in class org.apache.bookkeeper.proto.BookieNettyServer
 
resumeProcessing() - Method in class org.apache.bookkeeper.proto.BookieServer
Resume processing requests in the bookie (for testing).
resumeRaw(int, byte[], int, int) - Method in class com.scurrilous.circe.crc.AbstractIntCrc
 
resumeRaw(int, byte[], int, int) - Method in class com.scurrilous.circe.crc.NormalByteCrc
 
resumeRaw(int, byte[], int, int) - Method in class com.scurrilous.circe.crc.NormalIntCrc
 
resumeRaw(int, byte[], int, int) - Method in class com.scurrilous.circe.crc.ReflectedIntCrc
 
resumeRaw(long, byte[], int, int) - Method in class com.scurrilous.circe.crc.AbstractLongCrc
 
resumeRaw(long, byte[], int, int) - Method in class com.scurrilous.circe.crc.NormalLongCrc
 
resumeRaw(long, byte[], int, int) - Method in class com.scurrilous.circe.crc.ReflectedLongCrc
 
resumeSync() - Method in class org.apache.bookkeeper.bookie.SyncThread
Resume sync thread.
resumeUnchecked(int, byte[], int, int) - Method in class com.scurrilous.circe.crc.AbstractIntCrc
 
resumeUnchecked(int, byte[], int, int) - Method in class com.scurrilous.circe.crc.Sse42Crc32C
 
resumeUnchecked(int, byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
Evaluates this hash function as if the given range of the given input array were appended to the previously hashed input.
resumeUnchecked(long, byte[], int, int) - Method in class com.scurrilous.circe.crc.AbstractLongCrc
 
resumeUnchecked(long, byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
Evaluates this hash function as if the given range of the given input array were appended to the previously hashed input.
retain() - Method in interface org.apache.bookkeeper.common.util.ReferenceCounted
Retain the reference.
retain() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
retain() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
retain() - Method in class org.apache.bookkeeper.util.ByteBufList
 
retain() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
retain(int) - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
retain(int) - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
retain(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
retainedDuplicate() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
retainedSlice() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
retainedSlice(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
Retries - Class in org.apache.bookkeeper.common.util
A util class for supporting retries with customized backoff.
RETRY_BACKOFF - Static variable in class org.apache.bookkeeper.zookeeper.ExponentialBackOffWithDeadlinePolicy
 
retryExecThreadCount - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
retryPolicy - Variable in class org.apache.bookkeeper.zookeeper.ZooWorker
 
RetryPolicy - Interface in org.apache.bookkeeper.zookeeper
Interface of the policy to use when retrying operations.
retryThreadCount(int) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
reverseDns(InetAddress, String) - Static method in class org.apache.bookkeeper.net.DNS
Returns the hostname associated with the specified IP address by the provided nameserver.
RISIFFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.RegenerateInterleavedStorageIndexFileCommand.RISIFFlags
 
RLOC - Static variable in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
rollback(ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.FileSystemUpgrade
 
rollLog(Journal.LastLogMark) - Method in class org.apache.bookkeeper.bookie.Journal.LastLogMark
 
ROOT - Static variable in class org.apache.bookkeeper.net.NodeBase
String representation of root "".
rotatedLogChannels - Variable in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
rotateLatencyCollection() - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
rotateLatencyCollection() - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
RoundRobinDistributionSchedule - Class in org.apache.bookkeeper.client
A specific DistributionSchedule that places entries in round-robin fashion.
RoundRobinDistributionSchedule(int, int, int) - Constructor for class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
RRTopologyAwareCoverageEnsemble(int, int, int, int, Set<String>, int, int) - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
RRTopologyAwareCoverageEnsemble(int, int, int, int, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, int) - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
RRTopologyAwareCoverageEnsemble(int, int, int, int, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, Set<String>, int, int) - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
RRTopologyAwareCoverageEnsemble(TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble) - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
run() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
run() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
run() - Method in class org.apache.bookkeeper.bookie.Journal.QueueEntry
 
run() - Method in class org.apache.bookkeeper.bookie.Journal
A thread used for persisting journal entries to journal files.
run() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.CompactionPhase
 
run() - Method in class org.apache.bookkeeper.client.ForceLedgerOp
 
run() - Method in class org.apache.bookkeeper.client.MetadataUpdateLoop
 
run() - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle.MetadataUpdater
 
run() - Method in class org.apache.bookkeeper.client.ReadOpBase
 
run() - Method in class org.apache.bookkeeper.common.component.ComponentStarter.ComponentShutdownHook
 
run() - Method in class org.apache.bookkeeper.common.util.LogExceptionRunnable
 
run() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.ContextPreservingRunnable
 
run() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.TimedRunnable
 
run() - Method in interface org.apache.bookkeeper.common.util.SafeRunnable
 
run() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
run() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
run() - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager.CancelWatchLedgerMetadataTask
 
run() - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager.ReadLedgerMetadataTask
 
run() - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager.ReadLedgerMetadataTask
Deprecated.
 
run() - Method in class org.apache.bookkeeper.proto.ForceLedgerProcessorV3
 
run() - Method in class org.apache.bookkeeper.proto.GetBookieInfoProcessorV3
 
run() - Method in class org.apache.bookkeeper.proto.GetListOfEntriesOfLedgerProcessorV3
 
run() - Method in class org.apache.bookkeeper.proto.PacketProcessorBase
 
run() - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
run() - Method in class org.apache.bookkeeper.proto.ReadLacProcessorV3
 
run() - Method in class org.apache.bookkeeper.proto.WriteEntryProcessorV3
 
run() - Method in class org.apache.bookkeeper.proto.WriteLacProcessorV3
 
run() - Method in class org.apache.bookkeeper.replication.AuditorTask
 
run() - Method in class org.apache.bookkeeper.replication.ReplicationWorker
 
run() - Method in class org.apache.bookkeeper.sasl.TGTRefreshThread
 
run() - Method in class org.apache.bookkeeper.util.Shell
Check to see if a command needs to be executed and execute if needed.
run() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier
This is the method used to invoke the main loop of the IO driver.
run() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.ZkRetryRunnable
 
run(String[]) - Method in class org.apache.bookkeeper.bookie.BookieShell
 
run(String[]) - Method in class org.apache.bookkeeper.tools.framework.Cli
 
run(String[]) - Method in interface org.apache.bookkeeper.util.Tool
Exectue the command with given arguments.
run(Stream<Long>, Predicate<Throwable>, Supplier<CompletableFuture<ReturnT>>, OrderedScheduler) - Static method in class org.apache.bookkeeper.common.util.Retries
Retry a given task on failures.
run(Stream<Long>, Predicate<Throwable>, Supplier<CompletableFuture<ReturnT>>, OrderedScheduler, Object) - Static method in class org.apache.bookkeeper.common.util.Retries
Retry a given task on failures.
run(BookKeeper, ClientFlagsT) - Method in class org.apache.bookkeeper.tools.cli.helpers.ClientCommand
 
run(BookKeeper, DiscoveryFlagsT) - Method in class org.apache.bookkeeper.tools.cli.helpers.DiscoveryCommand
 
run(BookKeeper, SimpleTestCommand.Flags) - Method in class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand
 
run(RegistrationClient, DiscoveryFlagsT, boolean) - Method in class org.apache.bookkeeper.tools.cli.helpers.DiscoveryCommand
 
run(RegistrationClient, ListBookiesCommand.Flags, boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ListBookiesCommand
 
RUN_DURATION - Static variable in class org.apache.bookkeeper.bookie.ScrubberStats
 
runCli(CliSpec<CliOptsT>, String[]) - Static method in class org.apache.bookkeeper.tools.framework.Cli
 
runCmd(String[]) - Method in interface org.apache.bookkeeper.bookie.BookieShell.Command
 
runCmd(String[]) - Method in class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
runCmd(String[]) - Method in class org.apache.bookkeeper.tools.cli.helpers.BookieShellCommand
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.AutoRecoveryCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieFormatCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieInfoCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.BookieSanityTestCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.CheckDbLedgersIndexCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ClusterInfoCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ConvertToDbStorageCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ConvertToInterleavedStorageCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.DecommissionBookieCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.DeleteLedgerCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.EndpointInfoCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ForceAuditorChecksCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.HelpCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.InitBookieCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.InitNewCluster
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.LastMarkCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.LedgerCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.LedgerMetadataCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ListActiveLedgersCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ListBookiesCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ListDiskFilesCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ListLedgersCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ListUnderreplicatedCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.LocalConsistencyCheck
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.LostBookieRecoveryDelayCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.MetaFormatCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.MyCommand
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.NukeExistingCluster
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.QueryAutoRecoveryStatusCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadJournalCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLedgerEntriesCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLogCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.ReadLogMetadataCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgerLocationsIndexCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.RebuildDbLedgersIndexCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.RecoverCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.RegenerateInterleavedStorageIndexFile
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.SimpleTestCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.TriggerAuditCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateBookieInLedgerCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateCookieCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.UpdateLedgerCmd
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.WhatIsInstanceId
 
runCmd(CommandLine) - Method in class org.apache.bookkeeper.bookie.BookieShell.WhoIsAuditorCmd
 
runFullCheck() - Method in interface org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheck
Run full check of bookies local data.
runFullCheck() - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
runFunc() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
runFunctionWithLedgerManagerFactory(ServerConfiguration, Function<LedgerManagerFactory, T>) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Process the provided function with ledger manager factory resolved from the metadata service uri returned by AbstractConfiguration.getMetadataServiceUri().
runFunctionWithMetadataBookieDriver(ServerConfiguration, Function<MetadataBookieDriver, T>) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Process the provided function with metadata bookie driver resolved from the metadata service uri returned by AbstractConfiguration.getMetadataServiceUri().
runFunctionWithMetadataClientDriver(ClientConfiguration, Function<MetadataClientDriver, T>, ScheduledExecutorService) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Process the provided function with metadata client driver resolved from the metadata service uri returned by AbstractConfiguration.getMetadataServiceUri().
runFunctionWithRegistrationManager(ServerConfiguration, Function<RegistrationManager, T>) - Static method in class org.apache.bookkeeper.meta.MetadataDrivers
Process the provided function with registration manager resolved from the metadata service uri returned by AbstractConfiguration.getMetadataServiceUri().
runnable - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.TimedRunnable
 
running - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
running - Variable in class org.apache.bookkeeper.bookie.Journal
 
Running - org.apache.bookkeeper.common.util.SingleThreadExecutor.State
 
runPreBootCheck(String) - Method in interface org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheck
Run quick preboot check.
runPreBootCheck(String) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
runTask() - Method in class org.apache.bookkeeper.replication.AuditorBookieCheckTask
 
runTask() - Method in class org.apache.bookkeeper.replication.AuditorCheckAllLedgersTask
 
runTask() - Method in class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
runTask() - Method in class org.apache.bookkeeper.replication.AuditorReplicasCheckTask
 
runTask() - Method in class org.apache.bookkeeper.replication.AuditorTask
 
runUnitTests() - Static method in class com.scurrilous.circe.checksum.NarSystem
 
runUnitTests() - Static method in class org.apache.bookkeeper.util.nativeio.NarSystem
 
runUnitTests() - Static method in class org.apache.bookkeeper.utils.affinity.NarSystem
 
runUnitTestsNative() - Method in class com.scurrilous.circe.checksum.NarSystem
 
runUnitTestsNative() - Method in class org.apache.bookkeeper.util.nativeio.NarSystem
 
runUnitTestsNative() - Method in class org.apache.bookkeeper.utils.affinity.NarSystem
 
runWithFlags(boolean, boolean, boolean) - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
runZookeeper(int, int) - Static method in class org.apache.bookkeeper.util.LocalBookKeeper
 
runZookeeper(int, int, File) - Static method in class org.apache.bookkeeper.util.LocalBookKeeper
 
RW_REREPLICATE_BACKOFF_MS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
rwLock - Variable in class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
rwLock - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
rwLock - Variable in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
RxSchedulerLifecycleComponent - Class in org.apache.bookkeeper.common.component
The scheduler for rxjava based jobs, such as data integrity checking.
RxSchedulerLifecycleComponent(String, ComponentConfiguration, StatsLogger, Scheduler, ExecutorService) - Constructor for class org.apache.bookkeeper.common.component.RxSchedulerLifecycleComponent
 

S

safeOperationComplete(int, T) - Method in class org.apache.bookkeeper.util.OrderedGenericCallback
 
safeRun() - Method in interface org.apache.bookkeeper.common.util.SafeRunnable
 
safeRun(Runnable) - Static method in interface org.apache.bookkeeper.common.util.SafeRunnable
Utility method to use SafeRunnable from lambdas.
safeRun(Runnable) - Static method in class org.apache.bookkeeper.util.SafeRunnable
Utility method to use SafeRunnable from lambdas.
safeRun(Runnable, Consumer<Throwable>) - Static method in interface org.apache.bookkeeper.common.util.SafeRunnable
Utility method to use SafeRunnable from lambdas with a custom exception handler.
safeRun(Runnable, Consumer<Throwable>) - Static method in class org.apache.bookkeeper.util.SafeRunnable
Utility method to use SafeRunnable from lambdas with a custom exception handler.
SafeRunnable - Class in org.apache.bookkeeper.util
A SafeRunnable implementation.
SafeRunnable - Interface in org.apache.bookkeeper.common.util
A runnable that catches runtime exceptions.
SafeRunnable() - Constructor for class org.apache.bookkeeper.util.SafeRunnable
 
SANITY_CHECK_METRICS_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SanityFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.SanityTestCommand.SanityFlags
 
SanityTestCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
A bookie command to sanity test for local bookie.
SanityTestCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.SanityTestCommand
 
SanityTestCommand(SanityTestCommand.SanityFlags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.SanityTestCommand
 
SanityTestCommand.SanityFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for sanity command.
SASL_BOOKKEEPER_PROTOCOL - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
SASL_BOOKKEEPER_REALM - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
SASL_MD5_DUMMY_HOSTNAME - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
SASL_SERVICE_NAME - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
SASL_SERVICE_NAME_DEFAULT - Static variable in class org.apache.bookkeeper.sasl.SaslConstants
 
SASLBookieAuthProvider - Class in org.apache.bookkeeper.sasl
SASL Bookie Authentication Provider.
SASLBookieAuthProvider(BookieConnectionPeer, AuthCallbacks.GenericCallback<Void>, ServerConfiguration, Subject, Pattern) - Constructor for class org.apache.bookkeeper.sasl.SASLBookieAuthProvider
 
SASLBookieAuthProviderFactory - Class in org.apache.bookkeeper.sasl
BookieAuthProvider which uses JDK-bundled SASL.
SASLBookieAuthProviderFactory() - Constructor for class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
SASLClientAuthProvider - Class in org.apache.bookkeeper.sasl
SASL Client Authentication Provider.
SASLClientAuthProvider(ClientConnectionPeer, AuthCallbacks.GenericCallback<Void>, Subject) - Constructor for class org.apache.bookkeeper.sasl.SASLClientAuthProvider
 
SASLClientProviderFactory - Class in org.apache.bookkeeper.sasl
ClientAuthProvider which uses JDK-bundled SASL.
SASLClientProviderFactory() - Constructor for class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
SaslClientState - Class in org.apache.bookkeeper.sasl
A SASL Client State data object.
SaslClientState(String, Subject) - Constructor for class org.apache.bookkeeper.sasl.SaslClientState
 
SaslClientState.ClientCallbackHandler - Class in org.apache.bookkeeper.sasl
 
SaslConstants - Class in org.apache.bookkeeper.sasl
SASL Constants.
SaslConstants() - Constructor for class org.apache.bookkeeper.sasl.SaslConstants
 
saslResponse(byte[]) - Method in class org.apache.bookkeeper.sasl.SaslClientState
 
SaslServerState - Class in org.apache.bookkeeper.sasl
Server side Sasl implementation.
SaslServerState(ServerConfiguration, Subject, Pattern) - Constructor for class org.apache.bookkeeper.sasl.SaslServerState
 
save(OutputStream) - Method in class org.apache.bookkeeper.common.conf.ConfigDef
 
save(Path) - Method in class org.apache.bookkeeper.common.conf.ConfigDef
 
sb - Variable in class org.apache.bookkeeper.common.util.ExceptionMessageHelper
 
scan(ByteBufAllocator, LogReader, EntryLogScanner) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.LogReaderScan
 
scan(EntryLogScanner) - Method in interface org.apache.bookkeeper.bookie.storage.CompactionEntryLog
Scan the entry log, reading out all contained entries.
ScanAndCompareGarbageCollector - Class in org.apache.bookkeeper.bookie
Garbage collector implementation using scan and compare.
ScanAndCompareGarbageCollector(LedgerManager, CompactableLedgerStorage, ServerConfiguration, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.ScanAndCompareGarbageCollector
 
scanEntryLog(long, EntryLogScanner) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger
Scan entry log.
scanEntryLog(long, EntryLogScanner) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
scanEntryLog(long, EntryLogScanner) - Method in interface org.apache.bookkeeper.bookie.storage.EntryLogger
Scan the given entrylog, returning all entries contained therein.
scanEntryLogMetadata(long, AbstractLogCompactor.Throttler) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectEntryLogger
 
ScanEntryLogPhase(EntryLogMetadata, CompactionEntryLog) - Constructor for class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.ScanEntryLogPhase
 
scanJournal(long, long, Journal.JournalScanner, boolean) - Method in class org.apache.bookkeeper.bookie.Journal
Scan the journal.
scannerFactory - Variable in class org.apache.bookkeeper.bookie.EntryLogCompactor
 
schedule(Runnable, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
schedule(Runnable, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
schedule(Runnable, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
schedule(Runnable, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.SingleThreadSafeScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.SingleThreadSafeScheduledExecutorService
 
scheduleAtFixedRateOrdered(Object, Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period.
scheduleBookieHealthCheckIfEnabled(ClientConfiguration) - Method in class org.apache.bookkeeper.client.BookKeeper
 
scheduledFuture - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
scheduledFuture - Variable in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
scheduleGet(String, Set<String>, MetastoreCallback<Versioned<Value>>, Object) - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable
 
scheduleOrdered(Object, Runnable, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
Creates and executes a one-shot action that becomes enabled after the given delay.
scheduler - Variable in class org.apache.bookkeeper.client.BookKeeper
 
scheduler - Variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
scheduler - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
scheduler - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
SchedulerBuilder() - Constructor for class org.apache.bookkeeper.common.util.OrderedScheduler.SchedulerBuilder
 
scheduleTaskWithDelay(TimerTask, long) - Method in class org.apache.bookkeeper.replication.ReplicationWorker
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.SingleThreadSafeScheduledExecutorService
 
scheduleWithFixedDelayOrdered(Object, Runnable, long, long, TimeUnit) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given delay between the termination of one execution and the commencement of the next.
SCHEME - Static variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
scope - Variable in class org.apache.bookkeeper.feature.CacheableFeatureProvider
 
scope() - Method in annotation type org.apache.bookkeeper.stats.annotations.StatsDoc
The scope of this stats.
scope(String) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.MasterSlave
 
scope(String) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
 
scope(String) - Method in class org.apache.bookkeeper.feature.CacheableFeatureProvider
 
scope(String) - Method in interface org.apache.bookkeeper.feature.FeatureProvider
Provide the feature provider under scope name.
scope(String) - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
 
scope(String) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
 
scope(String) - Method in class org.apache.bookkeeper.stats.codahale.FastCodahaleStatsLogger
 
scope(String) - Method in class org.apache.bookkeeper.stats.NullStatsLogger
 
scope(String) - Method in class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
scope(String) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
scope(String) - Method in interface org.apache.bookkeeper.stats.StatsLogger
Provide the stats logger under scope name.
SCOPE - Static variable in class org.apache.bookkeeper.bookie.ScrubberStats
 
ScopeContext - Class in org.apache.bookkeeper.stats.otel
Holder for a scope and a set of associated labels.
ScopeContext - Class in org.apache.bookkeeper.stats.prometheus
Holder for a scope and a set of associated labels.
ScopeContext(String, Attributes) - Constructor for class org.apache.bookkeeper.stats.otel.ScopeContext
 
ScopeContext(String, Map<String, String>) - Constructor for class org.apache.bookkeeper.stats.prometheus.ScopeContext
 
scopeLabel(String, String) - Method in class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
scopeLabel(String, String) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
scopeLabel(String, String) - Method in interface org.apache.bookkeeper.stats.StatsLogger
Provide the stats logger with an attached label.
scopes - Variable in class org.apache.bookkeeper.feature.CacheableFeatureProvider
 
scopeStatsLoggers - Variable in class org.apache.bookkeeper.stats.CachingStatsLogger
 
SCRIPT_ARG_COUNT_KEY - Static variable in class org.apache.bookkeeper.net.ScriptBasedMapping
Key to the argument count that the script supports "networkTopologyScriptNumberArgs".
SCRIPT_FILENAME_KEY - Static variable in class org.apache.bookkeeper.net.ScriptBasedMapping
Key to the script filename "networkTopologyScriptFileName".
ScriptBasedMapping - Class in org.apache.bookkeeper.net
This class implements the DNSToSwitchMapping interface using a script configured via the CommonConfigurationKeys.NET_TOPOLOGY_SCRIPT_FILE_NAME_KEY option.
ScriptBasedMapping() - Constructor for class org.apache.bookkeeper.net.ScriptBasedMapping
Create an instance with the default configuration.
ScriptBasedMapping(Configuration) - Constructor for class org.apache.bookkeeper.net.ScriptBasedMapping
Create an instance from the given configuration.
ScrubberService - Class in org.apache.bookkeeper.server.service
A LifecycleComponent that runs the scrubber background service.
ScrubberService(StatsLogger, BookieConfiguration, LedgerStorage) - Constructor for class org.apache.bookkeeper.server.service.ScrubberService
 
ScrubberStats - Class in org.apache.bookkeeper.bookie
Stats associated with the consistency checker.
ScrubberStats() - Constructor for class org.apache.bookkeeper.bookie.ScrubberStats
 
sealed - Variable in class org.apache.bookkeeper.bookie.BufferedReadChannel
 
search(HashParameters) - Static method in class com.scurrilous.circe.HashProviders
Returns a map of hash providers supporting at least a stateful implementation of a hash function with the given parameters.
search(HashParameters, EnumSet<HashSupport>) - Static method in class com.scurrilous.circe.HashProviders
Returns a map of hash providers supporting at least the given flags for a hash function with the given parameters.
second - Variable in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
 
second - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.LongPair
 
SECTOR_SIZE - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
SecurityException - Exception in org.apache.bookkeeper.tls
Signals that a security-related exception has occurred.
SecurityException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
 
SecurityException() - Constructor for exception org.apache.bookkeeper.tls.SecurityException
 
SecurityException(String) - Constructor for exception org.apache.bookkeeper.tls.SecurityException
 
SecurityException(String, Throwable) - Constructor for exception org.apache.bookkeeper.tls.SecurityException
 
SecurityException(Throwable) - Constructor for exception org.apache.bookkeeper.tls.SecurityException
 
SecurityHandlerFactory - Interface in org.apache.bookkeeper.tls
A factory to manage the security handlers.
SecurityHandlerFactory.NodeType - Enum in org.apache.bookkeeper.tls
The security handler type.
SecurityProviderFactoryFactory - Class in org.apache.bookkeeper.tls
A factory to manage security provider factories.
SecurityProviderFactoryFactory() - Constructor for class org.apache.bookkeeper.tls.SecurityProviderFactoryFactory
 
seed() - Method in class com.scurrilous.circe.params.MurmurHash3Parameters
Returns the seed value for the hash function.
seedHigh() - Method in class com.scurrilous.circe.params.SipHash24Parameters
Returns the high-order 64 bits of the seed.
seedLow() - Method in class com.scurrilous.circe.params.SipHash24Parameters
Returns the low-order 64 bits of the seed.
seek(long) - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo.EntryIterator
 
SEEK_END - Static variable in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
SEEK_SET - Static variable in interface org.apache.bookkeeper.common.util.nativeio.NativeIO
 
seenBookies - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackQuorumCoverageSet
 
SEGMENT_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
selectDirForNextEntryLog() - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
selectFromNetworkLocation(String, Set<String>, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy
Select a node from networkLoc rack excluding excludeBookies.
selectFromNetworkLocation(String, Set<String>, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
selectFromNetworkLocation(String, Set<String>, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
selectFromNetworkLocation(String, Set<String>, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
selectFromNetworkLocation(String, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
selectFromNetworkLocation(String, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
selectFromNetworkLocation(String, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
selectFromNetworkLocation(String, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<T>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<T>, boolean) - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy
Select a node from a given network location.
selectFromNetworkLocation(Set<String>, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy
Select a node from cluster excluding excludeBookies and bookie nodes of excludeRacks.
selectFromNetworkLocation(Set<String>, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
selectFromNetworkLocation(Set<String>, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
It randomly selects a BookieNode that is not on the excludeRacks set, excluding the nodes in excludeBookies set.
selectFromNetworkLocation(Set<String>, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>, boolean) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
selectRandom(int, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
Choose a random node from whole cluster.
selectRandomFromRack(String, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
Choose random node under a given network path.
selectRandomFromRegions(Set<String>, int, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>) - Method in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
selectRandomInternal(List<BookieNode>, int, Set<Node>, ITopologyAwareEnsemblePlacementPolicy.Predicate<BookieNode>, ITopologyAwareEnsemblePlacementPolicy.Ensemble<BookieNode>) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
semaphore - Variable in class org.apache.bookkeeper.client.LedgerChecker
 
sendAddSuccessCallbacks() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
sendAddSuccessCallbacks() - Method in class org.apache.bookkeeper.client.PendingAddOp
 
sendForceLedgerRequest(int) - Method in class org.apache.bookkeeper.client.ForceLedgerOp
 
sendNextRead() - Method in class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
sendNextRead() - Method in class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
 
sendNextRead() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
sendReadReqResponse(int, Object, OpStatsLogger, boolean) - Method in class org.apache.bookkeeper.proto.PacketProcessorBase
 
sendReadTo(int, BookieId, BatchedReadOp.BatchedLedgerEntryRequest) - Method in class org.apache.bookkeeper.client.BatchedReadOp
 
sendReadTo(int, BookieId, PendingReadOp.SingleLedgerEntryRequest) - Method in class org.apache.bookkeeper.client.PendingReadOp
 
sendReadTo(int, BookieId, ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest) - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
sendResponse(int, Object, OpStatsLogger) - Method in class org.apache.bookkeeper.proto.PacketProcessorBase
 
sendResponse(BookkeeperProtocol.ReadResponse) - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
 
sendResponse(BookkeeperProtocol.StatusCode, Object, OpStatsLogger) - Method in class org.apache.bookkeeper.proto.PacketProcessorBaseV3
 
sendResponse(BookkeeperProtocol.StatusCode, Object, OpStatsLogger) - Method in class org.apache.bookkeeper.proto.WriteEntryProcessorV3
 
sendResponseAndWait(int, Object, OpStatsLogger) - Method in class org.apache.bookkeeper.proto.PacketProcessorBase
Write on the channel and wait until the write is completed.
sendWriteLacRequest(int) - Method in class org.apache.bookkeeper.client.PendingWriteLacOp
 
sendWriteReqResponse(int, Object, OpStatsLogger) - Method in class org.apache.bookkeeper.proto.PacketProcessorBase
 
sentReplicas - Variable in class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
sentReplicas - Variable in class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
 
sentReplicas - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
sentToHosts - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
seq - Variable in class org.apache.bookkeeper.client.PendingReadOp
 
seq - Variable in class org.apache.bookkeeper.client.SyncCounter
 
SequenceReadRequest(List<BookieId>, long, long) - Constructor for class org.apache.bookkeeper.client.PendingReadOp.SequenceReadRequest
 
SequenceReadRequest(List<BookieId>, long, long) - Constructor for class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.SequenceReadRequest
 
SequenceReadRequest(List<BookieId>, long, long, int, long) - Constructor for class org.apache.bookkeeper.client.BatchedReadOp.SequenceReadRequest
 
serialize() - Method in class org.apache.bookkeeper.meta.LedgerLayout
Generates a byte array based on the LedgerLayout object.
serialize(DataOutputStream) - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
Serializes EntryLogMetadata and writes to DataOutputStream.
serialize(LedgerMetadata) - Method in class org.apache.bookkeeper.meta.LedgerMetadataSerDe
 
serializeAddResponseInto(int, BookieProtocol.ParsedAddRequest, ByteBuf) - Static method in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEnDeCoderPreV3
 
serializeBookieServiceInfo(BookieServiceInfo) - Static method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
serializedSize(ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
serializedSize(ByteBuf) - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogWriter
 
serializeStateOfEntriesOfLedger() - Method in class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
server - Variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
Server - org.apache.bookkeeper.tls.SecurityHandlerFactory.NodeType
 
SERVER_EXCEPTION - Static variable in class org.apache.bookkeeper.bookie.ExitCode
 
SERVER_NUM_ACCEPTOR_THREADS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SERVER_NUM_IO_THREADS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SERVER_SANITY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
SERVER_SCOPE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
SERVER_SOCK_KEEPALIVE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SERVER_SOCK_LINGER - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SERVER_STATUS - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
SERVER_TCP_NODELAY - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SERVER_WRITEBUFFER_HIGH_WATER_MARK - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SERVER_WRITEBUFFER_LOW_WATER_MARK - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
serverConf - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataBookieDriver
 
serverConf - Variable in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
ServerConfiguration - Class in org.apache.bookkeeper.conf
Configuration manages server-side settings.
ServerConfiguration() - Constructor for class org.apache.bookkeeper.conf.ServerConfiguration
Construct a default configuration object.
ServerConfiguration(AbstractConfiguration) - Constructor for class org.apache.bookkeeper.conf.ServerConfiguration
Construct a configuration based on other configuration.
serverFactory - Variable in class org.apache.bookkeeper.shims.zk.ZooKeeperServerShimImpl
 
ServerLifecycleComponent - Class in org.apache.bookkeeper.server.component
A LifecycleComponent that runs on a bookie server.
ServerLifecycleComponent(String, BookieConfiguration, StatsLogger) - Constructor for class org.apache.bookkeeper.server.component.ServerLifecycleComponent
 
ServerSideHandler(BookieConnectionPeer, BookieAuthProvider.Factory) - Constructor for class org.apache.bookkeeper.proto.AuthHandler.ServerSideHandler
 
SERVICE_BK - Static variable in class org.apache.bookkeeper.common.net.ServiceURI
Service string for bookkeeper service.
SERVICE_BK_PORT - Static variable in class org.apache.bookkeeper.common.net.ServiceURI
 
SERVICE_DLOG - Static variable in class org.apache.bookkeeper.common.net.ServiceURI
Service string for dlog service.
SERVICE_ZK - Static variable in class org.apache.bookkeeper.common.net.ServiceURI
Service string for ledger service that uses zookeeper as metadata store.
ServiceDown - org.apache.bookkeeper.metastore.MSException.Code
 
ServiceDownException(String) - Constructor for exception org.apache.bookkeeper.metastore.MSException.ServiceDownException
 
ServiceDownException(String, Throwable) - Constructor for exception org.apache.bookkeeper.metastore.MSException.ServiceDownException
 
serviceUri - Variable in class org.apache.bookkeeper.tools.common.BKFlags
 
ServiceURI - Class in org.apache.bookkeeper.common.net
ServiceURI represents service uri within bookkeeper cluster.
SessionLost - org.apache.bookkeeper.meta.LedgerAuditorManager.AuditorEvent
 
sessionTimeoutMs - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
sessionTimeoutMs(int) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
set(boolean) - Method in class org.apache.bookkeeper.feature.SettableFeature
 
set(int) - Method in class org.apache.bookkeeper.feature.SettableFeature
 
set(int) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.LostBookieRecoveryDelayCommand.LBRDFlags
 
set(int, int) - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
Set the index at index i.
set(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LongWrapper
 
set(long, long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LongPairWrapper
 
set(long, DbLedgerStorageDataFormats.LedgerData) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
set(Configuration, Object) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Update the setting name in the configuration conf with the provided value.
setAckQuorumSize(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int32 ackQuorumSize = 9;
setACL(String, List<ACL>, int) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
setACL(String, List<ACL>, int, AsyncCallback.StatCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
setAddDelay(long) - Method in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
setAddEntryQuorumTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set timeout for top-level add entry request.
setAddEntryTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set timeout for add entry request.
setAddRequest(BookkeeperProtocol.AddRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AddRequest addRequest = 101;
setAddRequest(BookkeeperProtocol.AddRequest.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AddRequest addRequest = 101;
setAddResponse(BookkeeperProtocol.AddResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AddResponse addResponse = 101;
setAddResponse(BookkeeperProtocol.AddResponse.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AddResponse addResponse = 101;
setAdvertisedAddress(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configure the bookie to advertise a specific address.
setAffinity(int) - Static method in class org.apache.bookkeeper.common.util.affinity.impl.CpuAffinityJni
 
setAllocatorLeakDetectionPolicy(LeakDetectionPolicy) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Enable the leak detection for the allocator.
setAllocatorOutOfMemoryPolicy(OutOfMemoryPolicy) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Define the memory allocator out of memory policy.
setAllocatorPoolingConcurrenncy(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Controls the amount of concurrency for the memory pool.
setAllocatorPoolingPolicy(PoolingPolicy) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Define the memory pooling policy.
setAllowEphemeralPorts(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configure the bookie to allow using an ephemeral port.
setAllowLoopback(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configure the bookie to allow loopback interfaces to be used as the primary bookie interface.
setAllowMultipleDirsUnderSameDiskPartition(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configure the Bookie to allow/disallow multiple ledger/index/journal directories in the same filesystem diskpartition.
setAllowShadedLedgerManagerFactoryClass(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the flag to allow using shaded ledger manager factory class for instantiating a ledger manager factory.
setAllowStorageExpansion(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Change the setting of whether or not we should allow ledger/index dirs to be added to the current set of dirs.
setAuditorAcquireConcurrentOpenLedgerOperationsTimeoutMSec(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the acquire concurrent open ledger operations timeout.
setAuditorElected(boolean) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
setAuditorElected(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
setAuditorId(String) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
setAuditorId(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
setAuditorLedgerVerificationPercentage(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set what percentage of a ledger (fragment)'s entries will be verified.
setAuditorMaxNumberOfConcurrentOpenLedgerOperations(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the semaphore limit value for getting ledger from zookeeper in auto recovery.
setAuditorPeriodicBookieCheckInterval(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the interval between auditor bookie checks.
setAuditorPeriodicCheckInterval(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the regularity at which the auditor will run a check of all ledgers.
setAuditorPeriodicPlacementPolicyCheckInterval(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets the regularity/interval at which the auditor will run a placement policy check of all ledgers, which are closed.
setAuditorPeriodicReplicasCheckInterval(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets the interval at which the auditor will run a replicas check of all ledgers.
setAuth(int, String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string auth = 5;
setAuth(List<String>) - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
setAuthorizedId(BookKeeperPrincipal) - Method in interface org.apache.bookkeeper.proto.ConnectionPeer
Assign a principal to the current connection.
setAuthorizedRoles(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set authorized roles.
setAuthPluginName(String) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required string authPluginName = 1;
setAuthPluginNameBytes(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required string authPluginName = 1;
setAuthRequest(BookkeeperProtocol.AuthMessage) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AuthMessage authRequest = 102;
setAuthRequest(BookkeeperProtocol.AuthMessage.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .AuthMessage authRequest = 102;
setAuthResponse(BookkeeperProtocol.AuthMessage) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AuthMessage authResponse = 102;
setAuthResponse(BookkeeperProtocol.AuthMessage.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .AuthMessage authResponse = 102;
setAutoRecovery(AutoRecoveryMain) - Method in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
setAutoRecoveryDaemonEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets that whether the auto-recovery service can start along with Bookie server itself or not.
setAvailabilityOfEntriesOfLedger(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
condensed encoded format representing availability of entries of ledger
setAvailableForHighPriorityWrites(boolean) - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
setBatchReadEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
 
setBody(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required bytes body = 4;
setBody(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
optional bytes body = 4;
setBody(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required bytes body = 4;
setBookieAddressResolver(BookieAddressResolver) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DNSResolverDecorator
 
setBookieAddressResolver(BookieAddressResolver) - Method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
 
setBookieAddressResolver(BookieAddressResolver) - Method in interface org.apache.bookkeeper.net.DNSToSwitchMapping
Receives the current BookieAddressResolver.
setBookieAddressResolverEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/Disable BookieAddressResolver.
setBookieAuthProviderFactoryClass(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the bookie authentication provider factory class name.
setBookieErrorThresholdPerInterval(long) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the error threshold per interval (ClientConfiguration.getBookieHealthCheckIntervalSeconds()) for a bookie before it is quarantined.
setBookieFailureHistoryExpirationMSec(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the bookie failure tracking expiration timeout.
setBookieHealthCheckInterval(int, TimeUnit) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the bookie health check interval.
setBookieHost(String) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string bookieHost = 1;
setBookieHostBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string bookieHost = 1;
setBookieId(String) - Method in class org.apache.bookkeeper.bookie.Cookie.Builder
 
setBookieId(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configure the bookie to advertise a specific BookieId.
setBookieId(String) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
optional string bookieId = 1;
setBookieId(String) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
optional string bookieId = 1;
setBookieIdBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
optional string bookieId = 1;
setBookieIdBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
optional string bookieId = 1;
setBookieMaxWeightMultipleForWeightBasedPlacement(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the max multiple to use for nodes with very high weight.
setBookiePort(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set new bookie port that bookie server listen on.
setBookieQuarantineRatio(double) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
set the bookie quarantine ratio.
setBookieQuarantineTime(int, TimeUnit) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the time for which a bookie will be quarantined.
setBookieRecoveryDigestType(BookKeeper.DigestType) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set digest type used in bookkeeper admin.
setBookieRecoveryPasswd(byte[]) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set passwd used in bookkeeper admin.
setBookieServer(BookieServer) - Method in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
setBoolean(int, boolean) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBusyWaitEnabled(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Option to enable busy-wait settings.
setByte(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBytes(int, byte[]) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBytes(int, byte[], int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBytes(int, ByteBuf) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBytes(int, ByteBuf, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBytes(int, ByteBuf, int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBytes(int, InputStream, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBytes(int, ByteBuffer) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBytes(int, FileChannel, long, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setBytes(int, ScatteringByteChannel, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setChar(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setCharSequence(int, CharSequence, Charset) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setCheckAllLedgersCTime(long) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Setter for the CheckAllLedgers last executed ctime.
setCheckAllLedgersCTime(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
setCheckAllLedgersCTime(long) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
setCheckAllLedgersCTime(long) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
optional int64 checkAllLedgersCTime = 1;
setCheckpointer(Checkpointer) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
setCheckpointer(Checkpointer) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
setCheckpointer(Checkpointer) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
setCheckpointer(Checkpointer) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
setCheckpointer(Checkpointer) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
setCheckpointSource(CheckpointSource) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
setCheckpointSource(CheckpointSource) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
setCheckpointSource(CheckpointSource) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
setCheckpointSource(CheckpointSource) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
setCheckpointSource(CheckpointSource) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
setClean(int) - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
setClientAuthProviderFactoryClass(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the client authentication provider factory class name.
setClientConnectBookieUnavailableLogThrottling(int, TimeUnit) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the log frequency when a bookie is unavailable, in order to limit log filesize.
setClientConnectTimeoutMillis(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set client netty connect timeout in millis.
setClientReceiveBufferSize(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set client netty channel receive buffer size.
setClientRole(String) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the client role.
setClientSendBufferSize(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set client netty channel send buffer size.
setClientSockKeepalive(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set socket keepalive setting.
setClientTcpNoDelay(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set socket nodelay setting.
setClientWriteBufferHighWaterMark(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set client netty channel write buffer high water mark.
setClientWriteBufferLowWaterMark(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set client netty channel write buffer low water mark.
setCloseChannelOnResponseTimeout(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configures action in case if server timed out sending response to the client.
setClosed() - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
setClusterUnderReplicated(boolean) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
setClusterUnderReplicated(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
setCommandGroup(boolean) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
setCompactionMaxOutstandingRequests(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the maximum number of entries which can be compacted without flushing.
setCompactionRate(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the rate of compaction adds.
setCompactionRateByBytes(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the rate of compaction adds.
setCompactionRateByEntries(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the rate of compaction adds.
SetComparator() - Constructor for class com.scurrilous.circe.HashSupport.SetComparator
 
setConf(CompositeConfiguration) - Method in class org.apache.bookkeeper.bookie.BookieShell
 
setConf(CompositeConfiguration) - Method in interface org.apache.bookkeeper.util.Tool
Passe a configuration object to the tool.
setConf(Configuration) - Method in interface org.apache.bookkeeper.conf.Configurable
Set the configuration to be used by this object.
setConf(Configuration) - Method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
 
setConf(Configuration) - Method in class org.apache.bookkeeper.net.ScriptBasedMapping
Set the configuration to be used by this object.
setCtime(long) - Method in class org.apache.bookkeeper.meta.UnderreplicatedLedger
 
setCtime(long) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 ctime = 10;
setCtime(long) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
optional int64 ctime = 2;
setCToken(long) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 cToken = 12;
setCurLogMark(long, long) - Method in class org.apache.bookkeeper.bookie.Journal.LastLogMark
 
setCurrentLogForLedgerAndAddToRotate(long, DefaultEntryLogger.BufferedLogChannel) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerBase
 
setCurrentLogForLedgerAndAddToRotate(long, DefaultEntryLogger.BufferedLogChannel) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForEntryLogPerLedger
 
setCurrentLogForLedgerAndAddToRotate(long, DefaultEntryLogger.BufferedLogChannel) - Method in class org.apache.bookkeeper.bookie.EntryLogManagerForSingleEntryLog
 
setCustomMetadata(int, DataFormats.LedgerMetadataFormat.cMetadataMapEntry) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
setCustomMetadata(int, DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.cMetadataMapEntry customMetadata = 11;
setData(String, byte[], int) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
setData(String, byte[], int, AsyncCallback.StatCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
setDataIntegrityCheckingEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Enabled data integrity checker.
setDataIntegrityStampMissingCookiesEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
When this config is set to true and the data integrity checker is also enabled then any missing cookie files in the ledger directories do not prevent the bookie from booting.
setDefaultRocksDBConf(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set default rocksdb conf.
setDelayEnsembleChange(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/Disable delaying ensemble change.
setDesiredNumZonesPerWriteQuorum(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the desired number of zones per write quorum in ZoneAwarePlacementPolicy.
setDigestType(DataFormats.LedgerMetadataFormat.DigestType) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional .LedgerMetadataFormat.DigestType digestType = 7;
setDisableEnsembleChangeFeatureName(String) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the name of the dynamic feature that disables ensemble change.
setDisableServerSocketBind(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configure the bookie to disable bind on network interfaces, this bookie will be available only to BookKeeper clients executed on the local JVM.
setDiskCheckInterval(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the disk checker interval to monitor ledger disk space.
setDiskLowWaterMarkUsageThreshold(float) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the disk free space low water mark threshold.
setDiskSpaceThreshold(float, float) - Method in class org.apache.bookkeeper.util.DiskChecker
Set the disk space threshold.
setDiskUsageThreshold(float) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the Disk free space threshold as a fraction of the total after which disk will be considered as full during disk check.
setDiskUsageWarnThreshold(float) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the warning threshold for disk usage.
setDiskWeightBasedPlacementEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set whether or not disk weight based placement is enabled.
setDouble(int, double) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setEnableBookieAddressTracking(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/Disable bookie address changes tracking.
setEnableBookieFailureTracking(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/Disable bookie failure tracking.
setEnableDigestTypeAutodetection(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable autodetection of digest type.
setEnableLocalTransport(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configure the bookie to listen for BookKeeper clients executed on the local JVM.
setEnableParallelRecoveryRead(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/Disable parallel reading in recovery read.
setEnableTaskExecutionStats(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/Disable recording task execution stats.
setEnableTaskExecutionStats(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Enable/Disable recording task execution stats.
setEndpoints(int, DataFormats.BookieServiceInfoFormat.Endpoint) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
setEndpoints(int, DataFormats.BookieServiceInfoFormat.Endpoint.Builder) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
repeated .BookieServiceInfoFormat.Endpoint endpoints = 6;
setEndpoints(List<BookieServiceInfo.Endpoint>) - Method in class org.apache.bookkeeper.discover.BookieServiceInfo
 
setEnforceMinNumFaultDomainsForWrite(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the flag to enforce minimum number of fault domains for write.
setEnforceMinNumRacksPerWriteQuorum(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the flag to enforce minimum number of racks per write quorum.
setEnforceStrictZoneawarePlacement(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the flag to enforce strict zoneaware placement.
setEnsembleMember(int, String) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
repeated string ensembleMember = 1;
setEnsemblePlacementPolicy(Class<? extends EnsemblePlacementPolicy>) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set Ensemble Placement Policy Class.
setEnsemblePlacementPolicySlowBookies(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/Disable ordering slow bookies in placement policy.
setEnsembleSize(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int32 ensembleSize = 2;
setEntryBuf(ByteBuf) - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
 
setEntryFormatterClass(Class<? extends EntryFormatter>) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set entry formatter Class.
setEntryId(long) - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
 
setEntryId(long) - Method in class org.apache.bookkeeper.client.PendingAddOp
 
setEntryId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required int64 entryId = 2;
setEntryId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required int64 entryId = 3;
setEntryId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
entryId will be -1 for reading the LAST_ADD_CONFIRMED entry.
setEntryId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required int64 entryId = 3;
setEntryListener(BookkeeperInternalCallbacks.ReadEntryListener) - Method in class org.apache.bookkeeper.client.LedgerRecoveryOp
Set an entry listener to listen on individual recovery reads during recovery procedure.
setEntryLocationRocksdbConf(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set entry Location rocksdb conf.
setEntryLogFilePreAllocationEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Enable/disable entry log file preallocation.
setEntrylogMapAccessExpiryTimeInSeconds(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
setEntryLogPerLedgerCounterLimitsMultFactor(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
setEntryLogPerLedgerEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
setEntryLogSizeLimit(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set entry logger size limitation.
setEnvironment(Map<String, String>) - Method in class org.apache.bookkeeper.util.Shell
Set the environment for the command.
setEventLoopGroup(EventLoopGroup) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in interface org.apache.bookkeeper.common.component.LifecycleComponent
Set the default handler invoked when a lifecycle component abruptly terminates due an uncaught exception.
setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.bookkeeper.proto.BookieServer
Currently the uncaught exception handler is used for DeathWatcher to notify lifecycle management that a bookie is dead for some reasons.
setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.bookkeeper.replication.AutoRecoveryMain
Currently the uncaught exception handler is used for DeathWatcher to notify lifecycle management that a bookie is dead for some reasons.
setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.bookkeeper.server.service.AutoRecoveryService
 
setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.bookkeeper.server.service.BookieService
 
setExists(boolean) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bool exists = 1;
setExplicitLac(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
setExplicitLac(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
setExplicitLac(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
setExplicitLac(long, ByteBuf) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
setExplicitLac(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
setExplicitLac(long, ByteBuf) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
setExplicitLac(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
setExplicitLac(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
setExplicitLac(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
setExplicitLac(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
setExplicitLac(ByteString) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
optional bytes explicitLac = 4;
setExplicitLac(ByteBuf) - Method in class org.apache.bookkeeper.bookie.FileInfo
 
setExplicitLac(ByteBuf) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
setExplicitLac(ByteBuf) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
setExplicitLac(ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
setExplicitLac(ByteBuf, BookkeeperInternalCallbacks.WriteCallback, Object, byte[]) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
setExplicitLac(ByteBuf, BookkeeperInternalCallbacks.WriteCallback, Object, byte[]) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
setExplictLacInterval(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the interval to check the need for sending an explicit LAC.
setExtensions(int, String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
repeated string extensions = 6;
setExtensions(List<String>) - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
setExtraServerComponents(String[]) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the extra list of server lifecycle components to enable on a bookie server.
setFeature(String, Feature) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
 
setFenced() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
setFenced() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
setFenced() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
setFenced() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorReadOnlyImpl
 
setFenced(boolean) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bool fenced = 2;
setFenced(long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
setFenced(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
setFenced(long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
setFenced(long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
setFenced(long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
setFenced(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Fenced the ledger id in ledger storage.
setFenced(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
setFenced(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
setFenced(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
setFenced(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
setField(String, byte[]) - Method in class org.apache.bookkeeper.metastore.Value
 
setFileInfoCacheInitialCapacity(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the minimum total size for the internal file info cache tables for initialization.
setFileInfoFormatVersionToWrite(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set fileinfo format version to write.
setFileInfoMaxIdleTime(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the max idle time allowed for a open file info existed in file info cache.
setFirstEntryId(long) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
required int64 firstEntryId = 2;
setFirstSpeculativeReadLACTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the period of time after which the first speculative read last add confirmed and entry should be triggered.
setFirstSpeculativeReadTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the first speculative read timeout.
setFlag(BookkeeperProtocol.AddRequest.Flag) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
optional .AddRequest.Flag flag = 100;
setFlag(BookkeeperProtocol.ReadRequest.Flag) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
optional .ReadRequest.Flag flag = 100;
setFloat(int, float) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setFlushDelay(long) - Method in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
setFlushInterval(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set flush interval.
setFlushIntervalInBytes(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set entry log flush interval in bytes.
setFlushMaxOutstandingBytesCounter(Counter) - Method in class org.apache.bookkeeper.bookie.stats.JournalStats
 
setForceAllowCompaction(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Allow manually force compact the entry log or not.
setForceCompacting(boolean) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
setForceLedgerRequest(BookkeeperProtocol.ForceLedgerRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ForceLedgerRequest forceLedgerRequest = 107;
setForceLedgerRequest(BookkeeperProtocol.ForceLedgerRequest.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ForceLedgerRequest forceLedgerRequest = 107;
setForceLedgerResponse(BookkeeperProtocol.ForceLedgerResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ForceLedgerResponse forceLedgerResponse = 107;
setForceLedgerResponse(BookkeeperProtocol.ForceLedgerResponse.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ForceLedgerResponse forceLedgerResponse = 107;
setForceReadOnlyBookie(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets that whether force start a bookie in readonly mode.
setForceWriteRequests(BatchedBlockingQueue<Journal.ForceWriteRequest>) - Method in class org.apache.bookkeeper.bookie.Journal
 
setFreeDiskSpace(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
optional int64 freeDiskSpace = 3;
setFreeSpace(long) - Method in class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
setGcEntryLogMetadataCacheEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set whether the bookie is configured to use persistent entrylogMetadataMap.
setGcEntryLogMetadataCachePath(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set directory to persist Entrylog metadata if gcPersistentEntrylogMetadataMapEnabled is true.
setGcOverreplicatedLedgerMaxConcurrentRequests(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Max number of concurrent requests in garbage collection of overreplicated ledgers.
setGcOverreplicatedLedgerWaitTime(long, TimeUnit) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set wait time for garbage collection of overreplicated ledgers.
setGcWaitTime(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set garbage collection wait time.
setGetBookieInfoIntervalSeconds(int, TimeUnit) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the time interval between successive polls for bookie get info.
setGetBookieInfoRequest(BookkeeperProtocol.GetBookieInfoRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
setGetBookieInfoRequest(BookkeeperProtocol.GetBookieInfoRequest.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetBookieInfoRequest getBookieInfoRequest = 105;
setGetBookieInfoResponse(BookkeeperProtocol.GetBookieInfoResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
setGetBookieInfoResponse(BookkeeperProtocol.GetBookieInfoResponse.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetBookieInfoResponse getBookieInfoResponse = 105;
setGetBookieInfoRetryIntervalSeconds(int, TimeUnit) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the time interval between retries on unsuccessful GetInfo requests.
setGetBookieInfoTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the timeout value in secs for the GET_BOOKIE_INFO request.
setGetDelay(long) - Method in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
setGetListOfEntriesOfLedgerRequest(BookkeeperProtocol.GetListOfEntriesOfLedgerRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
setGetListOfEntriesOfLedgerRequest(BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .GetListOfEntriesOfLedgerRequest getListOfEntriesOfLedgerRequest = 108;
setGetListOfEntriesOfLedgerResponse(BookkeeperProtocol.GetListOfEntriesOfLedgerResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
setGetListOfEntriesOfLedgerResponse(BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .GetListOfEntriesOfLedgerResponse getListOfEntriesOfLedgerResponse = 108;
setHeader(BookkeeperProtocol.BKPacketHeader) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
required .BKPacketHeader header = 1;
setHeader(BookkeeperProtocol.BKPacketHeader) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
required .BKPacketHeader header = 1;
setHeader(BookkeeperProtocol.BKPacketHeader.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
required .BKPacketHeader header = 1;
setHeader(BookkeeperProtocol.BKPacketHeader.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
required .BKPacketHeader header = 1;
setHighPriorityWritesAvailability(boolean) - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
setHighPriorityWritesAvailability(boolean) - Method in interface org.apache.bookkeeper.bookie.StateManager
Enable/Disable the availability for high priority writes.
setHost(String) - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
setHost(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string host = 3;
setHostBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string host = 3;
setHostnameVerificationEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/Disable hostname verification for tls connection.
setHttpServerEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set whether to start the http server or not.
setHttpServerHost(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set Http server host listening on.
setHttpServerKeyStorePassword(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set Http server keyStore password.
setHttpServerKeystorePath(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set Http server keystore path.
setHttpServerPort(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set Http server port listening on.
setHttpServerTlsEnable(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set if Http Server Tls enable.
setHttpServerTrustStorePasswordPassword(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set Http server trustStore password.
setHttpServerTrustStorePath(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set Http server trustStore path.
setId(String) - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
setId(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string id = 1;
setIdBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string id = 1;
setIgnoreExtraServerComponentsStartupFailures(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the flag whether to ignore startup failures on loading server components specified at ServerConfiguration.getExtraServerComponents().
setIgnoreLocalNodeInPlacementPolicy(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Sets the flag to ignore usage of localnode in placement policy.
setIndex(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setIndexDirName(String[]) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set dir name to store index files.
setIndexDirs(String) - Method in class org.apache.bookkeeper.bookie.Cookie.Builder
 
setIndexDirs(String) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string indexDirs = 5;
setIndexDirsBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string indexDirs = 5;
setInstanceId(String) - Method in class org.apache.bookkeeper.bookie.Cookie.Builder
 
setInstanceId(String) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string instanceId = 4;
setInstanceIdBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
optional string instanceId = 4;
setInt(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setIntLE(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setIsForceGCAllowWhenNoSpace(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set whether force GC is allowed when disk full or almost full.
setIsThrottleByBytes(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set whether use bytes to throttle garbage collector compaction or not.
setJournalAdaptiveGroupWrites(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Enable/disable group journal force writes.
setJournalAlignmentSize(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set journal alignment size.
setJournalBufferedEntriesThreshold(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set maximum entries to buffer to impose on a journal write to achieve grouping.
setJournalBufferedWritesThreshold(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set maximum bytes to buffer to impose on a journal write to achieve grouping.
setJournalChannelProvider(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set JournalChannelProvider classname.
setJournalDir(String) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string journalDir = 2;
setJournalDirBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string journalDir = 2;
setJournalDirName(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set dir name to store journal files.
setJournalDirs(String) - Method in class org.apache.bookkeeper.bookie.Cookie.Builder
 
setJournalDirsName(String[]) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set dir names to store journal files.
setJournalFlushWhenQueueEmpty(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set if we should flush the journal when queue is empty.
setJournalFormatVersionToWrite(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set journal format version to write.
setJournalMaxGroupWaitMSec(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets the maximum latency to impose on a journal write to achieve grouping.
setJournalMaxMemorySizeMb(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the max amount of memory that can be used by the journal.
setJournalPageCacheFlushIntervalMSec(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set PageCache flush interval in second.
setJournalQueueSize(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the size of the journal queue.
setJournalRemovePagesFromCache(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets that whether should we remove pages from page cache after force write.
setJournalReuseFiles(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set reuse journal files.
setJournalSyncData(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Enable or disable journal syncs.
setJournalWriteBufferSizeKB(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the size of the write buffers used for the journal.
setJournalWriteData(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Should the data be written to journal before acknowledgment.
setKey(String) - Method in class org.apache.bookkeeper.metastore.MetastoreTableItem
Set the key of the item.
setKey(String) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string key = 1;
setKey(String) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional string key = 1;
setKeyBytes(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string key = 1;
setKeyBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional string key = 1;
setLac(long) - Method in class org.apache.bookkeeper.client.PendingWriteLacOp
 
setLac(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required int64 lac = 2;
setLacBody(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
lac sent by PutLacRequest
setLacUpdateTimestamp(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
optional int64 lacUpdateTimestamp = 6;
setLacUpdateTimestamp(long) - Method in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
setLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.FileInfo
 
setLastAddConfirmed(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
setLastAddConfirmed(long) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
setLastAddConfirmed(long) - Method in class org.apache.bookkeeper.client.ReadOpBase.ReadContext
 
setLastAddConfirmed(long) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.ReadEntryCallbackCtx
 
setLastAddConfirmed(long) - Method in class org.apache.bookkeeper.proto.ReadLastConfirmedAndEntryContext
 
setLastConfirmed(long) - Method in class org.apache.bookkeeper.client.LedgerHandle.LastConfirmedCtx
 
setLastEntryBody(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
Actual last entry on the disk
setLastEntryId(long) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional int64 lastEntryId = 4;
setLastLogId(File, long) - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
writes the given id to the "lastId" file in the given directory.
setLastLogin(long) - Method in class org.apache.bookkeeper.sasl.TGTRefreshThread
 
setLastLogMark(Long, long) - Method in class org.apache.bookkeeper.bookie.Journal
Update lastLogMark of the journal Indicates that the file has been processed.
setLastMajorCompactionTime(long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
setLastMinorCompactionTime(long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
setLayoutVersion(int) - Method in class org.apache.bookkeeper.bookie.Cookie.Builder
 
setLedgerAndFirstEntry(long, long) - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
setLedgerDirNames(String[]) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set dir names to store ledger data.
setLedgerDirs(String) - Method in class org.apache.bookkeeper.bookie.Cookie.Builder
 
setLedgerDirs(String) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string ledgerDirs = 3;
setLedgerDirsBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
required string ledgerDirs = 3;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required int64 ledgerId = 1;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required int64 ledgerId = 2;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
required int64 ledgerId = 1;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
required int64 ledgerId = 2;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
required int64 ledgerId = 1;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
required int64 ledgerId = 2;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
required int64 ledgerId = 1;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
required int64 ledgerId = 2;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
required int64 ledgerId = 1;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required int64 ledgerId = 2;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required int64 ledgerId = 1;
setLedgerId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
required int64 ledgerId = 2;
setLedgerIdAssigned(Long) - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.BufferedLogChannel
 
setLedgerIdFormatter(LedgerIdFormatter) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToDBStorageCommand
 
setLedgerIdFormatter(LedgerIdFormatter) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ConvertToInterleavedStorageCommand
 
setLedgerIdFormatterClass(Class<? extends LedgerIdFormatter>) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set Ledger id formatter Class.
setLedgerLength(long) - Method in class org.apache.bookkeeper.client.PendingAddOp
 
setLedgerManagerFactory(LedgerManagerFactory) - Method in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
setLedgerManagerFactoryClass(Class<? extends LedgerManagerFactory>) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set Ledger Manager Factory Class.
setLedgerManagerFactoryClassName(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set Ledger Manager Factory Class Name.
setLedgerManagerType(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
setLedgerMetadata(Versioned<LedgerMetadata>, Versioned<LedgerMetadata>) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
setLedgerMetadataFormatVersion(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set Ledger metadata format version.
setLedgerMetadataRocksdbConf(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set ledger metadata rocksdb conf.
setLedgerReplicationEnabled(boolean) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
setLedgerReplicationEnabled(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
setLedgerStorageClass(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the LedgerStorage implementation class name.
setLength(long) - Method in class org.apache.bookkeeper.client.impl.LedgerEntryImpl
 
setLength(long) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int64 length = 3;
setLevel(int) - Method in interface org.apache.bookkeeper.net.Node
Set this node's level in the tree.
setLevel(int) - Method in class org.apache.bookkeeper.net.NodeBase
Set this node's level in the tree.
setLh(LedgerHandle) - Method in class org.apache.bookkeeper.client.SyncCounter
 
setLimbo(boolean) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
optional bool limbo = 5;
setLimbo(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
setLimboState(long) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
setLimboState(long) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Set a ledger to limbo state.
setLimboState(long) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
setLimboState(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
setLimboState(long) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
setLimitStatsLogging(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Sets flag to limit the stats logging.
setListeningInterface(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the network interface that the bookie should listen on.
setLocalScrubPeriod(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set local scrub period in seconds (<=0 for disabled).
setLocalScrubRateLimit(double) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Get local scrub rate limit (entries/second).
setLockReleaseOfFailedLedgerGracePeriod(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the grace period, in milliseconds, which the replication worker has to wait before releasing the lock after it failed to replicate a ledger.
setLogin(LoginContext) - Method in interface org.apache.bookkeeper.sasl.JAASCredentialsContainer
 
setLogin(LoginContext) - Method in class org.apache.bookkeeper.sasl.SASLBookieAuthProviderFactory
 
setLogin(LoginContext) - Method in class org.apache.bookkeeper.sasl.SASLClientProviderFactory
 
setLogMark(long, long) - Method in class org.apache.bookkeeper.bookie.LogMark
 
setLong(byte[], int, long) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.ArrayUtil
 
setLong(int, long) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setLongLE(int, long) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setLongVersion(long) - Method in class org.apache.bookkeeper.versioning.LongVersion
 
setLostBookieRecoveryDelay(int) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Setter for LostBookieRecoveryDelay value (in seconds) in Zookeeper.
setLostBookieRecoveryDelay(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the delay interval for starting recovery of a lost bookie.
setLostBookieRecoveryDelay(int) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Setter for the lostBookieRecoveryDelay znode.
setLostBookieRecoveryDelay(int) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
setLostBookieRecoveryDelay(int) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
setMajorCompacting(boolean) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
setMajorCompactionCounter(long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
setMajorCompactionInterval(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set interval to run major compaction.
setMajorCompactionMaxTimeMillis(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the maximum milliseconds to run major compaction.
setMajorCompactionThreshold(double) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set threshold of major compaction.
setMasterKey(long, byte[]) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
setMasterKey(long, byte[]) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
setMasterKey(long, byte[]) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
setMasterKey(long, byte[]) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
setMasterKey(long, byte[]) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
setMasterKey(long, byte[]) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Set the master key for a ledger.
setMasterKey(long, byte[]) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
setMasterKey(long, byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
setMasterKey(long, byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
setMasterKey(long, byte[]) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
setMasterKey(ByteString) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
required bytes masterKey = 3;
setMasterKey(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
required bytes masterKey = 3;
setMasterKey(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used while fencing a ledger.
setMasterKey(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
required bytes masterKey = 3;
setMaxAddsInProgressLimit(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set max number of adds in progress.
setMaxAllowedEnsembleChanges(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the max allowed ensemble change number.
setMaxBackupJournals(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set max number of older journal files to kept.
setMaxBatchReadSize(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the max batch read size.
setMaximumNumberOfActiveEntryLogs(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
setMaxJournalSizeMB(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set new max journal file size.
setMaxLAC(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
Piggyback LAC
setMaxPendingAddRequestPerThread(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the max number of pending add requests for each add worker thread.
setMaxPendingReadRequestPerThread(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the max number of pending read requests for each read worker thread.
setMaxProbabilityMultiplier(int) - Method in class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
setMaxProbabilityMultiplier(int) - Method in interface org.apache.bookkeeper.client.WeightedRandomSelection
 
setMaxProbabilityMultiplier(int) - Method in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
setMaxReadsInProgressLimit(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set max number of reads in progress.
setMaxSpeculativeReadLACTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the maximum interval between successive speculative read last add confirmed and entry requests.
setMaxSpeculativeReadTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the max speculative read timeout.
setMedium(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setMediumLE(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setMemoryLimitController(MemoryLimitController) - Method in class org.apache.bookkeeper.bookie.Journal
 
setMetadataServiceUri(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the metadata service uri.
setMetastoreImplClass(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set metastore implementation class.
setMetastoreMaxEntriesPerScan(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set max entries per scan in metastore.
setMinNumRacksPerWriteQuorum(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the minimum number of racks per write quorum.
setMinNumZonesPerWriteQuorum(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the minimum number of zones per write quorum in ZoneAwarePlacementPolicy.
setMinorCompacting(boolean) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
setMinorCompactionCounter(long) - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus
 
setMinorCompactionInterval(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set interval to run minor compaction.
setMinorCompactionMaxTimeMillis(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the maximum milliseconds to run minor compaction.
setMinorCompactionThreshold(double) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set threshold of minor compaction.
setMinUsableSizeForEntryLogCreation(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets the minimum safe usable size to be available in ledger directory for Bookie to create entry log files.
setMinUsableSizeForHighPriorityWrites(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets the minimum safe usable size to be available in ledger directory for Bookie to accept high priority writes.
setMinUsableSizeForIndexFileCreation(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets the minimum safe Usable size to be available in index directory for Bookie to create Index File while replaying journal at the time of Bookie Start in Readonly Mode (in bytes).
setNettyMaxFrameSizeBytes(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the max number of bytes a single message can be that is read by the bookie.
setNettyMaxFrameSizeBytes(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the max number of bytes a single message can be that is read by the bookie.
setNettyMaxFrameSizeBytes(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the max number of bytes a single message can be that is read by the bookie.
setNettyUsePooledBuffers(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
setNetworkLocation(String) - Method in interface org.apache.bookkeeper.net.Node
Set this node's network location.
setNetworkLocation(String) - Method in class org.apache.bookkeeper.net.NodeBase
Set this node's network location.
setNetworkTopologyStabilizePeriodSeconds(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the network topology stabilize period in seconds.
setNumAddWorkerThreads(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the number of threads that would handle write requests.
setNumChannelsPerBookie(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set num channels per bookie.
setNumHighPriorityWorkerThreads(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the number of threads that should be used for high priority requests (i.e.
setNumIOThreads(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the number of IO threads.
setNumJournalCallbackThreads(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Deprecated.
setNumLongPollWorkerThreads(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the number of threads that should handle long poll requests.
setNumOfMemtableFlushThreads(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
setNumReadWorkerThreads(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the number of threads that would handle read requests.
setNumWorkerThreads(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the number of worker threads.
setOffset(long, int) - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
setOomHandler(Consumer<OutOfMemoryError>) - Method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorWithOomHandler
 
setOomHandler(Consumer<OutOfMemoryError>) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorImpl
 
setOpenFileLimit(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set limitation of number of open files.
setOpenLedgerRereplicationGracePeriod(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the grace period which the rereplication worker will wait before fencing and rereplicating a ledger fragment which is still being written to, on bookie failure.
setOperation(BookkeeperProtocol.OperationType) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required .OperationType operation = 2;
setOperationMaxNumbersInSingleRocksDBWriteBatch(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the max operation numbers in a single rocksdb write batch.
setOpportunisticStriping(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/Disable opportunistic striping.
setOpStats(int, BKStats.OpStats) - Method in class org.apache.bookkeeper.proto.BKStats
Set stats of a specified operation.
setOutstanding() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
setOutstanding() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
setOutstanding() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.ReadCompletion
 
setPageLimit(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set limitation number of index pages in ledger cache.
setPageSize(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set page size.
setParent(String) - Method in class org.apache.bookkeeper.tools.framework.CliCommand
 
setParent(Node) - Method in interface org.apache.bookkeeper.net.Node
Set this node's parent.
setParent(Node) - Method in class org.apache.bookkeeper.net.NodeBase
Set this node's parent.
setPassed(boolean) - Method in class org.apache.bookkeeper.server.http.service.BookieSanityService.BookieSanity
 
setPassword(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
optional bytes password = 8;
setPayload(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
required bytes payload = 2;
setPCBCTimeoutTimerNumTicks(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Deprecated.
setPCBCTimeoutTimerTickDurationMs(long) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Deprecated.
setPermittedStartupUsers(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Limit who can start the application to prevent future permission errors.
setPersistBookieStatusEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Whether to persist the bookie status so that when bookie server restarts, it will continue using the previous status.
setPiggyBackedLac(long) - Method in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
setPlacementPolicyCheckCTime(long) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Setter for the PlacementPolicyCheck last executed ctime.
setPlacementPolicyCheckCTime(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
setPlacementPolicyCheckCTime(long) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
setPlacementPolicyCheckCTime(long) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
optional int64 placementPolicyCheckCTime = 1;
setPort(int) - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
setPort(int) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required int32 port = 2;
setPreserveMdcForTaskExecution(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Whether to preserve MDC for tasks in Executor.
setPreviousLAC(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used for waiting on last add confirmed update
setPrint(Consumer<String>) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.LedgerCommand
 
setPriority(int) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
optional uint32 priority = 4 [default = 0];
setProperties(Map<String, String>) - Method in class org.apache.bookkeeper.discover.BookieServiceInfo
 
setProperty(String, Object) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
setProtocol(String) - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
setProtocol(String) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string protocol = 4;
setProtocolBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
required string protocol = 4;
setQuorumSize(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required int32 quorumSize = 1;
setrc(int) - Method in class org.apache.bookkeeper.client.SyncCounter
 
setRC(int) - Method in class org.apache.bookkeeper.client.LedgerHandle.LastConfirmedCtx
 
setReadBufferBytes(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the number of bytes we should use as capacity for org.apache.bookkeeper.bookie.BufferedReadChannel.
setReadEntryTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the timeout for read entry request.
setReadLacRequest(BookkeeperProtocol.ReadLacRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ReadLacRequest readLacRequest = 104;
setReadLacRequest(BookkeeperProtocol.ReadLacRequest.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .ReadLacRequest readLacRequest = 104;
setReadLacResponse(BookkeeperProtocol.ReadLacResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ReadLacResponse readLacResponse = 104;
setReadLacResponse(BookkeeperProtocol.ReadLacResponse.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .ReadLacResponse readLacResponse = 104;
setReadOnly(boolean) - Method in class org.apache.bookkeeper.server.http.service.BookieSanityService.BookieSanity
 
setReadOnly(boolean) - Method in class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService.ReadOnlyState
 
setReadOnly(boolean) - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
setReadonlyBookiesCount(int) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
setReadonlyBookiesCount(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
setReadOnlyModeEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set whether the bookie is able to go into read-only mode.
setReadOnlyModeOnAnyDiskFullEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set whether the bookie is able to go into read-only mode when any disk is full.
setReadRequest(BookkeeperProtocol.ReadRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
Requests
setReadRequest(BookkeeperProtocol.ReadRequest.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
Requests
setReadResponse(BookkeeperProtocol.ReadResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
Response
setReadResponse(BookkeeperProtocol.ReadResponse.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
Response
setReadTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
setReadWorkerThreadsThrottlingEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Use auto-throttling of the read-worker threads.
setRecoveryBatchReadEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/disable recovery batch read.
setRecoveryReadBatchSize(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set Recovery Read Batch Size.
setRecvByteBufAllocatorSizeInitial(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set Recv ByteBuf allocator initial buf size.
setRecvByteBufAllocatorSizeMax(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set Recv ByteBuf allocator max buf size.
setRecvByteBufAllocatorSizeMin(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set Recv ByteBuf allocator min buf size.
setRegistrationClientClass(Class<? extends RegistrationClient>) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Deprecated.
since 4.7.0
setRegistrationManagerClass(Class<? extends RegistrationManager>) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Deprecated.
setReorderReadSequenceEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/disable reordering read sequence on reading entries.
setReorderThresholdPendingRequests(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the threshold for the number of pending requests beyond which to reorder reads.
setRepairedPlacementPolicyNotAdheringBookieEnable(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
setReplica(int, String) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
repeated string replica = 1;
setReplicaList(List<String>) - Method in class org.apache.bookkeeper.meta.UnderreplicatedLedger
 
setReplicasCheckCTime(long) - Method in interface org.apache.bookkeeper.meta.LedgerUnderreplicationManager
Setter for the ReplicasCheck last executed ctime.
setReplicasCheckCTime(long) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerUnderreplicationManager
 
setReplicasCheckCTime(long) - Method in class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
setReplicasCheckCTime(long) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
optional int64 replicasCheckCTime = 1;
setReplicateType(LedgerFragment.ReplicateType) - Method in class org.apache.bookkeeper.client.LedgerFragment
 
setReplicationRateByBytes(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the bytes rate of re-replication.
setRequestContext(int, BookkeeperProtocol.ContextPair) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
setRequestContext(int, BookkeeperProtocol.ContextPair.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
to pass MDC context
setRequested(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
bitwise OR of Flags
setRequestProcessor(RequestProcessor) - Method in class org.apache.bookkeeper.proto.BookieNettyServer
 
setRequestTimerNumTicks(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the number of ticks per wheel for the request timer.
setRequestTimerTickDurationMs(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the tick duration in milliseconds.
setRereplicationEntryBatchSize(long) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the max entries to keep in fragment for re-replication.
setRunning(boolean) - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
setRwRereplicateBackoffMs(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set how long to backoff when encountering exception on rereplicating a ledger.
setSanityCheckMetricsEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Enable sanity check metrics in bookie stats.
setSegment(int, DataFormats.LedgerMetadataFormat.Segment) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
setSegment(int, DataFormats.LedgerMetadataFormat.Segment.Builder) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
repeated .LedgerMetadataFormat.Segment segment = 6;
setSequence(Enumeration<LedgerEntry>) - Method in class org.apache.bookkeeper.client.SyncCounter
 
setServerConfiguration(ServerConfiguration) - Method in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
setServerNumIOThreads(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the number of IO threads.
setServerSockKeepalive(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set socket keepalive setting.
setServerSockLinger(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set socket linger timeout on close.
setServerTcpNoDelay(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set socket nodelay setting.
setServerWriteBufferHighWaterMark(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set server netty channel write buffer high water mark.
setServerWriteBufferLowWaterMark(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set server netty channel write buffer low water mark.
setSessionStateListener(MetadataClientDriver.SessionStateListener) - Method in interface org.apache.bookkeeper.meta.MetadataClientDriver
sets session state listener.
setSessionStateListener(MetadataClientDriver.SessionStateListener) - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
setShadedLedgerManagerFactoryClassPrefix(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the class prefix of the shaded ledger manager factory class for instantiating a ledger manager factory.
setShort(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setShortLE(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setShutdownHandler(StateManager.ShutdownHandler) - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
setShutdownHandler(StateManager.ShutdownHandler) - Method in interface org.apache.bookkeeper.bookie.StateManager
 
setShuttingDown(boolean) - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
setSkipListArenaChunkSize(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the number of bytes we used as chunk allocation for org.apache.bookkeeper.bookie.SkipListArena.
setSkipListArenaMaxAllocSize(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the max size we should allocate from the skiplist arena.
setSkipListSizeLimit(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set skip list size limit.
setSkipReplayJournalInvalidRecord(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
When this config is set to true,if we replay journal failed, we will skip.
setSortedLedgerStorageEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Deprecated.
Use ServerConfiguration.setLedgerStorageClass(String) to configure the implementation class
setSpeculativeReadLACTimeoutBackoffMultiplier(float) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the multipler to use when determining time between successive speculative read LAC requests.
setSpeculativeReadTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the speculative read timeout.
setSpeculativeReadTimeoutBackoffMultiplier(float) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the multipler to use when determining time between successive speculative read requests.
setStartTLSRequest(BookkeeperProtocol.StartTLSRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .StartTLSRequest startTLSRequest = 106;
setStartTLSRequest(BookkeeperProtocol.StartTLSRequest.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .StartTLSRequest startTLSRequest = 106;
setStartTLSResponse(BookkeeperProtocol.StartTLSResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .StartTLSResponse startTLSResponse = 106;
setStartTLSResponse(BookkeeperProtocol.StartTLSResponse.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .StartTLSResponse startTLSResponse = 106;
setStartTLSTimeout(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the timeout value in secs for the START_TLS request.
setState(DataFormats.LedgerMetadataFormat.State) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
required .LedgerMetadataFormat.State state = 5 [default = OPEN];
setStateManager(StateManager) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
setStateManager(StateManager) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
setStateManager(StateManager) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
setStateManager(StateManager) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
setStateManager(StateManager) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
setStatisticsEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Turn on/off statistics.
setStatsLogger(StatsLogger) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
setStatsProvider(StatsProvider) - Method in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
setStatsProviderClass(Class<? extends StatsProvider>) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the stats provider used by bookie.
setStatus(BookkeeperProtocol.StatusCode) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
required .StatusCode status = 1;
setStatus(BookkeeperProtocol.StatusCode) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
required .StatusCode status = 1;
setStatus(BookkeeperProtocol.StatusCode) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
required .StatusCode status = 1;
setStatus(BookkeeperProtocol.StatusCode) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
required .StatusCode status = 1;
setStatus(BookkeeperProtocol.StatusCode) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
required .StatusCode status = 1;
setStatus(BookkeeperProtocol.StatusCode) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
required .StatusCode status = 1;
setStatus(BookkeeperProtocol.StatusCode) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
EOK if the underlying request succeeded.
setStatus(BookkeeperProtocol.StatusCode) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
required .StatusCode status = 1;
setStickyReadsEnabled(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable/disable having read operations for a ledger to be sticky to a single bookie.
setStorageStateFlag(LedgerStorage.StorageState) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
setStorageStateFlag(LedgerStorage.StorageState) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Set a storage state flag for the storage instance.
setStorageStateFlag(LedgerStorage.StorageState) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
setStorageStateFlag(LedgerStorage.StorageState) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
setStorageStateFlag(LedgerStorage.StorageState) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
setStorageStateFlags(int, int) - Method in class org.apache.bookkeeper.bookie.storage.ldb.LedgerMetadataIndex
 
setStoreSystemtimeAsLedgerCreationTime(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Enable the client to use system time as the ledger creation time.
setStoreSystemTimeAsLedgerUnderreplicatedMarkTime(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Enable the Auditor to use system time as underreplicated ledger mark time.
SettableFeature - Class in org.apache.bookkeeper.feature
A feature implementation that allow changing availability programmatically.
SettableFeature(String, boolean) - Constructor for class org.apache.bookkeeper.feature.SettableFeature
 
SettableFeature(String, int) - Constructor for class org.apache.bookkeeper.feature.SettableFeature
 
SettableFeatureProvider - Class in org.apache.bookkeeper.feature
A provider will provide settable features.
SettableFeatureProvider(String, int) - Constructor for class org.apache.bookkeeper.feature.SettableFeatureProvider
 
setTaskExecutionWarnTimeMicros(long) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set task execution duration which triggers a warning.
setTcpUserTimeoutMillis(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set client netty TCP user timeout in millis (only for Epoll channels).
setThrottleValue(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set throttle value.
setTimeOut(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
Used as a timeout (in milliseconds) for the long polling request
setTimeoutMonitorIntervalSec(long) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the interval between successive executions of the operation timeout monitor.
setTimeoutTaskIntervalMillis(long) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Deprecated.
setTimeoutTimerNumTicks(int) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set number of ticks that used for timeout timer.
setTimeoutTimerTickDurationMs(long) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the tick duration in milliseconds that used for timeout timer.
setTLSCertFilesRefreshDurationSeconds(long) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set tls certificate files refresh duration in seconds.
setTLSCertificatePath(String) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the path to file containing TLS Certificate.
setTLSCertificatePath(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the path to file containing TLS Certificate.
setTLSClientAuthentication(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Specify whether the client will send an TLS certificate on TLS-handshake.
setTLSEnabledCipherSuites(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the list of enabled TLS cipher suites.
setTLSEnabledProtocols(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the list of enabled TLS protocols.
setTLSKeyStore(String) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the keystore path for the client.
setTLSKeyStore(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the keystore path for the client.
setTLSKeyStorePasswordPath(String) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the path to file containing keystore password, if the client keystore is password protected.
setTLSKeyStorePasswordPath(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the path to file containing keystore password, if the client keystore is password protected.
setTLSKeyStoreType(String) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the keystore type for client.
setTLSKeyStoreType(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the keystore type for client.
setTLSProvider(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set TLS Provider (JDK or OpenSSL).
setTLSProviderFactoryClass(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the client security provider factory class name.
setTLSTrustStore(String) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the truststore path for the client.
setTLSTrustStore(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the truststore path for the client.
setTLSTrustStorePasswordPath(String) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the path to file containing truststore password, if the client truststore is password protected.
setTLSTrustStorePasswordPath(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the path to file containing truststore password, if the client truststore is password protected.
setTLSTrustStoreType(String) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the truststore type for client.
setTLSTrustStoreType(String) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the truststore type for client.
setToReadOnlyMode() - Method in class org.apache.bookkeeper.bookie.BookieStatus
 
setTotalBookiesCount(int) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
setTotalBookiesCount(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
setTotalDiskCapacity(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
optional int64 totalDiskCapacity = 2;
setTotalSpace(long) - Method in class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
setToWritableMode() - Method in class org.apache.bookkeeper.bookie.BookieStatus
 
setTxnId(long) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required uint64 txnId = 3;
setType(String) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required string type = 1;
setTypeBytes(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required string type = 1;
setUnavailableBookiesCount(int) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
setUnavailableBookiesCount(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
setUnderreplicatedLedgerRecoveryGracePeriod(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Sets the grace period (in seconds) for underreplicated ledgers recovery.
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat.Builder
 
setupCli(String, CliSpec<CliFlagsT>, Map<String, Command>) - Static method in class org.apache.bookkeeper.tools.framework.Cli
 
setupConsole(CliSpec<CliFlagsT>) - Static method in class org.apache.bookkeeper.tools.framework.Cli
 
setUseHostNameAsBookieID(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configure the bookie to use its hostname to register with the co-ordination service(eg: zookeeper) and in ledger metadata.
setUseHostnameResolveLocalNodePlacementPolicy(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set the flag to use hostname to resolve local node placement policy.
setUseShortHostName(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Configure the bookie to use its short hostname or FQDN hostname to register with the co-ordination service(eg: zookeeper) and in ledger metadata.
setUseTargetEntryLogSizeForGc(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
 
setUseTransactionalCompaction(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set whether to use transactional compaction and using a separate log for compaction or not.
setUseV2WireProtocol(boolean) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Set whether or not to use older Bookkeeper wire protocol (no protobuf).
setValue(ByteString) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry.Builder
optional bytes value = 2;
setValue(String) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string value = 2;
setValue(Versioned<Value>) - Method in class org.apache.bookkeeper.metastore.MetastoreTableItem
Set the value of the item.
setValue(T) - Method in class org.apache.bookkeeper.versioning.Versioned
 
setValueBytes(ByteString) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair.Builder
required string value = 2;
setVerifyMetadataOnGc(boolean) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set whether the bookie is configured to double check prior to gc.
setVersion(int) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat.Builder
required int32 version = 2;
setVersion(BookkeeperProtocol.ProtocolVersion) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader.Builder
required .ProtocolVersion version = 1;
setVersion(Version) - Method in class org.apache.bookkeeper.versioning.Versioned
 
setWaitTimeoutOnBackpressureMillis(long) - Method in class org.apache.bookkeeper.conf.ClientConfiguration
Timeout controlling wait on request send in case of unresponsive bookie(s) (i.e.
setWaitTimeoutOnResponseBackpressureMillis(long) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Timeout controlling wait on response send in case of unresponsive client (i.e.
setWorkingDirectory(File) - Method in class org.apache.bookkeeper.util.Shell
Set the working directory.
setWritable(boolean) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
setWritableBookiesCount(int) - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
setWritableBookiesCount(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
setWriteBufferBytes(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set the number of bytes used as capacity for the write buffer.
setWriteFlags(int) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Builder
optional int32 writeFlags = 5;
setWriteLacRequest(BookkeeperProtocol.WriteLacRequest) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .WriteLacRequest writeLacRequest = 103;
setWriteLacRequest(BookkeeperProtocol.WriteLacRequest.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request.Builder
optional .WriteLacRequest writeLacRequest = 103;
setWriteLacResponse(BookkeeperProtocol.WriteLacResponse) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .WriteLacResponse writeLacResponse = 103;
setWriteLacResponse(BookkeeperProtocol.WriteLacResponse.Builder) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response.Builder
optional .WriteLacResponse writeLacResponse = 103;
setWritingCompactingLogId(long) - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
setWritingLogId(long) - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
 
setZero(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
setZk(ZooKeeper) - Method in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
setZkEnableSecurity(boolean) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set the usage of ACLs of new z-nodes.
setZkLedgersRootPath(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Deprecated.
setZkRequestRateLimit(double) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set zookeeper access request rate limit.
setZkRetryBackoffMaxMs(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set zookeeper client backoff retry max time in millis.
setZkRetryBackoffMaxRetries(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set zookeeper client backoff max retry times.
setZkRetryBackoffStartMs(int) - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Set zookeeper client backoff retry start time in millis.
setZkServers(String) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Deprecated.
setZkTimeout(int) - Method in class org.apache.bookkeeper.conf.AbstractConfiguration
Set zookeeper timeout.
setZookeeper(ZooKeeper) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
Deprecated.
sha1() - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the SHA-1 algorithm (160 bits).
SHA1 - Static variable in class com.scurrilous.circe.params.SimpleHashParameters
Represents the SHA-1 (160-bit) hash algorithm.
sha256() - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the SHA-256 algorithm (256 bits).
SHA256 - Static variable in class com.scurrilous.circe.params.SimpleHashParameters
Represents the SHA-256 (256-bit) hash algorithm.
sha384() - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the SHA-384 algorithm (384 bits).
SHA384 - Static variable in class com.scurrilous.circe.params.SimpleHashParameters
Represents the SHA-384 (384-bit) hash algorithm.
sha512() - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the SHA-512 algorithm (512 bits).
SHA512 - Static variable in class com.scurrilous.circe.params.SimpleHashParameters
Represents the SHA-512 (512-bit) hash algorithm.
SHADED_LEDGER_MANAGER_FACTORY_CLASS_PREFIX - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
shared() - Static method in class org.apache.bookkeeper.common.util.SharedResourceManager
 
SharedResourceManager - Class in org.apache.bookkeeper.common.util
A holder for shared resource singletons.
SharedResourceManager.Resource<T> - Interface in org.apache.bookkeeper.common.util
Defines a resource, and the way to create and destroy instances of it.
Shell - Class in org.apache.bookkeeper.util
A base class for running a Unix command.
Shell() - Constructor for class org.apache.bookkeeper.util.Shell
 
Shell(long) - Constructor for class org.apache.bookkeeper.util.Shell
 
Shell.ExitCodeException - Exception in org.apache.bookkeeper.util
This is an IOException with exit code added.
Shell.ShellCommandExecutor - Class in org.apache.bookkeeper.util
A simple shell command executor.
shellCmdName - Variable in class org.apache.bookkeeper.tools.cli.helpers.BookieShellCommand
 
ShellCommandExecutor(String[]) - Constructor for class org.apache.bookkeeper.util.Shell.ShellCommandExecutor
 
ShellCommandExecutor(String[], File) - Constructor for class org.apache.bookkeeper.util.Shell.ShellCommandExecutor
 
ShellCommandExecutor(String[], File, Map<String, String>) - Constructor for class org.apache.bookkeeper.util.Shell.ShellCommandExecutor
 
ShellCommandExecutor(String[], File, Map<String, String>, long) - Constructor for class org.apache.bookkeeper.util.Shell.ShellCommandExecutor
Create a new instance of the ShellCommandExecutor to execute a command.
shFactory - Variable in class org.apache.bookkeeper.proto.DefaultPerChannelBookieClientPool
 
SHORT - org.apache.bookkeeper.common.conf.Type
 
ShortReadException - Exception in org.apache.bookkeeper.bookie
Short Read Exception.
ShortReadException(String) - Constructor for exception org.apache.bookkeeper.bookie.ShortReadException
 
ShortReadException(String, Throwable) - Constructor for exception org.apache.bookkeeper.bookie.ShortReadException
 
shouldPiggybackEntry(BookkeeperProtocol.ReadRequest) - Static method in class org.apache.bookkeeper.proto.RequestUtils
 
shouldRoll(ByteBuf, long) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.WriterWithMetadata
 
shouldStoreCtime() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
shouldStoreCtime(LedgerMetadata) - Static method in class org.apache.bookkeeper.client.LedgerMetadataUtils
 
shrinkFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
shrinkFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
shrinkFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
shrinkFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
shrinkFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
shrinkFactor - Variable in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
shrinkFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.Builder
 
shrinkFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet.Builder
 
shrinkFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.Builder
 
shrinkFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.Builder
 
shrinkFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap.Builder
 
shrinkFactor(float) - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet.Builder
 
shuffleWithMask(DistributionSchedule.WriteSet, int, int) - Static method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
Shuffle all the entries of an array that matches a mask.
shutdown() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
shutdown() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
shutdown() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
Shutdown the garbage collector thread.
shutdown() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
shutdown() - Method in class org.apache.bookkeeper.bookie.Journal
Shuts down the journal.
shutdown() - Method in class org.apache.bookkeeper.bookie.LedgerDirsMonitor
 
shutdown() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Cleanup and free any resources being used by the storage system.
shutdown() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
shutdown() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
shutdown() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
shutdown() - Method in class org.apache.bookkeeper.bookie.SyncThread
 
shutdown() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
shutdown() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
shutdown() - Method in class org.apache.bookkeeper.proto.BookieNettyServer
 
shutdown() - Method in class org.apache.bookkeeper.proto.BookieServer
 
shutdown() - Method in class org.apache.bookkeeper.replication.Auditor
Shutdown the auditor.
shutdown() - Method in class org.apache.bookkeeper.replication.AuditorBookieCheckTask
 
shutdown() - Method in class org.apache.bookkeeper.replication.AuditorCheckAllLedgersTask
 
shutdown() - Method in class org.apache.bookkeeper.replication.AuditorElector
Shutting down AuditorElector.
shutdown() - Method in class org.apache.bookkeeper.replication.AuditorPlacementPolicyCheckTask
 
shutdown() - Method in class org.apache.bookkeeper.replication.AuditorReplicasCheckTask
 
shutdown() - Method in class org.apache.bookkeeper.replication.AuditorTask
 
shutdown() - Method in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
shutdown() - Method in class org.apache.bookkeeper.replication.ReplicationWorker
Stop the replication worker service.
shutdown(int) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
shutdown(int) - Method in interface org.apache.bookkeeper.bookie.StateManager.ShutdownHandler
 
Shutdown - org.apache.bookkeeper.common.util.SingleThreadExecutor.State
 
shutdownBookies() - Method in class org.apache.bookkeeper.util.LocalBookKeeper
 
shutdownNow() - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
shutdownNow() - Method in class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
shutdownTask - Variable in class org.apache.bookkeeper.replication.AuditorElector
 
shutdownTriggered - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
SIGNATURE - Static variable in class org.apache.bookkeeper.bookie.FileInfo
The fingerprint of a ledger index file.
signSafeMod(long, int) - Static method in class org.apache.bookkeeper.common.util.MathUtils
 
signSafeMod(long, int) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
signSafeMod(long, int) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
signSafeMod(long, int) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
signSafeMod(long, int) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
signSafeMod(long, int) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
signSafeMod(long, int) - Static method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
Simple - org.apache.bookkeeper.common.allocator.LeakDetectionPolicy
Instruments 1% of the allocated buffer to track for leaks.
SimpleBookieServiceInfoProvider - Class in org.apache.bookkeeper.proto
Simple Implementation of BookieServiceInfo supplier.
SimpleBookieServiceInfoProvider(ServerConfiguration) - Constructor for class org.apache.bookkeeper.proto.SimpleBookieServiceInfoProvider
 
SimpleGauge<T extends java.lang.Number> - Class in org.apache.bookkeeper.stats.prometheus
A Gauge implementation that forwards on the value supplier.
SimpleGauge(Gauge<T>, Map<String, String>) - Constructor for class org.apache.bookkeeper.stats.prometheus.SimpleGauge
 
SimpleHashParameters - Class in com.scurrilous.circe.params
Hash parameters consisting only of an algorithm name.
SimpleHashParameters(String) - Constructor for class com.scurrilous.circe.params.SimpleHashParameters
Constructs a SimpleHashParameters with the given algorithm name.
SimpleTestCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.SimpleTestCmd
 
SimpleTestCommand - Class in org.apache.bookkeeper.tools.cli.commands.client
A client command that simply tests if a cluster is healthy.
SimpleTestCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand
 
SimpleTestCommand(SimpleTestCommand.Flags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand
 
SimpleTestCommand.Flags - Class in org.apache.bookkeeper.tools.cli.commands.client
Flags for simple test command.
SinBin(Ticker) - Constructor for class org.apache.bookkeeper.bookie.datainteg.EntryCopierImpl.SinBin
 
since() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The version when this setting was introduced.
since(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
The version when this setting was introduced.
since(String) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The version when this setting was introduced.
SingleDirectoryDbLedgerStorage - Class in org.apache.bookkeeper.bookie.storage.ldb
Single directory implementation of LedgerStorage that uses RocksDB to keep the indexes for entries stored in EntryLogs.
SingleDirectoryDbLedgerStorage(ServerConfiguration, LedgerManager, LedgerDirsManager, LedgerDirsManager, EntryLogger, StatsLogger, ByteBufAllocator, long, long, int, long) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
SingleDirectoryDbLedgerStorage.LedgerLoggerProcessor - Interface in org.apache.bookkeeper.bookie.storage.ldb
Interface which process ledger logger.
SingleFragmentCallback(AsyncCallback.VoidCallback, LedgerHandle, LedgerManager, long, Map<BookieId, BookieId>) - Constructor for class org.apache.bookkeeper.client.LedgerFragmentReplicator.SingleFragmentCallback
 
SingleLedgerEntryRequest(List<BookieId>, long, long) - Constructor for class org.apache.bookkeeper.client.PendingReadOp.SingleLedgerEntryRequest
 
SingleThreadExecutor - Class in org.apache.bookkeeper.common.util
Implements a single thread executor that drains the queue in batches to minimize contention between threads.
SingleThreadExecutor(ThreadFactory) - Constructor for class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
SingleThreadExecutor(ThreadFactory, int, boolean) - Constructor for class org.apache.bookkeeper.common.util.SingleThreadExecutor
 
SingleThreadExecutor.State - Enum in org.apache.bookkeeper.common.util
 
SingleThreadSafeScheduledExecutorService - Class in org.apache.bookkeeper.common.util
 
SingleThreadSafeScheduledExecutorService(ThreadFactory) - Constructor for class org.apache.bookkeeper.common.util.SingleThreadSafeScheduledExecutorService
 
sipHash24() - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the SipHash-2-4 algorithm (64 bits) with the default seed, 00 01 02 03 04 05 06 07 08 09 0A 0B 0C 0D 0E 0F.
sipHash24(long, long) - Static method in class com.scurrilous.circe.CommonHashes
Returns a hash function implementing the SipHash-2-4 algorithm (64 bits) with the given seed value.
SipHash24Parameters - Class in com.scurrilous.circe.params
Hash parameters for SipHash-2-4.
SipHash24Parameters() - Constructor for class com.scurrilous.circe.params.SipHash24Parameters
Constructs a SipHash24Parameters with the default seed, 00 01 02 03 04 05 06 07 08 09 0A 0B 0C 0D 0E 0F.
SipHash24Parameters(long, long) - Constructor for class com.scurrilous.circe.params.SipHash24Parameters
Constructs a SipHash24Parameters with the given seed.
size - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 
size - Variable in class org.apache.bookkeeper.bookie.LedgerCache.LedgerIndexMetadata
 
size() - Method in class org.apache.bookkeeper.bookie.BufferedChannelBase
Get the current size of the underlying FileChannel.
size() - Method in class org.apache.bookkeeper.bookie.BufferedReadChannel
 
size() - Method in interface org.apache.bookkeeper.bookie.EntryLogMetadataMap
Returns number of entryLogMetadata records presents into the map.
size() - Method in class org.apache.bookkeeper.bookie.FileInfo
 
size() - Method in class org.apache.bookkeeper.bookie.InMemoryEntryLogMetadataMap
 
size() - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
 
size() - Method in class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
 
size() - Method in class org.apache.bookkeeper.bookie.storage.ldb.ReadCache
 
size() - Method in class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
size() - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
The number of indexes in the write set.
size() - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
size() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
size() - Method in class org.apache.bookkeeper.meta.LedgerManager.LedgerRange
 
size() - Method in class org.apache.bookkeeper.stats.codahale.FastSnapshot
 
size() - Method in class org.apache.bookkeeper.util.ByteBufList
 
size() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
size() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
size() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
size() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
size() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
size() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
sizeInBytes() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashSet
 
sizeInBytes() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
sizeInBytes() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
SKIP_LIST_CHUNK_SIZE_ENTRY - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SKIP_LIST_FLUSH_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
SKIP_LIST_GET_ENTRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
SKIP_LIST_MAX_ALLOC_ENTRY - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SKIP_LIST_PUT_ENTRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
SKIP_LIST_SIZE_LIMIT - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SKIP_LIST_SNAPSHOT - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
SKIP_LIST_THROTTLING - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
SKIP_LIST_THROTTLING_LATENCY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
SKIP_REPLAY_JOURNAL_INVALID_RECORD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
skipBytes(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
SkipListArena - Class in org.apache.bookkeeper.bookie
SkipList allocation buffer to reduce memory fragment.
SkipListArena(ServerConfiguration) - Constructor for class org.apache.bookkeeper.bookie.SkipListArena
 
SkipListArena.MemorySlice - Class in org.apache.bookkeeper.bookie
The result of a single allocation.
SkipListFlusher - Interface in org.apache.bookkeeper.bookie
Flush entries from skip list.
skipListSemaphore - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 
skipListSizeLimit - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 
skipOpenLedgers(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
skipUnrecoverableLedgers(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.RecoverCommand.RecoverFlags
 
slave - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
slave - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicy
 
Slf4jSlogger - Class in org.apache.bookkeeper.slogger.slf4j
Slf4j implementation of slogger.
Slf4jSlogger() - Constructor for class org.apache.bookkeeper.slogger.slf4j.Slf4jSlogger
 
Slf4jSlogger(Class<?>) - Constructor for class org.apache.bookkeeper.slogger.slf4j.Slf4jSlogger
 
Slf4jSlogger(Class<?>, Iterable<Object>) - Constructor for class org.apache.bookkeeper.slogger.slf4j.Slf4jSlogger
 
slice() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
slice(int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
slog - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
slog - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
Sloggable - Interface in org.apache.bookkeeper.slogger
Interface to be implemented by classes that want more control over how they are added to a structured log.
SloggableAccumulator - Interface in org.apache.bookkeeper.slogger
Interface passed to Sloggable instances, with which they can add their own key/value pairs to the logged event.
Slogger - Interface in org.apache.bookkeeper.slogger
Event logging interface will support for key value pairs and reusable context.
SLOW_MASK - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
slowBookies - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
slowBookies - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
SlowBufferedChannel - Class in org.apache.bookkeeper.bookie
Strictly for testing.
SlowBufferedChannel(ByteBufAllocator, FileChannel, int) - Constructor for class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
SlowBufferedChannel(ByteBufAllocator, FileChannel, int, int) - Constructor for class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
SMALL_ENTRY_SIZE_THRESHOLD - Static variable in class org.apache.bookkeeper.proto.BookieProtoEncoding
Threshold under which an entry is considered to be "small".
snapshot - Variable in class org.apache.bookkeeper.bookie.EntryMemTable
 
snapshot - Variable in class org.apache.bookkeeper.util.SnapshotMap
 
snapshot() - Method in class org.apache.bookkeeper.bookie.EntryMemTable
 
snapshot() - Method in class org.apache.bookkeeper.util.SnapshotMap
Create a snapshot of current map.
snapshot(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.EntryMemTable
Snapshot current EntryMemTable.
SnapshotMap<K,​V> - Class in org.apache.bookkeeper.util
A snapshotable map.
SnapshotMap() - Constructor for class org.apache.bookkeeper.util.SnapshotMap
 
sort() - Method in interface org.apache.bookkeeper.client.DistributionSchedule.WriteSet
Sort the indices.
sort(long[]) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.ArrayGroupSort
 
sort(long[], int, int) - Static method in class org.apache.bookkeeper.bookie.storage.ldb.ArrayGroupSort
 
SORTED_LEDGER_STORAGE_ENABLED - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
SortedLedgerStorage - Class in org.apache.bookkeeper.bookie
A SortedLedgerStorage is an extension of InterleavedLedgerStorage.
SortedLedgerStorage() - Constructor for class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
SortedLedgerStorage(InterleavedLedgerStorage) - Constructor for class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
spec - Variable in class org.apache.bookkeeper.tools.framework.CliCommand
 
SPECULATIVE_READ_COUNT - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
SPECULATIVE_READ_LAC_TIMEOUT_BACKOFF_MULTIPLIER - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
SPECULATIVE_READ_TIMEOUT - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
SPECULATIVE_READ_TIMEOUT_BACKOFF_MULTIPLIER - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
SpeculativeRequestExecutionPolicy - Interface in org.apache.bookkeeper.client
Define a policy for speculative request execution.
SpeculativeRequestExecutor - Interface in org.apache.bookkeeper.client
Define an executor for issuing speculative requests.
speculativeTask - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
splitIntoSubFragments(LedgerHandle, LedgerFragment, long) - Static method in class org.apache.bookkeeper.client.LedgerFragmentReplicator
Split the full fragment into batched entry fragments by keeping rereplicationEntryBatchSize of entries in each one and can treat them as sub fragments.
srcBookie(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags
 
srcLogId - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectCompactionEntryLog
 
Sse42Crc32C - Class in com.scurrilous.circe.crc
Implementation of CRC-32C using the SSE 4.2 CRC instruction.
Sse42Crc32C() - Constructor for class com.scurrilous.circe.crc.Sse42Crc32C
 
Sse42Crc32C(int[]) - Constructor for class com.scurrilous.circe.crc.Sse42Crc32C
 
StabilizeNetworkTopology - Class in org.apache.bookkeeper.net
This is going to provide a stabilize network topology regarding to flapping zookeeper registration.
StabilizeNetworkTopology(HashedWheelTimer, int) - Constructor for class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
StabilizeNetworkTopology.NodeStatus - Class in org.apache.bookkeeper.net
 
stabilizePeriodMillis - Variable in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
stabilizePeriodSeconds - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
stabilizePeriodSeconds - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
StandardCRC32Digest - Class in org.apache.bookkeeper.proto.checksum
Regular implementation of CRC32 digest that makes use of CRC32 class.
StandardCRC32Digest() - Constructor for class org.apache.bookkeeper.proto.checksum.StandardCRC32Digest
 
StandardCrcProvider - Class in com.scurrilous.circe.crc
Provides pure Java and JDK-supplied CRC implementations.
StandardCrcProvider() - Constructor for class com.scurrilous.circe.crc.StandardCrcProvider
Constructs a new StandardCrcProvider.
start() - Method in interface org.apache.bookkeeper.bookie.Bookie
 
start() - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
start() - Method in interface org.apache.bookkeeper.bookie.Checkpointer
 
start() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
start() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
start() - Method in class org.apache.bookkeeper.bookie.Journal
 
start() - Method in class org.apache.bookkeeper.bookie.LedgerDirsMonitor
 
start() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Start any background threads belonging to the storage system.
start() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
start() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
start() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
start() - Method in class org.apache.bookkeeper.bookie.SyncThread
 
start() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.CompactionPhase
 
start() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.FlushCompactionLogPhase
 
start() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.ScanEntryLogPhase
 
start() - Method in class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.UpdateIndexPhase
 
start() - Method in class org.apache.bookkeeper.client.BookieInfoReader
 
start() - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
start() - Method in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
start() - Method in interface org.apache.bookkeeper.common.component.LifecycleComponent
 
start() - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
start() - Method in class org.apache.bookkeeper.meta.LedgerManager.LedgerRange
 
start() - Method in class org.apache.bookkeeper.proto.BookieNettyServer
 
start() - Method in class org.apache.bookkeeper.proto.BookieServer
 
start() - Method in class org.apache.bookkeeper.replication.Auditor
 
start() - Method in class org.apache.bookkeeper.replication.AuditorElector
 
start() - Method in class org.apache.bookkeeper.replication.AutoRecoveryMain
 
start() - Method in class org.apache.bookkeeper.replication.ReplicationWorker
Start the replication worker.
start() - Method in interface org.apache.bookkeeper.shims.zk.ZooKeeperServerShim
Start the zookeeper server.
start() - Method in class org.apache.bookkeeper.shims.zk.ZooKeeperServerShimImpl
 
start() - Method in class org.apache.bookkeeper.util.LocalBookKeeper
 
start(Configuration) - Method in class org.apache.bookkeeper.stats.CachingStatsProvider
 
start(Configuration) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
start(Configuration) - Method in class org.apache.bookkeeper.stats.NullStatsProvider
 
start(Configuration) - Method in class org.apache.bookkeeper.stats.otel.OtelMetricsProvider
 
start(Configuration) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
start(Configuration) - Method in interface org.apache.bookkeeper.stats.StatsProvider
Initialize the stats provider by loading the given configuration conf.
START_OF_DATA - Static variable in class org.apache.bookkeeper.bookie.FileInfo
 
START_TLS - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
START_TLS = 9;
START_TLS - org.apache.bookkeeper.proto.PerChannelBookieClient.ConnectionState
 
START_TLS_TIMEOUT_SECS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
START_TLS_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
START_TLS = 9;
startAudit(boolean) - Method in class org.apache.bookkeeper.replication.AuditorBookieCheckTask
Start running the actual audit task.
startCheckpoint(CheckpointSource.Checkpoint) - Method in interface org.apache.bookkeeper.bookie.Checkpointer
Start checkpointing for a given checkpoint location.
startCheckpoint(CheckpointSource.Checkpoint) - Method in class org.apache.bookkeeper.bookie.SyncThread
 
startComponent(LifecycleComponent) - Static method in class org.apache.bookkeeper.common.component.ComponentStarter
Start a component and register a shutdown hook.
started() - Method in class org.apache.bookkeeper.common.component.Lifecycle
Returns true if the state is started.
STARTED - org.apache.bookkeeper.common.component.Lifecycle.State
 
startEntryId - Variable in class org.apache.bookkeeper.client.ReadOpBase
 
startEntryToRead - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
startPos(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ReadLogCommand.ReadLogFlags
 
startTime - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
startTime - Variable in class org.apache.bookkeeper.client.LedgerDeleteOp
 
startTime - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
startTime - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.TimedGenericCallback
 
startTime - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
startTimeNanos - Variable in class org.apache.bookkeeper.proto.WriteEntryProcessor
 
startTimeNanos - Variable in class org.apache.bookkeeper.zookeeper.ZooWorker
 
startTLSComplete(int, Object) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.StartTLSCallback
 
StartTLSCompletion(PerChannelBookieClient.CompletionKey) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.StartTLSCompletion
 
STARTTLSREQUEST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
STARTTLSRESPONSE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
startTLSTimeout - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
startupFinished() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher
Called by the framework to signal that preparation of startup is done, so we have gathered all of the available information.
state - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
state() - Method in class org.apache.bookkeeper.common.component.Lifecycle
 
STATE_FENCED_BIT - Static variable in class org.apache.bookkeeper.bookie.FileInfo
 
STATE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
STATEFUL - com.scurrilous.circe.HashSupport
Indicates that the hash algorithm is available as a StatefulHash.
StatefulHash - Interface in com.scurrilous.circe
Represents a stateful hash function, which can accumulate input from multiple method calls and provide output in various forms.
StatefulIntHash - Interface in com.scurrilous.circe
Interface implemented by stateful hash functions with an output length of 4 bytes or less.
StatefulLongHash - Interface in com.scurrilous.circe
Interface implemented by stateless hash functions with an output length greater than 4 bytes and less than or equal to 8 bytes.
stateless - Variable in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
stateless - Variable in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
STATELESS_INCREMENTAL - com.scurrilous.circe.HashSupport
Indicates that the hash algorithm is available as a IncrementalIntHash or IncrementalLongHash, depending on which of HashSupport.INT_SIZED or HashSupport.LONG_SIZED is set.
StatelessHash - Interface in com.scurrilous.circe
Base interface for stateless hash functions that immediately return the hash value corresponding to a given input.
StatelessIntHash - Interface in com.scurrilous.circe
Interface implemented by stateless hash functions with an output length of 4 bytes or less.
StatelessLongHash - Interface in com.scurrilous.circe
Interface implemented by stateless hash functions with an output length greater than 4 bytes and less than or equal to 8 bytes.
stateManager - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
StateManager - Interface in org.apache.bookkeeper.bookie
State management of Bookie, including register, turn bookie to w/r mode.
StateManager.ShutdownHandler - Interface in org.apache.bookkeeper.bookie
ShutdownHandler used to shutdown bookie.
stateService - Variable in class org.apache.bookkeeper.bookie.BookieStateManager
 
stats - Variable in class org.apache.bookkeeper.proto.BKStats
 
stats(CompletableFuture<T>, OpStatsLogger, Stopwatch) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
Add a event listener over result for collecting the operation stats.
Stats - Class in org.apache.bookkeeper.stats
An umbrella class for loading stats provider.
Stats() - Constructor for class org.apache.bookkeeper.stats.Stats
 
STATS_ADD - Static variable in class org.apache.bookkeeper.proto.BKStats
 
STATS_PROVIDER_CLASS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
STATS_PROVIDER_CLASS - Static variable in class org.apache.bookkeeper.stats.Stats
 
STATS_READ - Static variable in class org.apache.bookkeeper.proto.BKStats
 
STATS_UNKNOWN - Static variable in class org.apache.bookkeeper.proto.BKStats
 
StatsDoc - Annotation Type in org.apache.bookkeeper.stats.annotations
Documenting the stats.
statsLogger - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
statsLogger - Variable in class org.apache.bookkeeper.bookie.stats.BookieStats
 
statsLogger - Variable in class org.apache.bookkeeper.bookie.stats.GarbageCollectorStats
 
statsLogger - Variable in class org.apache.bookkeeper.client.BookKeeper.Builder
 
statsLogger - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
statsLogger - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
statsLogger - Variable in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
statsLogger - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
statsLogger - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
statsLogger - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.TimedGenericCallback
 
statsLogger - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
statsLogger - Variable in class org.apache.bookkeeper.zookeeper.ZooWorker
 
statsLogger(StatsLogger) - Method in interface org.apache.bookkeeper.client.api.BookKeeperBuilder
Configure the bookkeeper client with a provided StatsLogger.
statsLogger(StatsLogger) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
Configure the bookkeeper client with a provided StatsLogger.
statsLogger(StatsLogger) - Method in class org.apache.bookkeeper.client.impl.BookKeeperBuilderImpl
 
statsLogger(StatsLogger) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
statsLogger(StatsLogger) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
StatsLogger - Interface in org.apache.bookkeeper.stats
A simple interface that exposes just 2 useful methods.
statsLoggers - Variable in class org.apache.bookkeeper.stats.CachingStatsProvider
 
statsProvider - Variable in class org.apache.bookkeeper.server.http.BKHttpServiceProvider.Builder
 
statsProvider(StatsProvider) - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
 
StatsProvider - Interface in org.apache.bookkeeper.stats
Provider to provide stats logger for different scopes.
StatsProviderService - Class in org.apache.bookkeeper.server.service
A LifecycleComponent that runs stats provider.
StatsProviderService(BookieConfiguration) - Constructor for class org.apache.bookkeeper.server.service.StatsProviderService
 
status(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.ToggleCommand.AutoRecoveryFlags
 
status(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.health.SwitchOfHealthCheckCommand.HealthCheckFlags
 
STATUS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
STATUS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
STICKY_READS_ENABLED - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
stop() - Method in class org.apache.bookkeeper.bookie.EntryLoggerAllocator
Stop the allocator.
stop() - Method in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
stop() - Method in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
stop() - Method in interface org.apache.bookkeeper.common.component.LifecycleComponent
 
stop() - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack
 
stop() - Method in interface org.apache.bookkeeper.shims.zk.ZooKeeperServerShim
Stop the zookeeper server.
stop() - Method in class org.apache.bookkeeper.shims.zk.ZooKeeperServerShimImpl
 
stop() - Method in class org.apache.bookkeeper.stats.CachingStatsProvider
 
stop() - Method in class org.apache.bookkeeper.stats.codahale.CodahaleMetricsProvider
 
stop() - Method in class org.apache.bookkeeper.stats.NullStatsProvider
 
stop() - Method in class org.apache.bookkeeper.stats.otel.OtelMetricsProvider
 
stop() - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
stop() - Method in interface org.apache.bookkeeper.stats.StatsProvider
Close the stats provider.
stopExplicitLacFlush() - Method in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
stopExplicitLacFlush() - Method in interface org.apache.bookkeeper.client.ExplicitLacFlushPolicy
 
stopOnExit - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
stopped() - Method in class org.apache.bookkeeper.common.component.Lifecycle
Returns true if the state is stopped.
STOPPED - org.apache.bookkeeper.common.component.Lifecycle.State
 
stoppedOrClosed() - Method in class org.apache.bookkeeper.common.component.Lifecycle
 
STORAGE_GET_ENTRY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
STORAGE_GET_OFFSET - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
STORAGE_SCRUB_PAGE_RETRIES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
STORAGE_SCRUB_PAGES_SCANNED - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
storageDirectoriesFromConf(ServerConfiguration) - Static method in class org.apache.bookkeeper.server.Main
 
STORE_SYSTEMTIME_AS_LEDGER_CREATION_TIME - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
STORE_SYSTEMTIME_AS_LEDGER_UNDERREPLICATED_MARK_TIME - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
storeCtime - Variable in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
storeLedgerLayout(LedgerLayout) - Method in interface org.apache.bookkeeper.meta.LayoutManager
Store the ledger layout.
storeLedgerLayout(LedgerLayout) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLayoutManager
 
storeLedgerLayout(LedgerLayout) - Method in class org.apache.bookkeeper.meta.ZkLayoutManager
Store the ledger layout to zookeeper.
storingCreationTime(boolean) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
StreamUtil - Class in org.apache.bookkeeper.common.util
Java Stream related operations.
StreamUtil() - Constructor for class org.apache.bookkeeper.common.util.StreamUtil
 
STRING - org.apache.bookkeeper.common.conf.Type
 
STRING_FORMATTER - Static variable in class org.apache.bookkeeper.util.EntryFormatter
 
StringEntryFormatter - Class in org.apache.bookkeeper.util
A String-based entry formatter.
StringEntryFormatter() - Constructor for class org.apache.bookkeeper.util.StringEntryFormatter
 
stringToHierarchicalLedgerId(String) - Static method in class org.apache.bookkeeper.util.StringUtils
Parse the hierarchical ledger path to its ledger id.
stringToHierarchicalLedgerId(String...) - Static method in class org.apache.bookkeeper.util.StringUtils
Get ledger id.
stringToLongHierarchicalLedgerId(String) - Static method in class org.apache.bookkeeper.util.StringUtils
Parse the long hierarchical ledger path to its ledger id.
StringUtils - Class in org.apache.bookkeeper.util
Provided utilites for parsing network addresses, ledger-id from node paths etc.
StringUtils() - Constructor for class org.apache.bookkeeper.util.StringUtils
 
submit() - Method in class org.apache.bookkeeper.client.ReadOpBase
 
submit(Runnable) - Method in class org.apache.bookkeeper.common.util.BoundedExecutorService
 
submit(Runnable) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
submit(Runnable) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
submit(Runnable) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
submit(Runnable) - Method in class org.apache.bookkeeper.common.util.SingleThreadSafeScheduledExecutorService
 
submit(Runnable, T) - Method in class org.apache.bookkeeper.common.util.BoundedExecutorService
 
submit(Runnable, T) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
submit(Runnable, T) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
submit(Runnable, T) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
submit(Callable<T>) - Method in class org.apache.bookkeeper.common.util.BoundedExecutorService
 
submit(Callable<T>) - Method in class org.apache.bookkeeper.common.util.BoundedScheduledExecutorService
 
submit(Callable<T>) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
submit(Callable<T>) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler.OrderedSchedulerDecoratedThread
 
submitAuditTask() - Method in class org.apache.bookkeeper.replication.Auditor
 
submitBookieCheckTask() - Method in class org.apache.bookkeeper.replication.Auditor
 
submitCallback(int) - Method in class org.apache.bookkeeper.client.BatchedReadOp
 
submitCallback(int) - Method in class org.apache.bookkeeper.client.ListenerBasedPendingReadOp
 
submitCallback(int) - Method in class org.apache.bookkeeper.client.PendingAddOp
 
submitCallback(int) - Method in class org.apache.bookkeeper.client.PendingReadOp
 
submitCallback(int) - Method in class org.apache.bookkeeper.client.ReadOpBase
 
submitElectionTask() - Method in class org.apache.bookkeeper.replication.AuditorElector
Performing the auditor election using the ZooKeeper ephemeral sequential znode.
submitLostBookieRecoveryDelayChangedEvent() - Method in class org.apache.bookkeeper.replication.Auditor
 
submitOrdered(long, Callable<T>) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
submitOrdered(Object, Callable<T>) - Method in class org.apache.bookkeeper.common.util.OrderedScheduler
schedules a one time action to execute with an ordering guarantee on the key.
submitShutdownTask() - Method in interface org.apache.bookkeeper.replication.AuditorTask.ShutdownTaskHandler
 
submitShutdownTask() - Method in class org.apache.bookkeeper.replication.AuditorTask
 
subset(String) - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
subset(Set<Integer>) - Method in class org.apache.bookkeeper.client.LedgerFragment
Return a ledger fragment contains subset of bookies.
SubTreeCache - Class in org.apache.bookkeeper.util
Caching layer for traversing and monitoring changes on a znode subtree.
SubTreeCache(SubTreeCache.TreeProvider) - Constructor for class org.apache.bookkeeper.util.SubTreeCache
 
SubTreeCache.TreeProvider - Interface in org.apache.bookkeeper.util
A tree provider.
SubTreeCache.WatchGuard - Class in org.apache.bookkeeper.util
A watch guard.
success - Variable in class org.apache.bookkeeper.stats.codahale.CodahaleOpStatsLogger
 
successRc - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.MultiCallback
 
successRc - Variable in class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.TimedGenericCallback
 
suggestedDigestType - Variable in class org.apache.bookkeeper.client.LedgerOpenOp
 
supportReuseFile() - Method in interface org.apache.bookkeeper.bookie.FileChannelProvider
Whether support reuse file.
supportsIncremental() - Method in class com.scurrilous.circe.crc.JavaCrc32
 
supportsIncremental() - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
supportsIncremental() - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
supportsIncremental() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
supportsIncremental() - Method in interface com.scurrilous.circe.StatefulHash
Returns whether this hash function supports incremental hashing.
supportsUnsafe() - Method in class com.scurrilous.circe.crc.Sse42Crc32C
 
supportsUnsafe() - Method in interface com.scurrilous.circe.Hash
Returns whether this hash function supports unsafe access to arbitrary memory addresses using methods such as StatefulHash.update(long, long), StatelessIntHash.calculate(long, long), or IncrementalIntHash.resume(int, long, long).
supportsUnsafe() - Method in class com.scurrilous.circe.impl.AbstractIncrementalIntHash
 
supportsUnsafe() - Method in class com.scurrilous.circe.impl.AbstractIncrementalLongHash
 
supportsUnsafe() - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
 
supportsUnsafe() - Method in class com.scurrilous.circe.impl.AbstractStatelessIntHash
 
supportsUnsafe() - Method in class com.scurrilous.circe.impl.AbstractStatelessLongHash
 
supportsUnsafe() - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
supportsUnsafe() - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
supportsUnsafe() - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
supportsUnsafe() - Method in class com.scurrilous.circe.impl.IntStatelessLongHash
 
SuspendCompactionService - Class in org.apache.bookkeeper.server.http.service
 
SuspendCompactionService(BookieServer) - Constructor for class org.apache.bookkeeper.server.http.service.SuspendCompactionService
 
suspended - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
suspendMajorCompaction - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
suspendMajorGC() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
suspendMajorGC() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
suspendMajorGC() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
suspendMajorGC() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
suspendMajorGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
suspendMajorGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
suspendMinorCompaction - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
suspendMinorGC() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
suspendMinorGC() - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
suspendMinorGC() - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
 
suspendMinorGC() - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
suspendMinorGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
suspendMinorGC() - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
suspendProcessing() - Method in class org.apache.bookkeeper.proto.BookieNettyServer
 
suspendProcessing() - Method in class org.apache.bookkeeper.proto.BookieServer
Suspend processing of requests in the bookie (for testing).
suspendSync() - Method in class org.apache.bookkeeper.bookie.SyncThread
Suspend sync thread.
suspensionLock - Variable in class org.apache.bookkeeper.proto.BookieNettyServer
 
swap(Node[], int, int) - Static method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Swap two array items.
SwitchOfHealthCheckCommand - Class in org.apache.bookkeeper.tools.cli.commands.health
Command to enable or disable health check in the cluster.
SwitchOfHealthCheckCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.health.SwitchOfHealthCheckCommand
 
SwitchOfHealthCheckCommand.HealthCheckFlags - Class in org.apache.bookkeeper.tools.cli.commands.health
Flags for health check command.
sync() - Method in interface org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorage
Commit all pending write to durable storage.
sync() - Method in class org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageRocksDB
 
sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
SyncAddCallback() - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.SyncAddCallback
 
SyncCallbackUtils - Class in org.apache.bookkeeper.client
Utility for callbacks.
SyncCallbackUtils() - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils
 
SyncCallbackUtils.FutureReadLastConfirmed - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.FutureReadLastConfirmedAndEntry - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.LastAddConfirmedCallback - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.SyncAddCallback - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.SyncCloseCallback - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.SyncCreateAdvCallback - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.SyncCreateCallback - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.SyncDeleteCallback - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.SyncOpenCallback - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.SyncReadCallback - Class in org.apache.bookkeeper.client
 
SyncCallbackUtils.SyncReadLastConfirmedCallback - Class in org.apache.bookkeeper.client
 
syncCallWithRetries(ZooKeeperClient, ZooWorker.ZooCallable<T>, RetryPolicy, RateLimiter, OpStatsLogger) - Static method in class org.apache.bookkeeper.zookeeper.ZooWorker
Execute a sync zookeeper operation with a given retry policy.
SyncCloseCallback(CompletableFuture<Void>) - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.SyncCloseCallback
 
SyncCounter - Class in org.apache.bookkeeper.client
Implements objects to help with the synchronization of asynchronous calls.
SyncCounter() - Constructor for class org.apache.bookkeeper.client.SyncCounter
 
SyncCreateAdvCallback(CompletableFuture<? super LedgerHandleAdv>) - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.SyncCreateAdvCallback
 
SyncCreateCallback(CompletableFuture<? super LedgerHandle>) - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.SyncCreateCallback
 
SyncDeleteCallback(CompletableFuture<Void>) - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.SyncDeleteCallback
 
SynchronizedHashMultiMap<K,​V> - Class in org.apache.bookkeeper.util.collections
Simple multimap implementation that only stores key reference once.
SynchronizedHashMultiMap() - Constructor for class org.apache.bookkeeper.util.collections.SynchronizedHashMultiMap
 
SyncMetastoreCallback() - Constructor for class org.apache.bookkeeper.metastore.MetastoreUtils.SyncMetastoreCallback
 
SyncObject() - Constructor for class org.apache.bookkeeper.client.BookKeeperAdmin.SyncObject
 
SyncOpenCallback(CompletableFuture<? super LedgerHandle>) - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.SyncOpenCallback
 
SyncReadCallback(CompletableFuture<Enumeration<LedgerEntry>>) - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.SyncReadCallback
 
SyncReadLastConfirmedCallback() - Constructor for class org.apache.bookkeeper.client.SyncCallbackUtils.SyncReadLastConfirmedCallback
 
SyncResult() - Constructor for class org.apache.bookkeeper.meta.MSLedgerManagerFactory.SyncResult
Deprecated.
 
syncThread - Variable in class org.apache.bookkeeper.bookie.BookieImpl
 
SyncThread - Class in org.apache.bookkeeper.bookie
SyncThread is a background thread which help checkpointing ledger storage when a checkpoint is requested.
SyncThread(ServerConfiguration, LedgerDirsManager.LedgerDirsListener, LedgerStorage, CheckpointSource, StatsLogger) - Constructor for class org.apache.bookkeeper.bookie.SyncThread
 

T

TABLE_NAME - Static variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
tables - Static variable in class org.apache.bookkeeper.metastore.InMemoryMetaStore
 
tailer() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
take() - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
take() - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
take() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
takeAll(T[]) - Method in class org.apache.bookkeeper.common.collections.BatchedArrayBlockingQueue
 
takeAll(T[]) - Method in interface org.apache.bookkeeper.common.collections.BatchedBlockingQueue
Drain the queue into an array.
takeAll(T[]) - Method in class org.apache.bookkeeper.common.collections.BlockingMpscQueue
 
TASK_EXECUTION_WARN_TIME_MICROS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
taskExecutionStats - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
taskPendingStats - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
tentativeToRemove - Variable in class org.apache.bookkeeper.net.StabilizeNetworkTopology.NodeStatus
 
Terminated - org.apache.bookkeeper.common.util.SingleThreadExecutor.State
 
test(long, long) - Method in interface org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap.LongLongPredicate
 
test(long, long, long, long) - Method in interface org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap.LongLongPairPredicate
 
test(long, V) - Method in interface org.apache.bookkeeper.util.collections.ConcurrentLongHashMap.LongObjectPredicate
 
TGTRefreshThread - Class in org.apache.bookkeeper.sasl
TGT Refresh Thread.
TGTRefreshThread(JAASCredentialsContainer) - Constructor for class org.apache.bookkeeper.sasl.TGTRefreshThread
 
that - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.ZkRetryRunnable
 
THREAD_RUNTIME - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
threadFactory - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
threadFactory(ThreadFactory) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
threadId - Variable in class org.apache.bookkeeper.stats.ThreadRegistry.ThreadPoolThread
 
threadIds - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
threadPool - Variable in class org.apache.bookkeeper.stats.ThreadRegistry.ThreadPoolThread
 
ThreadPoolThread(String, int, long) - Constructor for class org.apache.bookkeeper.stats.ThreadRegistry.ThreadPoolThread
 
ThreadRegistry - Class in org.apache.bookkeeper.stats
For mapping thread ids to thread pools and threads within those pools or just for lone named threads.
ThreadRegistry() - Constructor for class org.apache.bookkeeper.stats.ThreadRegistry
 
ThreadRegistry.ThreadPoolThread - Class in org.apache.bookkeeper.stats
Stores the thread pool and ordinal.
threads - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
threadScopedCounters - Variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
ThreadScopedDataSketchesStatsLogger - Class in org.apache.bookkeeper.stats.prometheus
OpStatsLogger implementation that lazily registers OpStatsLoggers per thread with added labels for the threadpool/thresd name and thread no.
ThreadScopedDataSketchesStatsLogger(PrometheusMetricsProvider, ScopeContext, Map<String, String>) - Constructor for class org.apache.bookkeeper.stats.prometheus.ThreadScopedDataSketchesStatsLogger
 
ThreadScopedLongAdderCounter - Class in org.apache.bookkeeper.stats.prometheus
Counter implementation that lazily registers LongAdderCounters per thread * with added labels for the threadpool/thread name and thread no.
ThreadScopedLongAdderCounter(PrometheusMetricsProvider, ScopeContext, Map<String, String>) - Constructor for class org.apache.bookkeeper.stats.prometheus.ThreadScopedLongAdderCounter
 
threadScopedOpStats - Variable in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
THROTTLE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
throttler - Variable in class org.apache.bookkeeper.bookie.AbstractLogCompactor
 
throttler - Variable in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
throttler - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
Throttler(int) - Constructor for class org.apache.bookkeeper.client.LedgerFragmentReplicator.Throttler
 
Throttler(ServerConfiguration) - Constructor for class org.apache.bookkeeper.bookie.AbstractLogCompactor.Throttler
 
throttleReadResponses - Variable in class org.apache.bookkeeper.proto.ReadEntryProcessor
 
throttleValue - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
ThrowException - org.apache.bookkeeper.common.allocator.OutOfMemoryPolicy
Throw regular OOM exception without taking addition actions.
throwIfClosed() - Method in class org.apache.bookkeeper.bookie.storage.ldb.PersistentEntryLogMetadataMap
 
timedCallable(Callable<T>) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
TimedCallable(Callable<T>) - Constructor for class org.apache.bookkeeper.common.util.OrderedExecutor.TimedCallable
 
timedCallables(Collection<? extends Callable<T>>) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
TimedGenericCallback(BookkeeperInternalCallbacks.GenericCallback<T>, int, OpStatsLogger) - Constructor for class org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.TimedGenericCallback
 
timedRunnable(Runnable) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor
 
TimedRunnable(Runnable) - Constructor for class org.apache.bookkeeper.common.util.OrderedExecutor.TimedRunnable
 
timeout() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.CompletionValue
 
timeout(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.SanityTestCommand.SanityFlags
 
timeout(long) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.ListActiveLedgersCommand.ActiveLedgerFlags
 
TIMEOUT_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
TIMEOUT_GET_BOOKIE_INFO - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
TIMEOUT_GET_LIST_OF_ENTRIES_OF_LEDGER - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
TIMEOUT_MONITOR_INTERVAL_SEC - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
TIMEOUT_TASK_INTERVAL_MILLIS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
TIMEOUT_TIMER_NUM_TICKS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
TIMEOUT_TIMER_TICK_DURATION_MS - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
TimeoutException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Operations timeouts.
timeoutFuture - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
timeOutInterval - Variable in class org.apache.bookkeeper.util.Shell
 
timeoutMonitorIntervalSec - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
timeoutQuorumWait() - Method in class org.apache.bookkeeper.client.PendingAddOp
 
timer - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
timer - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
timer - Variable in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
TLS_CERT_FILES_REFRESH_DURATION_SECONDS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLS_CERTIFICATE_PATH - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLS_CLIENT_AUTHENTICATION - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLS_ENABLED_CIPHER_SUITES - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
This list will be passed to SSLEngine.setEnabledCipherSuites(java.lang.String[]).
TLS_ENABLED_PROTOCOLS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
This list will be passed to SSLEngine.setEnabledProtocols(java.lang.String[]).
TLS_HOSTNAME_VERIFICATION_ENABLED - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
TLS_KEYSTORE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLS_KEYSTORE_PASSWORD_PATH - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLS_KEYSTORE_TYPE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
TLS KeyStore, TrustStore, Password files and Certificate Paths.
TLS_PROVIDER - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLS_PROVIDER_FACTORY_CLASS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLS_TRUSTSTORE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLS_TRUSTSTORE_PASSWORD_PATH - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLS_TRUSTSTORE_TYPE - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
TLSContextFactory - Class in org.apache.bookkeeper.tls
A factory to manage TLS contexts.
TLSContextFactory() - Constructor for class org.apache.bookkeeper.tls.TLSContextFactory
 
TLSContextFactory.KeyStoreType - Enum in org.apache.bookkeeper.tls
Supported Key File Types.
tlsEnabled - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseDecoder
 
to - Variable in class org.apache.bookkeeper.client.ReadOpBase.ReadContext
 
toApiDigestType() - Method in enum org.apache.bookkeeper.client.BookKeeper.DigestType
 
toArray() - Method in class org.apache.bookkeeper.util.ByteBufList
Creates a copy of the readable content of the internal buffers and returns the copy.
toBackoffs() - Method in class org.apache.bookkeeper.common.util.Backoff.Constant
 
toBackoffs() - Method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
toBackoffs() - Method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
toBackoffs() - Method in interface org.apache.bookkeeper.common.util.Backoff.Policy
Convert the policy into a series of backoff values.
toBookieId() - Method in class org.apache.bookkeeper.net.BookieSocketAddress
Create a BookieID in legacy format hostname:port.
toBuilder() - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
toBuilder() - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
toBuilder() - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
ToggleCommand - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Command to enable or disable auto recovery in the cluster.
ToggleCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.ToggleCommand
 
ToggleCommand.AutoRecoveryFlags - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Flags for auto recovery command.
toInt(byte, byte, short) - Static method in class org.apache.bookkeeper.proto.BookieProtocol.PacketHeader
 
toIterable() - Method in interface org.apache.bookkeeper.client.api.ListLedgersResult
Creates a Iterable, which wraps a LedgersIterator.
toJson(Object) - Static method in class org.apache.bookkeeper.common.util.JsonUtil
 
toList() - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy.Ensemble
 
toList() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.EnsembleForReplacementWithNoConstraints
 
toList() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
Tool - Interface in org.apache.bookkeeper.util
A tool interface that supports handling of generic command-line options.
TooManyRequestsException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Operations failed due to too many requests in the queue.
toOpStatData() - Method in class org.apache.bookkeeper.proto.BKStats.OpStats
 
toOpStatsData() - Method in class org.apache.bookkeeper.stats.codahale.CodahaleOpStatsLogger
This function should go away soon (hopefully).
toOpStatsData() - Method in class org.apache.bookkeeper.stats.NullStatsLogger.NullOpStatsLogger
 
toOpStatsData() - Method in interface org.apache.bookkeeper.stats.OpStatsLogger
 
toOpStatsData() - Method in class org.apache.bookkeeper.stats.otel.OtelOpStatsLogger
 
toOpStatsData() - Method in class org.apache.bookkeeper.stats.prometheus.DataSketchesOpStatsLogger
 
toOpStatsData() - Method in class org.apache.bookkeeper.stats.prometheus.ThreadScopedDataSketchesStatsLogger
 
topology - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
TopologyAwareEnsemblePlacementPolicy - Class in org.apache.bookkeeper.client
 
TopologyAwareEnsemblePlacementPolicy() - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
TopologyAwareEnsemblePlacementPolicy.DefaultResolver - Class in org.apache.bookkeeper.client
 
TopologyAwareEnsemblePlacementPolicy.DNSResolverDecorator - Class in org.apache.bookkeeper.client
Decorator for any existing dsn resolver.
TopologyAwareEnsemblePlacementPolicy.EnsembleForReplacementWithNoConstraints - Class in org.apache.bookkeeper.client
 
TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble - Class in org.apache.bookkeeper.client
A predicate checking the rack coverage for write quorum in RoundRobinDistributionSchedule, which ensures that a write quorum should be covered by at least two racks.
TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.CoverageSet - Interface in org.apache.bookkeeper.client
 
TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackOrRegionDurabilityCoverageSet - Class in org.apache.bookkeeper.client
 
TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble.RackQuorumCoverageSet - Class in org.apache.bookkeeper.client
 
TopologyAwareEnsemblePlacementPolicy.TruePredicate - Class in org.apache.bookkeeper.client
 
toProtoDigestType(BookKeeper.DigestType) - Static method in enum org.apache.bookkeeper.client.BookKeeper.DigestType
 
toSafeString() - Method in interface org.apache.bookkeeper.client.api.LedgerMetadata
Similar to #toString(), but omits the password of the ledger, so that it is safe to log the output.
toSafeString() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
Returns a string representation of this LedgerMetadata object by filtering out the password field.
toSafeString(BookkeeperProtocol.Request) - Static method in class org.apache.bookkeeper.proto.RequestUtils
this toSafeString method filters out body and masterKey from the output.
toSend - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
toSend - Variable in class org.apache.bookkeeper.client.PendingWriteLacOp
 
toString() - Method in class com.scurrilous.circe.params.SimpleHashParameters
 
toString() - Method in class org.apache.bookkeeper.auth.BookKeeperPrincipal
 
toString() - Method in class org.apache.bookkeeper.bookie.BookieStatus
 
toString() - Method in class org.apache.bookkeeper.bookie.Cookie
 
toString() - Method in class org.apache.bookkeeper.bookie.DefaultEntryLogger.BufferedLogChannel
 
toString() - Method in class org.apache.bookkeeper.bookie.EntryKeyValue
String representation.
toString() - Method in class org.apache.bookkeeper.bookie.EntryLocation
 
toString() - Method in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
toString() - Method in class org.apache.bookkeeper.bookie.FileInfoBackingCache.CachedFileInfo
 
toString() - Method in class org.apache.bookkeeper.bookie.GarbageCollectionStatus.GarbageCollectionStatusBuilder
 
toString() - Method in class org.apache.bookkeeper.bookie.Journal.LastLogMark
 
toString() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
toString() - Method in class org.apache.bookkeeper.bookie.LogMark
 
toString() - Method in class org.apache.bookkeeper.bookie.SkipListArena.MemorySlice
 
toString() - Method in class org.apache.bookkeeper.client.BatchedReadOp.BatchedLedgerEntryRequest
 
toString() - Method in class org.apache.bookkeeper.client.BookieInfoReader.BookieInfo
 
toString() - Method in class org.apache.bookkeeper.client.LedgerDeleteOp
 
toString() - Method in class org.apache.bookkeeper.client.LedgerFragment
 
toString() - Method in class org.apache.bookkeeper.client.LedgerMetadataImpl
 
toString() - Method in class org.apache.bookkeeper.client.PendingAddOp
 
toString() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
toString() - Method in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp
 
toString() - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle.MetadataUpdater
 
toString() - Method in class org.apache.bookkeeper.client.ReadOnlyLedgerHandle
 
toString() - Method in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
toString() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
toString() - Method in class org.apache.bookkeeper.common.collections.GrowableMpScArrayConsumerBlockingQueue
 
toString() - Method in class org.apache.bookkeeper.common.component.ComponentInfoPublisher.EndpointInfo
 
toString() - Method in class org.apache.bookkeeper.common.component.Lifecycle
 
toString() - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
 
toString() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
 
toString() - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup.ConfigKeyGroupBuilder
 
toString() - Method in class org.apache.bookkeeper.common.conf.ConfigKeyGroup
 
toString() - Method in class org.apache.bookkeeper.common.conf.validators.ClassValidator
 
toString() - Method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
 
toString() - Method in class org.apache.bookkeeper.common.util.Backoff.Constant
 
toString() - Method in class org.apache.bookkeeper.common.util.Backoff.Exponential
 
toString() - Method in class org.apache.bookkeeper.common.util.Backoff.Jitter
 
toString() - Method in class org.apache.bookkeeper.common.util.ExceptionMessageHelper
 
toString() - Method in class org.apache.bookkeeper.common.util.LogExceptionRunnable
 
toString() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo.Endpoint
 
toString() - Method in class org.apache.bookkeeper.discover.BookieServiceInfo
 
toString() - Method in class org.apache.bookkeeper.meta.LedgerLayout
 
toString() - Method in class org.apache.bookkeeper.meta.MetadataDrivers.MetadataBookieDriverInfo
 
toString() - Method in class org.apache.bookkeeper.meta.MetadataDrivers.MetadataClientDriverInfo
 
toString() - Method in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.MetadataVersion
 
toString() - Method in class org.apache.bookkeeper.metastore.Value
 
toString() - Method in class org.apache.bookkeeper.net.BookieId
Returns the serialized version of this object.
toString() - Method in class org.apache.bookkeeper.net.BookieNode
 
toString() - Method in class org.apache.bookkeeper.net.BookieSocketAddress
 
toString() - Method in class org.apache.bookkeeper.net.CachedDNSToSwitchMapping
 
toString() - Method in class org.apache.bookkeeper.net.NetworkTopologyImpl
Convert a network tree to a string.
toString() - Method in class org.apache.bookkeeper.net.NodeBase
 
toString() - Method in class org.apache.bookkeeper.net.ScriptBasedMapping
 
toString() - Method in class org.apache.bookkeeper.proto.BatchedReadEntryProcessor
 
toString() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Request
 
toString() - Method in class org.apache.bookkeeper.proto.BookieProtocol.Response
 
toString() - Method in class org.apache.bookkeeper.proto.BookieServer
 
toString() - Method in class org.apache.bookkeeper.proto.ForceLedgerProcessorV3
this toString method filters out body and masterKey from the output.
toString() - Method in class org.apache.bookkeeper.proto.PacketProcessorBaseV3
 
toString() - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.TxnCompletionKey
 
toString() - Method in class org.apache.bookkeeper.proto.ReadEntryProcessor
 
toString() - Method in class org.apache.bookkeeper.proto.ReadEntryProcessorV3
this toString method filters out masterKey from the output.
toString() - Method in class org.apache.bookkeeper.proto.WriteEntryProcessor
 
toString() - Method in class org.apache.bookkeeper.proto.WriteEntryProcessorV3
this toString method filters out body and masterKey from the output.
toString() - Method in class org.apache.bookkeeper.proto.WriteLacProcessorV3
this toString method filters out body and masterKey from the output.
toString() - Method in class org.apache.bookkeeper.replication.AuditorElector
 
toString() - Method in class org.apache.bookkeeper.server.http.service.BookieInfoService.BookieInfo
 
toString() - Method in class org.apache.bookkeeper.server.http.service.BookieSanityService.BookieSanity
 
toString() - Method in class org.apache.bookkeeper.server.http.service.BookieStateReadOnlyService.ReadOnlyState
 
toString() - Method in class org.apache.bookkeeper.server.http.service.BookieStateService.BookieState
 
toString() - Method in class org.apache.bookkeeper.server.http.service.ClusterInfoService.ClusterInfo
 
toString() - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
 
toString() - Method in class org.apache.bookkeeper.stats.otel.ScopeContext
 
toString() - Method in enum org.apache.bookkeeper.tls.TLSContextFactory.KeyStoreType
 
toString() - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.ClusterInfoCommand.ClusterInfo
 
toString() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
toString() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
toString() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
toString() - Method in class org.apache.bookkeeper.util.Shell.ShellCommandExecutor
Returns the commands of this instance.
toString() - Method in class org.apache.bookkeeper.versioning.LongVersion
 
toString() - Method in class org.apache.bookkeeper.versioning.Versioned
 
toString() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
toString(int, int, Charset) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
toString(Charset) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
total - Variable in class org.apache.bookkeeper.client.SyncCounter
 
total() - Method in class org.apache.bookkeeper.client.SyncCounter
 
TOTAL_DISK_CAPACITY - org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
TOTAL_DISK_CAPACITY = 1;
TOTAL_DISK_CAPACITY_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
TOTAL_DISK_CAPACITY = 1;
TOTALDISKCAPACITY_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
totalLatency - Variable in class org.apache.bookkeeper.proto.BKStats.OpStats
 
totalSize - Variable in class org.apache.bookkeeper.bookie.EntryLogMetadata
 
touch() - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
touch() - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
touch() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
touch(Object) - Method in class org.apache.bookkeeper.proto.BookieProtocol.BatchedReadResponse
 
touch(Object) - Method in class org.apache.bookkeeper.proto.BookieProtocol.ReadResponse
 
touch(Object) - Method in class org.apache.bookkeeper.util.ByteBufList
 
touch(Object) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
traceTaskExecution - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
traceTaskExecution - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
traceTaskExecution(boolean) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
traceTaskWarnTimeMicroSec(long) - Method in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
trackAddRequest() - Method in class org.apache.bookkeeper.proto.RequestStats
 
trackReadRequest() - Method in class org.apache.bookkeeper.proto.RequestStats
 
transaction() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
Deprecated.
TransactionalEntryLogCompactor - Class in org.apache.bookkeeper.bookie
This class is used for compaction.
TransactionalEntryLogCompactor(ServerConfiguration, EntryLogger, CompactableLedgerStorage, AbstractLogCompactor.LogRemovalListener) - Constructor for class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor
 
TransactionalEntryLogCompactor.CompactionPhase - Class in org.apache.bookkeeper.bookie
An abstract class that would be extended to be the actual transactional phases for compaction.
TransactionalEntryLogCompactor.FlushCompactionLogPhase - Class in org.apache.bookkeeper.bookie
Assume we're compacting log 1 to log 3.
TransactionalEntryLogCompactor.ScanEntryLogPhase - Class in org.apache.bookkeeper.bookie
Assume we're compacting entry log 1 to entry log 3.
TransactionalEntryLogCompactor.UpdateIndexPhase - Class in org.apache.bookkeeper.bookie
Assume we're compacting log 1 to log 3.
transactionIdGenerator - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
transform(LedgerMetadata) - Method in interface org.apache.bookkeeper.client.MetadataUpdateLoop.MetadataTransform
 
TransientLedgerInfo - Class in org.apache.bookkeeper.bookie.storage.ldb
This class borrows the logic from FileInfo.
TransientLedgerInfo(long, LedgerMetadataIndex) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
Construct an Watchable with zero watchers.
transitionToReadOnlyMode() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
transitionToReadOnlyMode() - Method in interface org.apache.bookkeeper.bookie.StateManager
Change the state of bookie to ReadOnly mode.
transitionToWritableMode() - Method in class org.apache.bookkeeper.bookie.BookieStateManager
 
transitionToWritableMode() - Method in interface org.apache.bookkeeper.bookie.StateManager
Change the state of bookie to Writable mode.
triggerAudit() - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Trigger AuditTask by resetting lostBookieRecoveryDelay to its current value.
TriggerAuditCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.TriggerAuditCmd
 
TriggerAuditCommand - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Command to trigger AuditTask by resetting lostBookieRecoveryDelay to its current value.
TriggerAuditCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.TriggerAuditCommand
 
TriggerAuditService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper trigger audit related http request.
TriggerAuditService(ServerConfiguration, BookKeeperAdmin) - Constructor for class org.apache.bookkeeper.server.http.service.TriggerAuditService
 
triggerBookieShutdown(int) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
triggerGC() - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
triggerGC(boolean, boolean, boolean) - Method in class org.apache.bookkeeper.bookie.GarbageCollectorThread
 
TriggerGCService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle force trigger GC requests.
TriggerGCService(ServerConfiguration, BookieServer) - Constructor for class org.apache.bookkeeper.server.http.service.TriggerGCService
 
TriggerLocationCompactService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle force trigger entry location compact requests.
TriggerLocationCompactService(BookieServer) - Constructor for class org.apache.bookkeeper.server.http.service.TriggerLocationCompactService
 
TruePredicate() - Constructor for class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.TruePredicate
 
tryAcquire(int, long, TimeUnit) - Method in class org.apache.bookkeeper.bookie.AbstractLogCompactor.Throttler
 
tryReadLastAddConfirmed() - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Obtains asynchronously the last confirmed write from a quorum of bookies but it doesn't wait all the responses from the quorum.
tryReadLastAddConfirmedAsync() - Method in interface org.apache.bookkeeper.client.api.ReadHandle
Obtains asynchronously the last confirmed write from a quorum of bookies but it doesn't wait all the responses from the quorum.
tryReadLastAddConfirmedAsync() - Method in class org.apache.bookkeeper.client.LedgerHandle
Obtains asynchronously the last confirmed write from a quorum of bookies but it doesn't wait all the responses from the quorum.
tryReadLastConfirmed() - Method in class org.apache.bookkeeper.client.LedgerHandle
Obtains synchronously the last confirmed write from a quorum of bookies.
TryReadLastConfirmedOp - Class in org.apache.bookkeeper.client
This op is try to read last confirmed without involving quorum coverage checking.
TryReadLastConfirmedOp(LedgerHandle, BookieClient, List<BookieId>, ReadLastConfirmedOp.LastConfirmedDataCallback, long) - Constructor for class org.apache.bookkeeper.client.TryReadLastConfirmedOp
 
tryReserveMemory(long) - Method in class org.apache.bookkeeper.common.util.MemoryLimitController
 
tryRetain() - Method in class org.apache.bookkeeper.bookie.FileInfoBackingCache.CachedFileInfo
Attempt to retain the file info.
tryToBecomeAuditor(String, Consumer<LedgerAuditorManager.AuditorEvent>) - Method in interface org.apache.bookkeeper.meta.LedgerAuditorManager
Try to become the auditor.
tryToBecomeAuditor(String, Consumer<LedgerAuditorManager.AuditorEvent>) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerAuditorManager
 
tryToBecomeAuditor(String, Consumer<LedgerAuditorManager.AuditorEvent>) - Method in class org.apache.bookkeeper.meta.ZkLedgerAuditorManager
 
two(StatsLogger, StatsLogger) - Static method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger
Create a broadcast stats logger of two stats loggers `first` and `second`.
TxnCompletionKey(long, BookkeeperProtocol.OperationType) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.TxnCompletionKey
 
txnId - Variable in class org.apache.bookkeeper.proto.PerChannelBookieClient.TxnCompletionKey
 
TXNID_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
type - Variable in class org.apache.bookkeeper.metastore.MSWatchedEvent
 
type() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Type of the configuration setting.
type(Type) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
Type of the configuration setting.
type(Type) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Type of the configuration setting.
Type - Enum in org.apache.bookkeeper.common.conf
Config key types.
TYPE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 

U

unableToReadEntriesForReplication - Variable in class org.apache.bookkeeper.replication.ReplicationWorker
 
UNASSIGNED_CTIME - Static variable in class org.apache.bookkeeper.meta.UnderreplicatedLedger
 
UNASSIGNED_LEDGERID - Static variable in interface org.apache.bookkeeper.bookie.storage.EntryLogger
 
UnauthorizedAccessException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
UnauthorizedAccessException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Operations failed due to unauthorized.
UNAVAIL_MASK - Static variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
UnavailableException(String) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException.UnavailableException
 
UnavailableException(String, Throwable) - Constructor for exception org.apache.bookkeeper.replication.ReplicationException.UnavailableException
 
unblockAddRequest(long) - Method in class org.apache.bookkeeper.proto.RequestStats
 
unblockReadRequest(long) - Method in class org.apache.bookkeeper.proto.RequestStats
 
uncaughtException(Thread, Throwable) - Method in class org.apache.bookkeeper.bookie.BookieThread
 
uncaughtExceptionHandler - Variable in class org.apache.bookkeeper.common.component.AbstractLifecycleComponent
 
uncaughtExceptionHandler - Variable in class org.apache.bookkeeper.common.component.AutoCloseableLifecycleComponent
 
UncheckedConfigurationException - Exception in org.apache.bookkeeper.conf
Wraps a ConfigurationException with an unchecked exception.
UncheckedConfigurationException(String, ConfigurationException) - Constructor for exception org.apache.bookkeeper.conf.UncheckedConfigurationException
Constructs an instance of this class.
UncheckedConfigurationException(ConfigurationException) - Constructor for exception org.apache.bookkeeper.conf.UncheckedConfigurationException
Constructs an instance of this class.
uncleanShutdownDetection - Variable in class org.apache.bookkeeper.proto.BookieServer
 
uncleanShutdownDetection(UncleanShutdownDetection) - Method in class org.apache.bookkeeper.server.EmbeddedServer.Builder
 
UncleanShutdownDetection - Interface in org.apache.bookkeeper.bookie
An interface for unclean shutdown detection.
UncleanShutdownDetectionImpl - Class in org.apache.bookkeeper.bookie
Used to determine if the prior shutdown was unclean or not.
UncleanShutdownDetectionImpl(LedgerDirsManager) - Constructor for class org.apache.bookkeeper.bookie.UncleanShutdownDetectionImpl
 
UnclosedFragmentException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Replication failed due to unclosed fragments.
UNDER_REPLICATED_LEDGERS_TOTAL_SIZE - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
UNDER_REPLICATION_LOCK - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
UNDER_REPLICATION_NODE - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
underlying - Variable in class org.apache.bookkeeper.stats.CachingStatsLogger
 
underlying - Variable in class org.apache.bookkeeper.stats.CachingStatsProvider
 
UNDERREPLICATED_LEDGER_RECOVERY_GRACE_PERIOD - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
UnderreplicatedLedger - Class in org.apache.bookkeeper.meta
UnderReplicated ledger representation info.
UnderreplicatedLedger(long) - Constructor for class org.apache.bookkeeper.meta.UnderreplicatedLedger
 
UnexpectedConditionException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Unexpected condition.
uninitalize() - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
uninitalize() - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
uninitalize() - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Uninitialize the policy.
uninitalize() - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicy
 
uninitalize() - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
uninitalize() - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicy
 
uninitalize() - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
UNINITIALIZED - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
A placer holder (unused).
UNINITIALIZED_LOG_ID - Static variable in class org.apache.bookkeeper.bookie.DefaultEntryLogger
 
Unknown - org.apache.bookkeeper.tls.SecurityHandlerFactory.NodeType
 
UNKNOWN_REGION - Static variable in class org.apache.bookkeeper.client.RegionAwareEnsemblePlacementPolicy
 
UNKNOWN_ZONE - Static variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
UnknownBookieIdException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
UnknownBookieIdException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.UnknownBookieIdException
 
UnknownBookieIdException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.UnknownBookieIdException
 
unpersistedBytes - Variable in class org.apache.bookkeeper.bookie.BufferedChannel
 
unpersistedBytesBound - Variable in class org.apache.bookkeeper.bookie.BufferedChannel
 
unpooledAllocator - Variable in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
unpooledAllocator(ByteBufAllocator) - Method in interface org.apache.bookkeeper.common.allocator.ByteBufAllocatorBuilder
Specify a custom allocator where the allocation requests should be forwarded to.
unpooledAllocator(ByteBufAllocator) - Method in class org.apache.bookkeeper.common.allocator.impl.ByteBufAllocatorBuilderImpl
 
UnpooledHeap - org.apache.bookkeeper.common.allocator.PoolingPolicy
Allocate memory from JVM heap without any pooling.
UNQUEUED - org.apache.bookkeeper.client.BookieInfoReader.State
 
unregisterBookie(BookieId, boolean) - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Unregistering the bookie server as bookieId.
unregisterBookie(BookieId, boolean) - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
unregisterBookie(BookieId, boolean) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
unregisterGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.MasterSlave
 
unregisterGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.common.stats.BroadCastStatsLogger.Two
 
unregisterGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.CachingStatsLogger
 
unregisterGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.codahale.CodahaleStatsLogger
 
unregisterGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.NullStatsLogger
 
unregisterGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.otel.OtelStatsLogger
 
unregisterGauge(String, Gauge<T>) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusStatsLogger
 
unregisterGauge(String, Gauge<T>) - Method in interface org.apache.bookkeeper.stats.StatsLogger
Unregister given gauge from name name.
unregisterLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
unregisterLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
unregisterLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in interface org.apache.bookkeeper.meta.LedgerManager
Unregister the ledger metadata listener on ledgerId.
unregisterLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
unregisterLedgerMetadataListener(long, BookkeeperInternalCallbacks.LedgerMetadataListener) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
unregisterLocalBookieAddress(BookieId) - Static method in class org.apache.bookkeeper.proto.LocalBookiesRegistry
 
unresolvedNodeLocation - Variable in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
UNSAFE - com.scurrilous.circe.HashSupport
Indicates that the stateful hash algorithm unsafe memory access via StatefulHash.update(long, long).
UNSAFE_INCREMENTAL - com.scurrilous.circe.HashSupport
Indicates that the incremental hash algorithm supports unsafe memory access via IncrementalIntHash.resume(int, long, long) or IncrementalLongHash.resume(long, long, long), depending on which of HashSupport.INT_SIZED or HashSupport.LONG_SIZED is set.
unsetSuccessAndSendWriteRequest(List<BookieId>, int) - Method in class org.apache.bookkeeper.client.PendingAddOp
 
unsetSuccessAndSendWriteRequest(List<BookieId>, Set<Integer>) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
untrackAddRequest() - Method in class org.apache.bookkeeper.proto.RequestStats
 
untrackReadRequest() - Method in class org.apache.bookkeeper.proto.RequestStats
 
unwatchReadOnlyBookies(RegistrationClient.RegistrationListener) - Method in interface org.apache.bookkeeper.discover.RegistrationClient
Unwatch the changes of bookies.
unwatchReadOnlyBookies(RegistrationClient.RegistrationListener) - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
unwatchWritableBookies(RegistrationClient.RegistrationListener) - Method in interface org.apache.bookkeeper.discover.RegistrationClient
Unwatch the changes of bookies.
unwatchWritableBookies(RegistrationClient.RegistrationListener) - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
unwrap() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
unwrap(Throwable) - Static method in class org.apache.bookkeeper.bookie.datainteg.MetadataAsyncIterator
 
update(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.client.LedgerMetaDataCommand.LedgerMetadataFlag
 
update(byte[]) - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
 
update(byte[]) - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
update(byte[]) - Method in interface com.scurrilous.circe.StatefulHash
Updates the state of this hash function with the entire given input array.
update(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
 
update(byte[], int, int) - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
update(byte[], int, int) - Method in interface com.scurrilous.circe.StatefulHash
Updates the state of this hash function with the given range of the given input array.
update(byte[], int, int) - Method in interface org.apache.bookkeeper.proto.checksum.CRC32DigestManager.CRC32Digest
 
update(byte[], int, int) - Method in class org.apache.bookkeeper.proto.checksum.DirectMemoryCRC32Digest
 
update(byte[], int, int) - Method in class org.apache.bookkeeper.proto.checksum.StandardCRC32Digest
 
update(int, ByteBuf, int, int) - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
update(long, long) - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
 
update(long, long) - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
update(long, long) - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
update(long, long) - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
update(long, long) - Method in interface com.scurrilous.circe.StatefulHash
Updates the state of this hash function with memory with the given address and length.
update(long, TimeUnit) - Method in class org.apache.bookkeeper.stats.codahale.FastTimer
Add an event to this timer.
update(ByteBuf, int, int) - Method in interface org.apache.bookkeeper.proto.checksum.CRC32DigestManager.CRC32Digest
 
update(ByteBuf, int, int) - Method in class org.apache.bookkeeper.proto.checksum.DirectMemoryCRC32Digest
 
update(ByteBuf, int, int) - Method in class org.apache.bookkeeper.proto.checksum.StandardCRC32Digest
 
update(ByteBuffer) - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
 
update(ByteBuffer) - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
update(ByteBuffer) - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
update(ByteBuffer) - Method in class com.scurrilous.circe.impl.IntStatefulLongHash
 
update(ByteBuffer) - Method in interface com.scurrilous.circe.StatefulHash
Updates the state of this hash function with the remaining contents of the given input buffer.
update(LastAddConfirmedUpdateNotification) - Method in class org.apache.bookkeeper.proto.LongPollReadEntryProcessorV3
 
update(T) - Method in interface org.apache.bookkeeper.common.util.Watcher
This method is called whenever the watched object is changed.
updateBookieIdInLedgers(BookieId, BookieId, int, int, int, BookieShell.UpdateLedgerNotifier) - Method in class org.apache.bookkeeper.client.UpdateLedgerOp
Update the bookie id present in the ledger metadata.
updateBookieInfo(Map<BookieId, BookieInfoReader.BookieInfo>) - Method in class org.apache.bookkeeper.bookie.LocalBookieEnsemblePlacementPolicy
 
updateBookieInfo(Map<BookieId, BookieInfoReader.BookieInfo>) - Method in class org.apache.bookkeeper.client.DefaultEnsemblePlacementPolicy
 
updateBookieInfo(Map<BookieId, BookieInfoReader.BookieInfo>) - Method in interface org.apache.bookkeeper.client.EnsemblePlacementPolicy
Send the bookie info details.
updateBookieInfo(Map<BookieId, BookieInfoReader.BookieInfo>) - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
UpdateBookieInLedgerCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.UpdateBookieInLedgerCmd
 
UpdateBookieInLedgerCommand - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Command to update ledger command.
UpdateBookieInLedgerCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand
 
UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags - Class in org.apache.bookkeeper.tools.cli.commands.bookie
Flags for update bookie in ledger command.
UpdateBookieInLedgerFlags() - Constructor for class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags
 
UpdateCookieCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.UpdateCookieCmd
 
UpdateCookieCommand - Class in org.apache.bookkeeper.tools.cli.commands.cookie
A command that updates cookie.
UpdateCookieCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.UpdateCookieCommand
 
UpdateCookieCommand(PrintStream) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.UpdateCookieCommand
 
UpdateCookieCommand(UpdateCookieCommand.Flags) - Constructor for class org.apache.bookkeeper.tools.cli.commands.cookie.UpdateCookieCommand
 
UpdateCookieCommand.Flags - Class in org.apache.bookkeeper.tools.cli.commands.cookie
Flags to create a cookie for a given bookie.
updateEntriesLocations(Iterable<EntryLocation>) - Method in interface org.apache.bookkeeper.bookie.CompactableLedgerStorage
Update the location of several entries.
updateEntriesLocations(Iterable<EntryLocation>) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
updateEntriesLocations(Iterable<EntryLocation>) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
updateEntriesLocations(Iterable<EntryLocation>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
UpdateIndexPhase(CompactionEntryLog) - Constructor for class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.UpdateIndexPhase
 
UpdateIndexPhase(CompactionEntryLog, boolean) - Constructor for class org.apache.bookkeeper.bookie.TransactionalEntryLogCompactor.UpdateIndexPhase
 
updateLAC(long) - Method in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
updateLastAddConfirmed(long, long) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
updateLastAddConfirmed(long, long) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
updateLastAddConfirmed(long, long) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
updateLastAddConfirmed(long, long) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
updateLastConfirmed(long, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
updateLatency(long) - Method in class org.apache.bookkeeper.proto.BKStats.OpStats
Update Latency.
UpdateLedgerCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.UpdateLedgerCmd
 
UpdateLedgerOp - Class in org.apache.bookkeeper.client
Encapsulates updating the ledger metadata operation.
UpdateLedgerOp(BookKeeper, BookKeeperAdmin) - Constructor for class org.apache.bookkeeper.client.UpdateLedgerOp
 
updateLocations(Iterable<EntryLocation>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.EntryLocationIndex
 
updateMap(Map<T, WeightedRandomSelection.WeightedObject>) - Method in class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
updateMap(Map<T, WeightedRandomSelection.WeightedObject>) - Method in interface org.apache.bookkeeper.client.WeightedRandomSelection
 
updateMap(Map<T, WeightedRandomSelection.WeightedObject>) - Method in class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
updateMetadataCache(Map<Long, LedgerMetadata>) - Method in class org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl
 
updateNode(Node, boolean) - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology
 
updatePage(LedgerEntryPage) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
Update the ledger entry page.
updatePerSec(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand.FlipBookieIdFlags
 
updatePerSec(int) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags
 
updatePiggyBackedLac(long) - Method in class org.apache.bookkeeper.client.ExplicitLacFlushPolicy.ExplicitLacFlushPolicyImpl
 
updatePiggyBackedLac(long) - Method in interface org.apache.bookkeeper.client.ExplicitLacFlushPolicy
 
updates - Variable in class org.apache.bookkeeper.util.SnapshotMap
 
updateSpecWithDefaultValues(CliSpec<CliFlagsT>) - Method in class org.apache.bookkeeper.tools.framework.Cli
 
updateStatus(boolean) - Method in class org.apache.bookkeeper.net.StabilizeNetworkTopology.NodeStatus
 
updatesToMerge - Variable in class org.apache.bookkeeper.util.SnapshotMap
 
updateUnchecked(byte[], int, int) - Method in class com.scurrilous.circe.crc.JavaCrc32
 
updateUnchecked(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
Updates the state of this hash function with the given range of the given input array.
updateUnchecked(byte[], int, int) - Method in class com.scurrilous.circe.impl.IncrementalIntStatefulHash
 
updateUnchecked(byte[], int, int) - Method in class com.scurrilous.circe.impl.IncrementalLongStatefulHash
 
updateValue(Versioned<LedgerMetadata>, Versioned<LedgerMetadata>) - Method in interface org.apache.bookkeeper.client.MetadataUpdateLoop.LocalValueUpdater
 
upgrade(ServerConfiguration) - Static method in class org.apache.bookkeeper.bookie.FileSystemUpgrade
 
UpgradeException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
UpgradeException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.UpgradeException
 
UpgradeException(String) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.UpgradeException
 
UpgradeException(Throwable) - Constructor for exception org.apache.bookkeeper.bookie.BookieException.UpgradeException
 
URL_PUBLISH_TIME_FOR_LOST_BOOKIE - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
usage() - Method in class org.apache.bookkeeper.tools.framework.Cli
 
usage() - Method in class org.apache.bookkeeper.tools.framework.CliCommand
 
usage() - Method in class org.apache.bookkeeper.tools.framework.CliCommandGroup
 
usage() - Method in class org.apache.bookkeeper.tools.framework.CliSpec
 
usage() - Method in interface org.apache.bookkeeper.tools.framework.Command
Print the help information.
usage() - Method in class org.apache.bookkeeper.tools.framework.HelpCommand
 
usage(String) - Method in class org.apache.bookkeeper.tools.framework.Cli
 
USE_CACHED_METADATA - org.apache.bookkeeper.bookie.datainteg.Events
The full check will use cached metadata.
USE_HOST_NAME_AS_BOOKIE_ID - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
USE_HOSTNAME_RESOLVE_LOCAL_NODE_PLACEMENT_POLICY - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
USE_SHORT_HOST_NAME - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
USE_TARGET_ENTRYLOG_SIZE_FOR_GC - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
USE_TRANSACTIONAL_COMPACTION - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
USE_V2_WIRE_PROTOCOL - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
useHostName() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.DNSResolverDecorator
 
useHostName() - Method in class org.apache.bookkeeper.net.CachedDNSToSwitchMapping
 
useHostName() - Method in interface org.apache.bookkeeper.net.DNSToSwitchMapping
Hints what to use with implementation when InetSocketAddress is converted to String: hostname (addr.getHostName(), default) or IP address (addr.getAddress().getHostAddress()).
useHostnameResolveLocalNodePlacementPolicy - Variable in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
usePage() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
useV2Protocol - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseDecoder
 
useV2Protocol - Variable in class org.apache.bookkeeper.proto.checksum.DigestManager
 
useV2WireProtocol - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
usingV3Protocol - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestDecoder
 
usingV3Protocol - Variable in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseDecoder
 
UUIDLedgerIdFormatter() - Constructor for class org.apache.bookkeeper.util.LedgerIdFormatter.UUIDLedgerIdFormatter
 

V

V0 - Static variable in class org.apache.bookkeeper.bookie.FileInfo
 
V0 - Static variable in class org.apache.bookkeeper.util.AvailabilityOfEntriesOfLedger
 
V1 - Static variable in class org.apache.bookkeeper.bookie.FileInfo
 
V1 - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
V1 - Static variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManagerFactory
 
V2 - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
V3 - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
V4 - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
V5 - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
V6 - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
validate() - Method in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
validate() - Method in interface org.apache.bookkeeper.client.ITopologyAwareEnsemblePlacementPolicy.Ensemble
Validates if an ensemble is valid.
validate() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.EnsembleForReplacementWithNoConstraints
Validates if an ensemble is valid.
validate() - Method in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
Validates if an ensemble is valid.
validate() - Method in class org.apache.bookkeeper.common.conf.ComponentConfiguration
 
validate() - Method in class org.apache.bookkeeper.conf.ServerConfiguration
Validate the configuration.
validate(String, Object) - Method in interface org.apache.bookkeeper.common.conf.Validator
Validates the configuration value.
validate(String, Object) - Method in class org.apache.bookkeeper.common.conf.validators.ClassValidator
 
validate(String, Object) - Method in class org.apache.bookkeeper.common.conf.validators.NullValidator
 
validate(String, Object) - Method in class org.apache.bookkeeper.common.conf.validators.RangeValidator
 
validate(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigDef
Validate if the provided conf is a valid configuration of this configuration definition.
validate(Configuration) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
Validate the setting is valid in the provided config conf.
validateAndGetFileChannel() - Method in class org.apache.bookkeeper.bookie.BufferedChannelBase
 
validateAndNukeExistingCluster(AbstractConfiguration<?>, LayoutManager) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManagerFactory
 
validateAndNukeExistingCluster(AbstractConfiguration<?>, LayoutManager) - Method in interface org.apache.bookkeeper.meta.LedgerManagerFactory
This method makes sure there are no unexpected znodes under ledgersRootPath and then it proceeds with ledger metadata formatting and nuking the cluster ZK state info.
validateAndNukeExistingCluster(AbstractConfiguration<?>, LayoutManager) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory
Deprecated.
 
validateAndNukeExistingCluster(AbstractConfiguration<?>, LayoutManager) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManagerFactory
 
validateConf() - Method in class org.apache.bookkeeper.net.AbstractDNSToSwitchMapping
when setConf is called it should do sanity checking of the conf/env.
validator() - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The validator used for validating configuration value.
validator() - Method in enum org.apache.bookkeeper.common.conf.Type
 
validator(Validator) - Method in class org.apache.bookkeeper.common.conf.ConfigKey.ConfigKeyBuilder
The validator used for validating configuration value.
validator(Validator) - Method in class org.apache.bookkeeper.common.conf.ConfigKey
The validator used for validating configuration value.
Validator - Interface in org.apache.bookkeeper.common.conf
Validator that validates configuration settings.
value - Variable in class org.apache.bookkeeper.client.BookKeeperAdmin.SyncObject
 
value - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.SyncResult
Deprecated.
 
value - Variable in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.Result
 
value - Variable in class org.apache.bookkeeper.versioning.Versioned
 
value(T) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
Value - Class in org.apache.bookkeeper.metastore
A metastore value.
Value() - Constructor for class org.apache.bookkeeper.metastore.Value
 
Value(Value) - Constructor for class org.apache.bookkeeper.metastore.Value
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
valueOf(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
Deprecated.
valueOf(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
Deprecated.
valueOf(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
Deprecated.
valueOf(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
Deprecated.
valueOf(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
Deprecated.
valueOf(int) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
Deprecated.
valueOf(int) - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
Deprecated.
valueOf(int) - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
Returns the enum constant of this type with the specified name.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
Returns the enum constant of this type with the specified name.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
Returns the enum constant of this type with the specified name.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
Returns the enum constant of this type with the specified name.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
Returns the enum constant of this type with the specified name.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
Returns the enum constant of this type with the specified name.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
Returns the enum constant of this type with the specified name.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.scurrilous.circe.HashSupport
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.scurrilous.circe.params.MurmurHash3Variant
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.bookie.BookieStatus.BookieMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.bookie.datainteg.Events
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.bookie.LedgerStorage.StorageState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.bookie.storage.directentrylogger.Events
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageFactory.DbConfigType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.client.api.DigestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.client.api.LedgerMetadata.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.client.api.WriteFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.client.BookieInfoReader.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.client.BookKeeper.DigestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementPolicyAdherence
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.client.LedgerFragment.ReplicateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.common.allocator.LeakDetectionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.common.allocator.OutOfMemoryPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.common.allocator.PoolingPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.common.component.Lifecycle.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.common.conf.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.common.util.Backoff.Jitter.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.common.util.SingleThreadExecutor.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.meta.exceptions.Code
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.meta.LedgerAuditorManager.AuditorEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.metastore.MetastoreScannableTable.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.metastore.MSException.Code
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.metastore.MSWatchedEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.proto.PerChannelBookieClient.ConnectionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.slogger.AbstractSlogger.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.stats.codahale.FastTimer.Buckets
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.tls.SecurityHandlerFactory.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.tls.TLSContextFactory.KeyStoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.util.HardLink.OSType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.bookkeeper.versioning.Version.Occurred
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.scurrilous.circe.HashSupport
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.scurrilous.circe.params.MurmurHash3Variant
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.bookie.BookieStatus.BookieMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.bookie.datainteg.DataIntegrityCheckImpl.LedgerResult.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.bookie.datainteg.Events
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.bookie.LedgerStorage.StorageState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.bookie.storage.directentrylogger.Events
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.bookie.storage.ldb.KeyValueStorageFactory.DbConfigType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.client.api.DigestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.client.api.LedgerMetadata.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.client.api.WriteFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.client.BookieInfoReader.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.client.BookKeeper.DigestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.client.EnsemblePlacementPolicy.PlacementPolicyAdherence
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.client.LedgerFragment.ReplicateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.common.allocator.LeakDetectionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.common.allocator.OutOfMemoryPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.common.allocator.PoolingPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.common.component.Lifecycle.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.common.conf.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.common.util.Backoff.Jitter.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.common.util.SingleThreadExecutor.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.meta.exceptions.Code
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.meta.LedgerAuditorManager.AuditorEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.metastore.MetastoreScannableTable.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.metastore.MSException.Code
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.metastore.MSWatchedEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest.Flags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.proto.BookkeeperProtocol.StatusCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.DigestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.proto.PerChannelBookieClient.ConnectionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.slogger.AbstractSlogger.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.stats.codahale.FastTimer.Buckets
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.tls.SecurityHandlerFactory.NodeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.tls.TLSContextFactory.KeyStoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongHashMap
 
values() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongHashMap
 
values() - Method in class org.apache.bookkeeper.util.collections.ConcurrentLongLongPairHashMap
 
values() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashMap
 
values() - Method in class org.apache.bookkeeper.util.collections.ConcurrentOpenHashSet
 
values() - Static method in enum org.apache.bookkeeper.util.HardLink.OSType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.bookkeeper.versioning.Version.Occurred
Returns an array containing the constants of this enum type, in the order they are declared.
variant() - Method in class com.scurrilous.circe.params.MurmurHash3Parameters
Returns the variant of the hash algorithm.
verbose(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.CheckDBLedgersIndexCommand.CheckLedgersIndexFlags
 
verbose(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.FlipBookieIdCommand.FlipBookieIdFlags
 
verbose(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.RebuildDBLedgersIndexCommand.RebuildLedgersIndexFlags
 
verbose(boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.bookie.UpdateBookieInLedgerCommand.UpdateBookieInLedgerFlags
 
verbose(Boolean) - Method in class org.apache.bookkeeper.tools.cli.commands.autorecovery.QueryAutoRecoveryStatusCommand.QFlags
 
verify(Cookie) - Method in class org.apache.bookkeeper.bookie.Cookie
 
VERIFY_METADATA_ON_GC - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
verifyDigestAndReturnData(long, ByteBuf) - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
Verify that the digest matches and returns the data in the entry.
verifyDigestAndReturnLac(ByteBuf) - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
verifyDigestAndReturnLastConfirmed(ByteBuf) - Method in class org.apache.bookkeeper.proto.checksum.DigestManager
 
verifyIsSuperSet(Cookie) - Method in class org.apache.bookkeeper.bookie.Cookie
 
version - Variable in class org.apache.bookkeeper.metastore.InMemoryMetastoreTable.MetadataVersion
 
version - Variable in class org.apache.bookkeeper.versioning.LongVersion
 
version - Variable in class org.apache.bookkeeper.versioning.Versioned
 
Version - Interface in org.apache.bookkeeper.versioning
An interface that allows us to determine if a given version happened before or after another version.
VERSION_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
VERSION_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
VERSION_FILENAME - Static variable in class org.apache.bookkeeper.util.BookKeeperConstants
 
VERSION_HEADER_SIZE - Static variable in class org.apache.bookkeeper.bookie.JournalChannel
 
VERSION_ONE - org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
VERSION_ONE = 1;
VERSION_ONE_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
VERSION_ONE = 1;
VERSION_THREE - org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
VERSION_THREE = 3;
VERSION_THREE_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
VERSION_THREE = 3;
VERSION_TWO - org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
VERSION_TWO = 2;
VERSION_TWO_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.ProtocolVersion
VERSION_TWO = 2;
Version.Occurred - Enum in org.apache.bookkeeper.versioning
Define the sequence of versions.
Versioned<T> - Class in org.apache.bookkeeper.versioning
A Versioned value represents a value associated with a version.
Versioned(T, Version) - Constructor for class org.apache.bookkeeper.versioning.Versioned
 
visit(long, long) - Method in interface org.apache.bookkeeper.bookie.LedgerEntryPage.EntryVisitor
 
visitArray(T, byte[], int, int) - Method in interface org.apache.bookkeeper.util.ByteBufVisitor.ByteBufVisitorCallback
 
visitBuffer(T, ByteBuf, int, int) - Method in interface org.apache.bookkeeper.util.ByteBufVisitor.ByteBufVisitorCallback
 
visitBuffers(ByteBuf, int, int, ByteBufVisitor.ByteBufVisitorCallback<T>, T) - Static method in class org.apache.bookkeeper.util.ByteBufVisitor
This method traverses the potential nested composite buffers of the provided buffer, given a specific offset and length.
visitBuffers(ByteBuf, int, int, ByteBufVisitor.ByteBufVisitorCallback<T>, T, int) - Static method in class org.apache.bookkeeper.util.ByteBufVisitor
Void() - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
 
VOID_EXPLICITLAC_FLUSH_POLICY - Static variable in interface org.apache.bookkeeper.client.ExplicitLacFlushPolicy
 
VoteWasDeleted - org.apache.bookkeeper.meta.LedgerAuditorManager.AuditorEvent
 

W

w - Variable in class org.apache.bookkeeper.util.SubTreeCache.WatchGuard
 
WAIT_TIMEOUT_ON_BACKPRESSURE - Static variable in class org.apache.bookkeeper.conf.ClientConfiguration
 
WAIT_TIMEOUT_ON_RESPONSE_BACKPRESSURE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
waitForConnection() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
waitForConnection() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperWatcherBase
Waiting for the SyncConnected event from the ZooKeeper server.
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in interface org.apache.bookkeeper.bookie.Bookie
 
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.BookieImpl
 
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.InterleavedLedgerStorage
 
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.InterleavedStorageRegenerateIndexOp.DryRunLedgerCache
 
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in interface org.apache.bookkeeper.bookie.LedgerCache
 
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.LedgerCacheImpl
 
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in interface org.apache.bookkeeper.bookie.LedgerStorage
Wait for last add confirmed update.
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.SortedLedgerStorage
 
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
waitForLastAddConfirmedUpdate(long, long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
waitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.FileInfo
 
waitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
waitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.LedgerDescriptorImpl
 
waitForLastAddConfirmedUpdate(long, Watcher<LastAddConfirmedUpdateNotification>) - Method in class org.apache.bookkeeper.bookie.storage.ldb.TransientLedgerInfo
 
waitForResult(CompletableFuture<T>) - Static method in class org.apache.bookkeeper.client.SyncCallbackUtils
Wait for a result.
waitForServerUp(String, long) - Static method in class org.apache.bookkeeper.util.LocalBookKeeper
 
waitForWritable(DistributionSchedule.WriteSet, int, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
 
waitForWriteSetMs - Variable in class org.apache.bookkeeper.client.ClientInternalConf
 
waitIfLedgerReplicationDisabled() - Method in class org.apache.bookkeeper.replication.AuditorBookieCheckTask
 
waitingForAuth - Variable in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
waitUntilAllFinished() - Method in class org.apache.bookkeeper.metastore.MetastoreUtils.MultiMetastoreCallback
 
warn(Enum<?>) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
warn(Enum<?>) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
warn(Enum<?>) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
warn(Enum<?>, Throwable) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
warn(Enum<?>, Throwable) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
warn(Enum<?>, Throwable) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
warn(String) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
warn(String) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
warn(String) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
warn(String, Throwable) - Method in class org.apache.bookkeeper.slogger.AbstractSlogger
 
warn(String, Throwable) - Method in class org.apache.bookkeeper.slogger.NullSlogger
 
warn(String, Throwable) - Method in interface org.apache.bookkeeper.slogger.Slogger
 
WARN - org.apache.bookkeeper.slogger.AbstractSlogger.Level
 
WARN_TIME_MICRO_SEC_DEFAULT - Static variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
warnTimeMicroSec - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor.AbstractBuilder
 
warnTimeMicroSec - Variable in class org.apache.bookkeeper.common.util.OrderedExecutor
 
watch() - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
Watchable<T> - Class in org.apache.bookkeeper.common.util
This class represents an watchable object, or "data" in the model-view paradigm.
Watchable(RecyclableArrayList.Recycler<Watcher<T>>) - Constructor for class org.apache.bookkeeper.common.util.Watchable
Construct an Watchable with zero watchers.
Watcher<T> - Interface in org.apache.bookkeeper.common.util
A class can implement the Watcher interface when it wants to be informed of one-time changes in watchable objects.
WATCHER_RECYCLER - Static variable in class org.apache.bookkeeper.bookie.LastAddConfirmedUpdateNotification
 
WATCHER_SCOPE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
watchers - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
watchers(Set<Watcher>) - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.Builder
 
WatchGuard(Watcher) - Constructor for class org.apache.bookkeeper.util.SubTreeCache.WatchGuard
 
watchReadOnlyBookies(RegistrationClient.RegistrationListener) - Method in interface org.apache.bookkeeper.discover.RegistrationClient
Watch the changes of bookies.
watchReadOnlyBookies(RegistrationClient.RegistrationListener) - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
watchReadOnlyBookiesChanged(RegistrationClient.RegistrationListener) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Notify when the available list of read only bookies changes.
WatchTask(String, CompletableFuture<Void>) - Constructor for class org.apache.bookkeeper.discover.ZKRegistrationClient.WatchTask
 
watchWritableBookies(RegistrationClient.RegistrationListener) - Method in interface org.apache.bookkeeper.discover.RegistrationClient
Watch the changes of bookies.
watchWritableBookies(RegistrationClient.RegistrationListener) - Method in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
watchWritableBookiesChanged(RegistrationClient.RegistrationListener) - Method in class org.apache.bookkeeper.client.BookKeeperAdmin
Notify when the available list of bookies changes.
WeightedRandomSelection<T> - Interface in org.apache.bookkeeper.client
 
WeightedRandomSelection.WeightedObject - Interface in org.apache.bookkeeper.client
 
WeightedRandomSelectionImpl<T> - Class in org.apache.bookkeeper.client
 
WeightedRandomSelectionImpl() - Constructor for class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
WeightedRandomSelectionImpl(int) - Constructor for class org.apache.bookkeeper.client.WeightedRandomSelectionImpl
 
weightedSelection - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy
 
weightMap - Variable in class org.apache.bookkeeper.client.DynamicWeightedRandomSelectionImpl
 
WhatIsInstanceId() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.WhatIsInstanceId
 
whenCompleteAsync(CompletableFuture<T>, BiConsumer<? super T, ? super Throwable>, OrderedScheduler, Object) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
Completing the future in the thread in the scheduler identified by the scheduleKey.
WhoIsAuditorCmd() - Constructor for class org.apache.bookkeeper.bookie.BookieShell.WhoIsAuditorCmd
 
WhoIsAuditorCommand - Class in org.apache.bookkeeper.tools.cli.commands.autorecovery
Command to print which node has the auditor lock.
WhoIsAuditorCommand() - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.WhoIsAuditorCommand
 
WhoIsAuditorCommand(BookKeeperAdmin) - Constructor for class org.apache.bookkeeper.tools.cli.commands.autorecovery.WhoIsAuditorCommand
 
WhoIsAuditorService - Class in org.apache.bookkeeper.server.http.service
HttpEndpointService that handle Bookkeeper who is auditor related http request.
WhoIsAuditorService(ServerConfiguration, BookKeeperAdmin) - Constructor for class org.apache.bookkeeper.server.http.service.WhoIsAuditorService
 
WINDOWS - Static variable in class org.apache.bookkeeper.util.Shell
Set to true on Windows platforms.
withAckQuorumSize(int) - Method in interface org.apache.bookkeeper.client.api.CreateBuilder
Set the number of acknowledgements to wait before considering a write to be completed with success.
withAckQuorumSize(int) - Method in class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
withAckQuorumSize(int) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withArgumentsUsage(String) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withCategory(String) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withClosedState() - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withComponentInfoPublisher(ComponentInfoPublisher) - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack.Builder
 
withConfigKey(ConfigKey) - Method in class org.apache.bookkeeper.common.conf.ConfigDef.Builder
Add the config key to the builder.
withConfigKeyGroup(ConfigKeyGroup) - Method in class org.apache.bookkeeper.common.conf.ConfigDef.Builder
Add the config key group to the builder.
withConsole(PrintStream) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withCreationTime(long) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withCToken(long) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withCustomMetadata(Map<String, byte[]>) - Method in interface org.apache.bookkeeper.client.api.CreateBuilder
Set a map a custom data to be attached to the ledger.
withCustomMetadata(Map<String, byte[]>) - Method in class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
withCustomMetadata(Map<String, byte[]>) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withDefaultFaultDomain(String) - Method in class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
withDefaultRack(String) - Method in class org.apache.bookkeeper.client.RackawareEnsemblePlacementPolicyImpl
 
withDescription(String) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withDigestType(DigestType) - Method in interface org.apache.bookkeeper.client.api.CreateBuilder
Set the Digest type used to guard data against corruption.
withDigestType(DigestType) - Method in interface org.apache.bookkeeper.client.api.OpenBuilder
Sets the expected digest type used to check the contents of the ledger.
withDigestType(DigestType) - Method in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
withDigestType(DigestType) - Method in class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
withDigestType(DigestType) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withEnsembleSize(int) - Method in interface org.apache.bookkeeper.client.api.CreateBuilder
Set the number of bookies which will receive data for this ledger.
withEnsembleSize(int) - Method in class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
withEnsembleSize(int) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withFlags(CliFlagsT) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withId(long) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
within(CompletableFuture<T>, long, TimeUnit, Throwable, OrderedScheduler, Object) - Static method in class org.apache.bookkeeper.common.concurrent.FutureUtils
Raise an exception to the promise within a given timeout period.
withInRecoveryState() - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withLastEntryId(long) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withLedgerId(long) - Method in interface org.apache.bookkeeper.client.api.CreateAdvBuilder
Set a fixed ledgerId for the newly created ledger.
withLedgerId(long) - Method in interface org.apache.bookkeeper.client.api.DeleteBuilder
Set the id of the ledger to be deleted.
withLedgerId(long) - Method in interface org.apache.bookkeeper.client.api.OpenBuilder
Set the id of the ledger to be opened.
withLedgerId(long) - Method in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
withLedgerId(long) - Method in class org.apache.bookkeeper.client.LedgerDeleteOp.DeleteBuilderImpl
 
withLength(long) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withMetadataFormatVersion(int) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withName(String) - Method in class org.apache.bookkeeper.common.component.LifecycleComponentStack.Builder
 
withName(String) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withParent(String) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withPassword(byte[]) - Method in interface org.apache.bookkeeper.client.api.CreateBuilder
Set a password for the ledger.
withPassword(byte[]) - Method in interface org.apache.bookkeeper.client.api.OpenBuilder
Sets the password to be used to open the ledger.
withPassword(byte[]) - Method in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
withPassword(byte[]) - Method in class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
withPassword(byte[]) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
withRecovery(boolean) - Method in interface org.apache.bookkeeper.client.api.OpenBuilder
Define to open the ledger in recovery mode or in readonly mode.
withRecovery(boolean) - Method in class org.apache.bookkeeper.client.impl.OpenBuilderBase
 
withRequestContext(BookkeeperProtocol.Request.Builder) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
withRunFunc(Function<CliFlagsT, Boolean>) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withTailer(String) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withUsage(String) - Method in class org.apache.bookkeeper.tools.framework.CliSpec.Builder
 
withWriteFlags(EnumSet<WriteFlag>) - Method in interface org.apache.bookkeeper.client.api.CreateBuilder
Set write flags.
withWriteFlags(EnumSet<WriteFlag>) - Method in class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
withWriteFlags(WriteFlag...) - Method in interface org.apache.bookkeeper.client.api.CreateBuilder
Set write flags.
withWriteQuorumSize(int) - Method in interface org.apache.bookkeeper.client.api.CreateBuilder
Set the number of bookies which receive every single entry.
withWriteQuorumSize(int) - Method in class org.apache.bookkeeper.client.LedgerCreateOp.CreateBuilderImpl
 
withWriteQuorumSize(int) - Method in class org.apache.bookkeeper.client.LedgerMetadataBuilder
 
worker - Variable in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.ZkRetryRunnable
 
wrap(byte[]) - Static method in class org.apache.bookkeeper.auth.AuthToken
 
writableBytes() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
write(byte[]) - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
write(byte[], int, int) - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
write(int) - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
write(long, byte[]) - Method in interface org.apache.bookkeeper.client.api.WriteAdvHandle
Add entry synchronously to an open ledger.
write(long, byte[], int, int) - Method in interface org.apache.bookkeeper.client.api.WriteAdvHandle
Add entry synchronously to an open ledger.
write(long, ByteBuf) - Method in interface org.apache.bookkeeper.client.api.WriteAdvHandle
Add entry asynchronously to an open ledger.
write(long, ByteBuffer) - Method in interface org.apache.bookkeeper.client.api.WriteAdvHandle
Add entry synchronously to an open ledger.
write(ByteBuf) - Method in class org.apache.bookkeeper.bookie.BufferedChannel
Write all the data in src to the FileChannel.
write(ByteBuf) - Method in class org.apache.bookkeeper.bookie.SlowBufferedChannel
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.bookkeeper.proto.AuthHandler.ClientSideHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.RequestEncoder
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.bookkeeper.proto.BookieProtoEncoding.ResponseEncoder
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.bookkeeper.util.ByteBufList.Encoder
 
write(ByteBuffer[], long) - Method in class org.apache.bookkeeper.bookie.FileInfo
 
write(LogWriter, EntryLogMetadata, ByteBufAllocator) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.LogMetadata
 
WRITE_BUFFER_SIZE - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
WRITE_BYTES - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
WRITE_CACHE_MAX_SIZE_MB - Static variable in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorage
 
WRITE_DATA_LATENCY - Static variable in interface org.apache.bookkeeper.replication.ReplicationStats
 
WRITE_DELAYED_DUE_TO_NOT_ENOUGH_FAULT_DOMAINS - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
WRITE_DELAYED_DUE_TO_NOT_ENOUGH_FAULT_DOMAINS_LATENCY - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
WRITE_FILE_INFO_CACHE_SIZE - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
WRITE_LAC - org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
WRITE_LAC = 6;
WRITE_LAC - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
WRITE_LAC - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
 
WRITE_LAC_OP - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
WRITE_LAC_REQUEST - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
WRITE_LAC_VALUE - Static variable in enum org.apache.bookkeeper.proto.BookkeeperProtocol.OperationType
WRITE_LAC = 6;
WRITE_THREAD_QUEUED_LATENCY - Static variable in interface org.apache.bookkeeper.bookie.BookKeeperServerStats
 
WRITE_TIMED_OUT_DUE_TO_NOT_ENOUGH_FAULT_DOMAINS - Static variable in interface org.apache.bookkeeper.client.BookKeeperClientStats
 
WriteAdvHandle - Interface in org.apache.bookkeeper.client.api
Provide write access to a ledger.
writeAllMetrics(Writer) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusMetricsProvider
 
writeAllMetrics(Writer) - Method in interface org.apache.bookkeeper.stats.StatsProvider
 
writeAndFlushWithClosePromise(ChannelOutboundInvoker, Object) - Static method in class org.apache.bookkeeper.util.NettyChannelUtil
Write and flush the message to the channel and the close the channel.
writeAndFlushWithVoidPromise(ChannelOutboundInvoker, Object) - Static method in class org.apache.bookkeeper.util.NettyChannelUtil
Write and flush the message to the channel.
writeAsync(long, byte[]) - Method in interface org.apache.bookkeeper.client.api.WriteAdvHandle
Add entry asynchronously to an open ledger.
writeAsync(long, byte[], int, int) - Method in interface org.apache.bookkeeper.client.api.WriteAdvHandle
Add entry asynchronously to an open ledger.
writeAsync(long, ByteBuf) - Method in interface org.apache.bookkeeper.client.api.WriteAdvHandle
Add entry asynchronously to an open ledger.
writeAsync(long, ByteBuf) - Method in class org.apache.bookkeeper.client.LedgerHandleAdv
 
writeAsync(long, ByteBuffer) - Method in interface org.apache.bookkeeper.client.api.WriteAdvHandle
Add entry asynchronously to an open ledger.
writeAt(long, ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
writeAt(long, ByteBuf) - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogWriter
Write the contents of a buffer at a predefined position in the log.
writeBoolean(boolean) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeBuffer - Variable in class org.apache.bookkeeper.bookie.BufferedChannel
The buffer used to write operations.
writeBufferStartPosition - Variable in class org.apache.bookkeeper.bookie.BufferedChannel
The position of the file channel's write pointer.
writeByte(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeByteBuf(ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
Write a btebuf to this buffer.
writeBytes(byte[]) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeBytes(byte[], int, int) - Method in class com.scurrilous.circe.impl.AbstractStatefulHash
Writes the output of this hash function into the given range of the given byte array.
writeBytes(byte[], int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeBytes(ByteBuf) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeBytes(ByteBuf, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeBytes(ByteBuf, int, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeBytes(InputStream, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeBytes(ByteBuffer) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeBytes(FileChannel, long, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeBytes(ScatteringByteChannel, int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeCache - Variable in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
WriteCache - Class in org.apache.bookkeeper.bookie.storage.ldb
Write cache implementation.
WriteCache(ByteBufAllocator, long) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
WriteCache(ByteBufAllocator, long, int) - Constructor for class org.apache.bookkeeper.bookie.storage.ldb.WriteCache
 
WriteCache.EntryConsumer - Interface in org.apache.bookkeeper.bookie.storage.ldb
Consumer that is used to scan the entire write cache.
writeCacheBeingFlushed - Variable in class org.apache.bookkeeper.bookie.storage.ldb.SingleDirectoryDbLedgerStorage
 
WriteCallback(BookkeeperVerifier.LedgerInfo, long, long, int) - Constructor for class org.apache.bookkeeper.verifier.BookkeeperVerifier.WriteCallback
 
writeCapacity - Variable in class org.apache.bookkeeper.bookie.BufferedChannel
The capacity of the write buffer.
writeChar(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeCharSequence(CharSequence, Charset) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeComplete(int, long, long, BookieId, Object) - Method in class org.apache.bookkeeper.bookie.BookieImpl.NopWriteCallback
 
writeComplete(int, long, long, BookieId, Object) - Method in class org.apache.bookkeeper.client.PendingAddOp
 
writeComplete(int, long, long, BookieId, Object) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.WriteCallback
 
writeComplete(int, long, long, BookieId, Object) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient.AddCompletion
 
writeComplete(int, long, long, BookieId, Object) - Method in class org.apache.bookkeeper.proto.WriteEntryProcessor
 
writeCookie(BookieId, Versioned<byte[]>) - Method in interface org.apache.bookkeeper.discover.RegistrationManager
Write the cookie data, which will be used for verifying the integrity of the bookie environment.
writeCookie(BookieId, Versioned<byte[]>) - Method in class org.apache.bookkeeper.discover.ZKRegistrationManager
 
writeCookie(BookieId, Versioned<byte[]>) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullRegistrationManager
 
writeCount - Variable in class org.apache.bookkeeper.client.LedgerRecoveryOp
 
writeCounter(Writer, String, LongAdderCounter) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusTextFormat
 
writeDelayedStartTime - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
writeDelimited(ByteBuf) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
writeDelimited(ByteBuf) - Method in interface org.apache.bookkeeper.bookie.storage.directentrylogger.LogWriter
Write a delimited buffer the log.
writeDouble(double) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeEmptyHeader(ByteBuf) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
writeEntry(long, long, byte[], Consumer<Integer>) - Method in interface org.apache.bookkeeper.verifier.BookkeeperVerifier.BookkeeperDriver
 
writeEntry(long, long, byte[], Consumer<Integer>) - Method in class org.apache.bookkeeper.verifier.DirectBookkeeperDriver
 
WriteEntryProcessor - Class in org.apache.bookkeeper.proto
Processes add entry requests.
WriteEntryProcessorV3 - Class in org.apache.bookkeeper.proto
 
WriteEntryProcessorV3(BookkeeperProtocol.Request, BookieRequestHandler, BookieRequestProcessor) - Constructor for class org.apache.bookkeeper.proto.WriteEntryProcessorV3
 
WriteException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Write operations failed (bookie error).
writeExecutor - Variable in class org.apache.bookkeeper.bookie.storage.directentrylogger.DirectWriter
 
writeFileInfoCache - Variable in class org.apache.bookkeeper.bookie.IndexPersistenceMgr
 
WriteFlag - Enum in org.apache.bookkeeper.client.api
Flags to specify the behaviour of writes.
writeFlags - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
writeFlags - Variable in class org.apache.bookkeeper.client.LedgerHandle
 
writeFlags - Variable in class org.apache.bookkeeper.client.PendingAddOp
 
WRITEFLAGS_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
writeFloat(float) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeFully(WritableByteChannel, ByteBuffer) - Static method in class org.apache.bookkeeper.util.IOUtils
Write a ByteBuffer to a WritableByteChannel, handling short writes.
writeGauge(Writer, String, SimpleGauge<? extends Number>) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusTextFormat
 
WriteHandle - Interface in org.apache.bookkeeper.client.api
Provide write access to a ledger.
writeHeader(ByteBuf, long, int) - Static method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Header
 
writeInt(int) - Method in class org.apache.bookkeeper.bookie.storage.directentrylogger.Buffer
Write an integer to buffer.
writeInt(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeIntLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeLac(long, byte[], long, ByteBufList, BookkeeperInternalCallbacks.WriteLacCallback, Object) - Method in class org.apache.bookkeeper.proto.PerChannelBookieClient
 
writeLac(BookieId, long, byte[], long, ByteBufList, BookkeeperInternalCallbacks.WriteLacCallback, Object) - Method in interface org.apache.bookkeeper.proto.BookieClient
Explicitly write the last add confirmed for ledger ledgerId to the bookie at address.
writeLac(BookieId, long, byte[], long, ByteBufList, BookkeeperInternalCallbacks.WriteLacCallback, Object) - Method in class org.apache.bookkeeper.proto.BookieClientImpl
 
writeLacComplete(int, long, BookieId, Object) - Method in class org.apache.bookkeeper.client.PendingWriteLacOp
 
writeLacComplete(int, long, BookieId, Object) - Method in interface org.apache.bookkeeper.proto.BookkeeperInternalCallbacks.WriteLacCallback
 
WriteLacCompletion(PerChannelBookieClient.CompletionKey, BookkeeperInternalCallbacks.WriteLacCallback, Object, long) - Constructor for class org.apache.bookkeeper.proto.PerChannelBookieClient.WriteLacCompletion
 
WriteLacProcessorV3 - Class in org.apache.bookkeeper.proto
 
WriteLacProcessorV3(BookkeeperProtocol.Request, BookieRequestHandler, BookieRequestProcessor) - Constructor for class org.apache.bookkeeper.proto.WriteLacProcessorV3
 
WRITELACREQUEST_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
writeLacRequestStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
WRITELACRESPONSE_FIELD_NUMBER - Static variable in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
writeLacStats - Variable in class org.apache.bookkeeper.proto.RequestStats
 
writeLedgerMetadata(long, LedgerMetadata, Version) - Method in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
writeLedgerMetadata(long, LedgerMetadata, Version) - Method in class org.apache.bookkeeper.meta.CleanupLedgerManager
 
writeLedgerMetadata(long, LedgerMetadata, Version) - Method in interface org.apache.bookkeeper.meta.LedgerManager
Write ledger metadata.
writeLedgerMetadata(long, LedgerMetadata, Version) - Method in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
writeLedgerMetadata(long, LedgerMetadata, Version) - Method in class org.apache.bookkeeper.meta.NullMetadataBookieDriver.NullLedgerManager
 
writeLogMark(ByteBuffer) - Method in class org.apache.bookkeeper.bookie.LogMark
 
writeLong(long) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeLongLE(long) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeMedium(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeMediumLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeMetricsCollectedByPrometheusClient(Writer, CollectorRegistry) - Static method in class org.apache.bookkeeper.stats.prometheus.PrometheusTextFormat
 
WriteOnReadOnlyBookieException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
Write operations failed due to bookies are readonly.
writeOpStat(Writer, String, DataSketchesOpStatsLogger) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusTextFormat
 
writePaddingBytes(JournalChannel, ByteBuf, int) - Static method in class org.apache.bookkeeper.bookie.Journal
 
writeQuorumSize - Variable in class org.apache.bookkeeper.client.LedgerCreateOp
 
writeQuorumSize - Variable in class org.apache.bookkeeper.client.TopologyAwareEnsemblePlacementPolicy.RRTopologyAwareCoverageEnsemble
 
writeQuorumSize(int) - Method in class org.apache.bookkeeper.tools.cli.commands.client.SimpleTestCommand.Flags
 
writerIndex() - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writerIndex(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
WriterWithMetadata - Class in org.apache.bookkeeper.bookie.storage.directentrylogger
WriterWithMetadata.
WriterWithMetadata(LogWriter, EntryLogMetadata, ByteBufAllocator) - Constructor for class org.apache.bookkeeper.bookie.storage.directentrylogger.WriterWithMetadata
 
writesCompleted - Variable in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
writeSet - Variable in class org.apache.bookkeeper.client.ReadLastConfirmedAndEntryOp.ReadLACAndEntryRequest
 
writeSet - Variable in class org.apache.bookkeeper.client.ReadOpBase.LedgerEntryRequest
 
writeSetFromValues(Integer...) - Static method in class org.apache.bookkeeper.client.RoundRobinDistributionSchedule
 
WriteSets - Class in org.apache.bookkeeper.bookie.datainteg
Pregenerate the write sets.
WriteSets(int, int) - Constructor for class org.apache.bookkeeper.bookie.datainteg.WriteSets
 
WriteSets(List<Integer>, int, int) - Constructor for class org.apache.bookkeeper.bookie.datainteg.WriteSets
 
writeShort(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writeShortLE(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
writesInProgress - Variable in class org.apache.bookkeeper.verifier.BookkeeperVerifier.LedgerInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.bookie.storage.ldb.DbLedgerStorageDataFormats.LedgerData
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AddResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.AuthMessage
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.BKPacketHeader
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ContextPair
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ForceLedgerResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetBookieInfoResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.GetListOfEntriesOfLedgerResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadLacResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.ReadResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Request
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.Response
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.StartTLSResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.BookkeeperProtocol.WriteLacResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.AuditorVoteFormat
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat.Endpoint
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.BookieServiceInfoFormat
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.CheckAllLedgersFormat
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.CookieFormat
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.cMetadataMapEntry
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat.Segment
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerMetadataFormat
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.LedgerRereplicationLayoutFormat
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.LockDataFormat
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.PlacementPolicyCheckFormat
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.ReplicasCheckFormat
 
writeTo(CodedOutputStream) - Method in class org.apache.bookkeeper.proto.DataFormats.UnderreplicatedLedgerFormat
 
writeToByteBuffer(ByteBuffer) - Method in class org.apache.bookkeeper.bookie.EntryKeyValue
Write EntryKeyValue blob into the provided byte buffer.
writeToDirectories(List<File>) - Method in class org.apache.bookkeeper.bookie.BookieStatus
Write bookie status to multiple directories in best effort.
writeToDirectory(File) - Method in class org.apache.bookkeeper.bookie.Cookie
 
writeToFile(File) - Method in class org.apache.bookkeeper.bookie.Cookie
 
writeToRegistrationManager(RegistrationManager, ServerConfiguration, Version) - Method in class org.apache.bookkeeper.bookie.Cookie
Writes cookie details to registration manager.
writeType(Writer, String, String) - Method in class org.apache.bookkeeper.stats.prometheus.PrometheusTextFormat
 
writeZero(int) - Method in class org.apache.bookkeeper.util.ByteBufVisitor.GetBytesCallbackByteBuf
 
WrongEntryException(long, long, long, long, long, long) - Constructor for exception org.apache.bookkeeper.bookie.DefaultEntryLogger.EntryLookupException.WrongEntryException
 

X

X64_128 - com.scurrilous.circe.params.MurmurHash3Variant
128-bit variant optimized for x64.
X86_128 - com.scurrilous.circe.params.MurmurHash3Variant
128-bit variant optimized for x86.
X86_32 - com.scurrilous.circe.params.MurmurHash3Variant
32-bit variant (optimized for x86).
xorOut() - Method in class com.scurrilous.circe.params.CrcParameters
Returns the value XOR'ed with the CRC register when it is read to determine the output value.

Z

ZeroBuffer - Class in org.apache.bookkeeper.util
Zero buffer utility.
ZeroBuffer() - Constructor for class org.apache.bookkeeper.util.ZeroBuffer
 
zeroPage() - Method in class org.apache.bookkeeper.bookie.LedgerEntryPage
 
zeros - Variable in class org.apache.bookkeeper.bookie.JournalChannel
 
zip(Stream<? extends T1>, Stream<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class org.apache.bookkeeper.common.util.StreamUtil
 
zk - Variable in class org.apache.bookkeeper.client.BookKeeper.Builder
 
zk - Variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
zk - Variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManagerFactory
 
zk - Variable in class org.apache.bookkeeper.meta.MSLedgerManagerFactory.MsLedgerManager
Deprecated.
 
zk - Variable in class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
zk - Variable in class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
zk(ZooKeeper) - Method in class org.apache.bookkeeper.client.BookKeeper.Builder
Deprecated.
ZK_BOOKIE_DRIVER_CLASS - Static variable in class org.apache.bookkeeper.meta.MetadataDrivers
 
ZK_CLIENT_DRIVER_CLASS - Static variable in class org.apache.bookkeeper.meta.MetadataDrivers
 
ZK_CONNECT_BACKOFF_MS - Static variable in class org.apache.bookkeeper.discover.ZKRegistrationClient
 
ZK_CONNECT_BACKOFF_MS - Static variable in class org.apache.bookkeeper.meta.AbstractZkLedgerManager
 
ZK_ENABLE_SECURITY - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ZK_EXPIRED - Static variable in class org.apache.bookkeeper.bookie.ExitCode
 
ZK_LEDGERS_ROOT_PATH - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ZK_REG_FAIL - Static variable in class org.apache.bookkeeper.bookie.ExitCode
 
ZK_REQUEST_RATE_LIMIT - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ZK_RETRY_BACKOFF_MAX_MS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ZK_RETRY_BACKOFF_MAX_RETRIES - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ZK_RETRY_BACKOFF_START_MS - Static variable in class org.apache.bookkeeper.conf.ServerConfiguration
 
ZK_SERVERS - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
ZK_TIMEOUT - Static variable in class org.apache.bookkeeper.conf.AbstractConfiguration
 
zkAcls - Variable in class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
ZKException - Static variable in interface org.apache.bookkeeper.client.api.BKException.Code
ZooKeeper operations failed.
ZKException() - Constructor for exception org.apache.bookkeeper.client.BKException.ZKException
 
ZKException(Throwable) - Constructor for exception org.apache.bookkeeper.client.BKException.ZKException
 
zkHost - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
ZkLayoutManager - Class in org.apache.bookkeeper.meta
Provide utils for writing/reading/deleting layout in zookeeper.
ZkLayoutManager(ZooKeeper, String, List<ACL>) - Constructor for class org.apache.bookkeeper.meta.ZkLayoutManager
 
ZkLedgerAuditorManager - Class in org.apache.bookkeeper.meta
ZK based implementation of LedgerAuditorManager.
ZkLedgerAuditorManager(ZooKeeper, ServerConfiguration, StatsLogger) - Constructor for class org.apache.bookkeeper.meta.ZkLedgerAuditorManager
 
ZkLedgerIdGenerator - Class in org.apache.bookkeeper.meta
ZooKeeper based ledger id generator class, which using EPHEMERAL_SEQUENTIAL with (ledgerIdGenPath)/ID- prefix to generate ledger id.
ZkLedgerIdGenerator(ZooKeeper, String, String, List<ACL>) - Constructor for class org.apache.bookkeeper.meta.ZkLedgerIdGenerator
 
zkLedgersRootPath(String) - Method in class org.apache.bookkeeper.tools.cli.commands.bookies.NukeExistingClusterCommand.NukeExistingClusterFlags
 
ZkLedgerUnderreplicationManager - Class in org.apache.bookkeeper.meta
ZooKeeper implementation of underreplication manager.
ZkLedgerUnderreplicationManager(AbstractConfiguration, ZooKeeper) - Constructor for class org.apache.bookkeeper.meta.ZkLedgerUnderreplicationManager
 
ZKMetadataBookieDriver - Class in org.apache.bookkeeper.meta.zk
ZooKeeper based metadata bookie driver.
ZKMetadataBookieDriver() - Constructor for class org.apache.bookkeeper.meta.zk.ZKMetadataBookieDriver
 
ZKMetadataClientDriver - Class in org.apache.bookkeeper.meta.zk
ZooKeeper based metadata client driver.
ZKMetadataClientDriver() - Constructor for class org.apache.bookkeeper.meta.zk.ZKMetadataClientDriver
 
ZKMetadataDriverBase - Class in org.apache.bookkeeper.meta.zk
This is a mixin class for supporting zookeeper based metadata driver.
ZKMetadataDriverBase() - Constructor for class org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase
 
zkPort - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
ZKRegistrationClient - Class in org.apache.bookkeeper.discover
ZooKeeper based RegistrationClient.
ZKRegistrationClient(ZooKeeper, String, ScheduledExecutorService, boolean) - Constructor for class org.apache.bookkeeper.discover.ZKRegistrationClient
 
ZKRegistrationClient.WatchTask - Class in org.apache.bookkeeper.discover
 
ZKRegistrationManager - Class in org.apache.bookkeeper.discover
ZooKeeper Based RegistrationManager.
ZKRegistrationManager(ServerConfiguration, ZooKeeper) - Constructor for class org.apache.bookkeeper.discover.ZKRegistrationManager
 
ZKRegistrationManager(ServerConfiguration, ZooKeeper, String) - Constructor for class org.apache.bookkeeper.discover.ZKRegistrationManager
 
ZkRetryRunnable(RetryPolicy, RateLimiter, OpStatsLogger) - Constructor for class org.apache.bookkeeper.zookeeper.ZooKeeperClient.ZkRetryRunnable
 
zkRun() - Method in class org.apache.bookkeeper.zookeeper.ZooKeeperClient.ZkRetryRunnable
 
zks - Variable in class org.apache.bookkeeper.shims.zk.ZooKeeperServerShimImpl
 
zks - Variable in class org.apache.bookkeeper.util.LocalBookKeeper
 
ZkUtils - Class in org.apache.bookkeeper.util
Provided utilites for zookeeper access, etc.
ZkUtils() - Constructor for class org.apache.bookkeeper.util.ZkUtils
 
ZoneawareEnsemblePlacementPolicy - Class in org.apache.bookkeeper.client
A placement policy implementation use zone information for placing ensembles.
ZoneawareEnsemblePlacementPolicy() - Constructor for class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicy
 
ZoneawareEnsemblePlacementPolicyImpl - Class in org.apache.bookkeeper.client
Simple zoneaware ensemble placement policy.
ZoneawareEnsemblePlacementPolicyImpl() - Constructor for class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl
 
ZoneawareEnsemblePlacementPolicyImpl.ZoneAwareNodeLocation - Class in org.apache.bookkeeper.client
Zone and UpgradeDomain pair of a node.
ZoneAwareNodeLocation(String, String) - Constructor for class org.apache.bookkeeper.client.ZoneawareEnsemblePlacementPolicyImpl.ZoneAwareNodeLocation
 
ZooKeeperClient - Class in org.apache.bookkeeper.zookeeper
Provide a zookeeper client to handle session expire.
ZooKeeperClient(String, int, ZooKeeperWatcherBase, RetryPolicy, RetryPolicy, StatsLogger, int, double, boolean) - Constructor for class org.apache.bookkeeper.zookeeper.ZooKeeperClient
 
ZooKeeperClient.Builder - Class in org.apache.bookkeeper.zookeeper
A builder to build retryable zookeeper client.
ZooKeeperClient.ZkRetryRunnable - Class in org.apache.bookkeeper.zookeeper
A runnable that retries zookeeper operations.
ZooKeeperServerShim - Interface in org.apache.bookkeeper.shims.zk
In order to be compatible with multiple versions of ZooKeeper.
ZooKeeperServerShimFactory - Class in org.apache.bookkeeper.shims.zk
A factory to create zookeeper server.
ZooKeeperServerShimFactory() - Constructor for class org.apache.bookkeeper.shims.zk.ZooKeeperServerShimFactory
 
ZooKeeperServerShimImpl - Class in org.apache.bookkeeper.shims.zk
 
ZooKeeperServerShimImpl() - Constructor for class org.apache.bookkeeper.shims.zk.ZooKeeperServerShimImpl
 
ZooKeeperWatcherBase - Class in org.apache.bookkeeper.zookeeper
Watcher for receiving zookeeper server connection events.
ZooKeeperWatcherBase(int) - Constructor for class org.apache.bookkeeper.zookeeper.ZooKeeperWatcherBase
 
ZooKeeperWatcherBase(int, Set<Watcher>, StatsLogger) - Constructor for class org.apache.bookkeeper.zookeeper.ZooKeeperWatcherBase
 
ZooKeeperWatcherBase(int, StatsLogger) - Constructor for class org.apache.bookkeeper.zookeeper.ZooKeeperWatcherBase
 
ZooWorker - Class in org.apache.bookkeeper.zookeeper
Provide a mechanism to perform an operation on ZooKeeper that is safe on disconnections and recoverable errors.
ZooWorker(RetryPolicy, OpStatsLogger) - Constructor for class org.apache.bookkeeper.zookeeper.ZooWorker
 
ZooWorker.ZooCallable<T> - Interface in org.apache.bookkeeper.zookeeper
 
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