Package org.apache.hadoop.hbase.regionserver


package org.apache.hadoop.hbase.regionserver
  • Class
    Description
    org.apache.hadoop.hbase.regionserver.AbstractMemStore
    An abstract class, which implements the behaviour shared by all concrete memstore instances.
    org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
    Base class for cell sink that separates the provided cells into multiple files.
    org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter.WriterFactory
     
    org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
    Adaptive is a heuristic that chooses whether to apply data compaction or not based on the level of redundancy in the data.
    org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategy
    Basic strategy chooses between two actions: flattening a segment or merging indices of all segments in the pipeline.
    org.apache.hadoop.hbase.regionserver.BloomType
     
    org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
    Manage the bootstrap node list at region server side.
    org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
    This Chore, every time it runs, will clear the unsused HFiles in the data folder.
    org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
    This class represents a split policy which makes the split decision based on how busy a region is.
    org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
    ByteBuffer based cell which has the chunkid at the 0th offset
    org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
    CellArrayImmutableSegment extends the API supported by a Segment, and ImmutableSegment.
    org.apache.hadoop.hbase.regionserver.CellArrayMap<T extends org.apache.hadoop.hbase.Cell>
    CellArrayMap is a simple array of Cells and cannot be allocated off-heap.
    org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
    CellChunkImmutableSegment extends the API supported by a Segment, and ImmutableSegment.
    org.apache.hadoop.hbase.regionserver.CellChunkMap<T extends org.apache.hadoop.hbase.Cell>
    CellChunkMap is an array of serialized representations of Cell (pointing to Chunks with full Cell data) and can be allocated both off-heap and on-heap.
    org.apache.hadoop.hbase.regionserver.CellFlatMap<T extends org.apache.hadoop.hbase.Cell>
    CellFlatMap stores a constant number of elements and is immutable after creation stage.
    org.apache.hadoop.hbase.regionserver.CellSet<T extends org.apache.hadoop.hbase.Cell>
    A Set of Cells, where an add will overwrite the entry if already exists in the set.
    org.apache.hadoop.hbase.regionserver.CellSink
    A sink of cells that allows appending cells to the Writers that implement it.
    org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
    If set of MapFile.Readers in Store change, implementors are notified.
    org.apache.hadoop.hbase.regionserver.Chunk
    A chunk of memory out of which allocations are sliced.
    org.apache.hadoop.hbase.regionserver.ChunkCreator
    Does the management of memstoreLAB chunk creations.
    org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
    Types of chunks, based on their sizes
    org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler
    Event handler that handles the removal and archival of the compacted hfiles
    org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
    A chore service that periodically cleans up the compacted files when there are no active readers using those compacted files and also helps in clearing the block cache of these compacted file entries.
    org.apache.hadoop.hbase.regionserver.CompactingMemStore
    A memstore implementation which supports in-memory compaction.
    org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
    Types of indexes (part of immutable segments) to be used after flattening, compaction, or merge are applied.
    org.apache.hadoop.hbase.regionserver.CompactionPipeline
    The compaction pipeline of a CompactingMemStore, is a FIFO queue of segments.
    org.apache.hadoop.hbase.regionserver.CompactionTool
     
    org.apache.hadoop.hbase.regionserver.CompactSplit
    Compact region on request and then run split if appropriate
    org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionCompleteTracker
     
    org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
    The CompositeImmutableSegments is created as a collection of ImmutableSegments and supports the interface of a single ImmutableSegments.
    org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
    A RegionSplitPolicy implementation which splits a region as soon as any of its store files exceeds a maximum configurable size.
    org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
     
    org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
    CSLMImmutableSegment is an abstract class that extends the API supported by a Segment, and ImmutableSegment.
    org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
    Helper class for CP hooks to change max versions and TTL.
    org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
    class for cell sink that separates the provided cells into multiple files for date tiered compaction.
    org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
    HBASE-15400 This store engine allows us to store data in date tiered layout with exponential sizing so that the more recent data has more granularity.
    org.apache.hadoop.hbase.regionserver.DefaultMemStore
    The MemStore holds in-memory modifications to the Store.
    org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
    Default StoreEngine creates the default compactor, policy, and store file manager, or their derivatives.
    org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
    Default implementation of StoreFlusher.
    org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestriction
    A RegionSplitRestriction implementation that groups rows by a prefix of the row-key with a delimiter.
    org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
    A RegionSplitPolicy that disables region splits.
    org.apache.hadoop.hbase.regionserver.DumpRegionServerMetrics
    Utility for doing JSON and MBeans.
    org.apache.hadoop.hbase.regionserver.EagerMemStoreCompactionStrategy
     
    org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
    Abstraction that allows different modules in RegionServer to update/get the favored nodes information for regions.
    org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
    Factory to use when you want to use the FifoRpcScheduler
    org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy
    A FlushPolicy that only flushes store larger a given threshold.
    org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
    A FlushPolicy that always flushes all stores for a given region.
    org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
    A FlushPolicy that only flushes store larger a given threshold.
    org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker
    Used to track flush execution.
    org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy
    A FlushPolicy that only flushes store larger than a given threshold.
    org.apache.hadoop.hbase.regionserver.FlushPolicy
    A flush policy determines the stores that need to be flushed when flushing a region.
    org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
    The class that creates a flush policy from a conf and HTableDescriptor.
    org.apache.hadoop.hbase.regionserver.FlushRegionCallable
     
    org.apache.hadoop.hbase.regionserver.FlushRequester
    Request a flush.
    org.apache.hadoop.hbase.regionserver.FlushRequestListener
    Listener which will get notified regarding flush requests of regions.
    org.apache.hadoop.hbase.regionserver.HeapMemoryManager
    Manages tuning of Heap memory using HeapMemoryTuner.
    org.apache.hadoop.hbase.regionserver.HeapMemoryManager.HeapMemoryTuneObserver
    Every class that wants to observe heap memory tune actions must implement this interface.
    org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
    POJO to pass all the relevant information required to do the heap memory tuning.
    org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
    POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.
    org.apache.hadoop.hbase.regionserver.HeapMemoryTuner
    Makes the decision regarding proper sizing of the heap memory.
    org.apache.hadoop.hbase.regionserver.HMobStore
    The store implementation to save MOBs (medium objects), it extends the HStore.
    org.apache.hadoop.hbase.regionserver.HRegion
    Regions store data for a certain region of a table.
    org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
    Listener class to enable callers of bulkLoadHFile() to perform any necessary pre/post processing of a given bulkload call
    org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
     
    org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
     
    org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
    Objects from this class are created when flushing to describe all the different states that that method ends up in.
    org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
    A result object from prepare flush cache stage
    org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
    Class used to represent a lock on a row.
    org.apache.hadoop.hbase.regionserver.HRegionFileSystem
    View to an on-disk Region.
    org.apache.hadoop.hbase.regionserver.HRegionServer
    HRegionServer makes a set of HRegions available to clients.
    org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
    Class responsible for parsing the command line and starting the RegionServer.
    org.apache.hadoop.hbase.regionserver.HRegionWALFileSystem
    A Wrapper for the region FileSystem operations adding WAL specific operations
    org.apache.hadoop.hbase.regionserver.HStore
    A Store holds a column family in a Region.
    org.apache.hadoop.hbase.regionserver.HStoreFile
    A Store data file.
    org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
    A MemStoreLAB implementation which wraps N MemStoreLABs.
    org.apache.hadoop.hbase.regionserver.ImmutableSegment
    ImmutableSegment is an abstract class that extends the API supported by a Segment, and is not needed for a MutableSegment.
    org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
    Split size is the number of regions that are on this server that all are of the same table, cubed, times 2x the region flush size OR the maximum region split size, whichever is smaller.
    org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
    Computes the HDFSBlockDistribution for a file based on the underlying located blocks for an HdfsDataInputStream reading that file.
    org.apache.hadoop.hbase.regionserver.InternalScan
    Special scanner, currently used for increment operations to allow additional server-side arguments for Scan operations.
    org.apache.hadoop.hbase.regionserver.InternalScanner
    Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.
    org.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityException
    Thrown if Mutation's Durability is skip wal but table need replication.
    org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
    A RegionSplitRestriction implementation that groups rows by a prefix of the row-key.
    org.apache.hadoop.hbase.regionserver.KeyValueHeap
    Implements a heap merge across any number of KeyValueScanners.
    org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
     
    org.apache.hadoop.hbase.regionserver.KeyValueScanner
    Scanner that returns the next KeyValue.
    org.apache.hadoop.hbase.regionserver.LastSequenceId
    Last flushed sequence Ids for the regions and their stores on region server
    org.apache.hadoop.hbase.regionserver.LeaseException
    Reports a problem with a lease
    org.apache.hadoop.hbase.regionserver.LeaseListener
    LeaseListener is an interface meant to be implemented by users of the Leases class.
    org.apache.hadoop.hbase.regionserver.LeaseManager
    Leases There are several server classes in HBase that need to track external clients that occasionally send heartbeats.
    org.apache.hadoop.hbase.regionserver.LeaseManager.LeaseStillHeldException
    Thrown if we are asked to create a lease but lease on passed name already exists.
    org.apache.hadoop.hbase.regionserver.LogRoller
    Runs periodically to determine if the WAL should be rolled.
    org.apache.hadoop.hbase.regionserver.MasterFifoRpcSchedulerFactory
    Factory to use when you want to use the MasterFifoRpcScheduler
    org.apache.hadoop.hbase.regionserver.MemStore
    The MemStore holds in-memory modifications to the Store.
    org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
    MemStoreCompactionStrategy is the root of a class hierarchy which defines the strategy for choosing the next action to apply in an (in-memory) memstore compaction.
    org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
    Types of actions to be done on the pipeline upon MemStoreCompaction invocation.
    org.apache.hadoop.hbase.regionserver.MemStoreCompactor
    The ongoing MemStore Compaction manager, dispatches a solo running compaction and interrupts the compaction if requested.
    org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
    The MemStoreCompactorSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for compaction operation meaning it is based on SQM
    org.apache.hadoop.hbase.regionserver.MemStoreFlusher
    Thread that flushes cache on request NOTE: This class extends Thread rather than Chore because the sleep time can be interrupted when there is something to do, rather than the Chore sleep time which is invariant.
    org.apache.hadoop.hbase.regionserver.MemStoreLAB
    A memstore-local allocation buffer.
    org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
    A memstore-local allocation buffer.
    org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
    The MemStoreMergerSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for simple merge operation meaning it is NOT based on SQM
    org.apache.hadoop.hbase.regionserver.MemStoreSegmentsIterator
    The MemStoreSegmentsIterator is designed to perform one iteration over given list of segments For another iteration new instance of MemStoreSegmentsIterator needs to be created The iterator is not thread-safe and must have only one instance per MemStore in each period of time
    org.apache.hadoop.hbase.regionserver.MemStoreSize
    Data structure of three longs.
    org.apache.hadoop.hbase.regionserver.MemStoreSizing
    Accounting of current heap and data sizes.
    org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
    MemStoreSnapshot is a Context Object to hold details of the snapshot taken on a MemStore.
    org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
    This class is for maintaining the various regionserver's heap memory manager statistics and publishing them through the metrics interfaces.
    org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
    This interface will be implemented by a MetricsSource that will export metrics from HeapMemoryManager in RegionServer into the hadoop metrics system.
    org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
    Hadoop2 implementation of MetricsHeapMemoryManagerSource.
    org.apache.hadoop.hbase.regionserver.MetricsRegion
    This is the glue between the HRegion and whatever hadoop shim layer is loaded (hbase-hadoop1-compat or hbase-hadoop2-compat).
    org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
    This interface will be implemented by a MetricsSource that will export metrics from multiple regions into the hadoop metrics system.
    org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
     
    org.apache.hadoop.hbase.regionserver.MetricsRegionServer
    Maintains regionserver statistics and publishes them through the metrics interfaces.
    org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
    A collection of exposed metrics for space quotas from an HBase RegionServer.
    org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
    Implementation of MetricsRegionServerQuotaSource.
    org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
    Interface for classes that expose metrics about the regionserver.
    org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
    Interface of a factory to create Metrics Sources used inside of regionservers.
    org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
    Factory to create MetricsRegionServerSource when given a MetricsRegionServerWrapper
    org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
     
    org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
    Hadoop2 implementation of MetricsRegionServerSource.
    org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
    This is the interface that will expose RegionServer information to hadoop1/hadoop2 implementations of the MetricsRegionServerSource.
    org.apache.hadoop.hbase.regionserver.MetricsRegionSource
    This interface will be implemented to allow single regions to push metrics into MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
    org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
     
    org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
    Interface of class that will wrap an HRegion and export numbers so they can be used in MetricsRegionSource
    org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
     
    org.apache.hadoop.hbase.regionserver.MetricsTable
     
    org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
    This interface will be implemented by a MetricsSource that will export metrics from multiple regions of a table into the hadoop metrics system.
    org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
     
    org.apache.hadoop.hbase.regionserver.MetricsTableSource
    This interface will be implemented to allow region server to push table metrics into MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
    org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
     
    org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
    Interface of class that will wrap a MetricsTableSource and export numbers so they can be used in MetricsTableSource
    org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
     
    org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
     
    org.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactory
     
    org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
     
    org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
    This interface will be implemented by a MetricsSource that will export metrics from multiple users into the hadoop metrics system.
    org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
     
    org.apache.hadoop.hbase.regionserver.MetricsUserSource
     
    org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
     
    org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
     
    org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<T>
    Wraps together the mutations which are applied as a batch to the region and their operation status and WALEdits.
    org.apache.hadoop.hbase.regionserver.MobStoreScanner
    Scanner scans both the memstore and the MOB Store.
    org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
    Manages the read/write consistency.
    org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
    Write number and whether write has completed given out at start of a write transaction.
    org.apache.hadoop.hbase.regionserver.MutableOnlineRegions
    Interface to Map of online regions.
    org.apache.hadoop.hbase.regionserver.MutableSegment
    A mutable segment in memstore, specifically the active segment.
    org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
    This is a special ScannerContext subclass that is designed to be used globally when limits should not be enforced during invocations of InternalScanner.next(java.util.List) or InternalScanner.next(java.util.List).
    org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
    A "non-lazy" scanner which always does a real seek operation.
    org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
    A "non-reversed & non-lazy" scanner which does not support backward scanning and always does a real seek operation.
    org.apache.hadoop.hbase.regionserver.NoRegionSplitRestriction
    A RegionSplitRestriction implementation that does nothing.
    org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
    Thrown if request for nonexistent column family.
    org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
    ByteBuffer based cell which has the chunkid at the 0th offset and with no tags
    org.apache.hadoop.hbase.regionserver.OffheapChunk
    An off heap chunk implementation.
    org.apache.hadoop.hbase.regionserver.OnheapChunk
    An on heap chunk implementation.
    org.apache.hadoop.hbase.regionserver.OnlineRegions
    Provides read-only access to the Regions presently online on the current RegionServer
    org.apache.hadoop.hbase.regionserver.OperationStatus
    This class stores the Operation status code and the exception message that occurs in case of failure of operations like put, delete, etc.
    org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier
    Class to submit requests for PrefetchExecutor depending on configuration change
    org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock
    Lock to manage concurrency between RegionScanner and HRegion.getSmallestReadPoint().
    org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock.LockType
     
    org.apache.hadoop.hbase.regionserver.Region
    Region is a subset of HRegion with operations required for the Coprocessors.
    org.apache.hadoop.hbase.regionserver.Region.Operation
    Operation enum is used in Region.startRegionOperation() and elsewhere to provide context for various checks.
    org.apache.hadoop.hbase.regionserver.Region.RowLock
    Row lock held by a given thread.
    org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
    Implements the coprocessor environment and runtime support for coprocessors loaded within a Region.
    org.apache.hadoop.hbase.regionserver.RegionScanner
    RegionScanner describes iterators over rows in an HRegion.
    org.apache.hadoop.hbase.regionserver.RegionServerAbortedException
    Thrown by the region server when it is aborting.
    org.apache.hadoop.hbase.regionserver.RegionServerAccounting
    RegionServerAccounting keeps record of some basic real time information about the Region Server.
    org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
     
    org.apache.hadoop.hbase.regionserver.RegionServerRunningException
    Thrown if the region server log directory exists (which indicates another region server is running at the same address)
    org.apache.hadoop.hbase.regionserver.RegionServerServices
    A curated subset of services provided by HRegionServer.
    org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
    Context for postOpenDeployTasks().
    org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
     
    org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
    Thrown by the region server when it is in shutting down state.
    org.apache.hadoop.hbase.regionserver.RegionServicesForStores
    Services a Store needs from a Region.
    org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
    A split policy determines when a Region should be split.
    org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
    A split restriction that restricts the pattern of the split point.
    org.apache.hadoop.hbase.regionserver.ReplicationService
    Gateway to Cluster Replication.
    org.apache.hadoop.hbase.regionserver.ReplicationSinkService
    A sink for a replication stream has to expose this service.
    org.apache.hadoop.hbase.regionserver.ReplicationSourceService
    A source for a replication stream has to expose this service.
    org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
    ReversedKeyValueHeap is used for supporting reversed scanning.
    org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
    ReversedMobStoreScanner extends from ReversedStoreScanner, and is used to support reversed scanning in both the memstore and the MOB store.
    org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
    ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.
    org.apache.hadoop.hbase.regionserver.RowTooBigException
    Deprecated.
    since 0.99.0.
    org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
    A factory class that constructs an RpcScheduler.
    org.apache.hadoop.hbase.regionserver.RSRpcServices
    Implements the regionserver RPC services.
    org.apache.hadoop.hbase.regionserver.RSSnapshotVerifier
    Used by SnapshotVerifyProcedure to verify if the region info and store file info in RegionManifest are intact.
    org.apache.hadoop.hbase.regionserver.ScanInfo
    Immutable information for scans over a store.
    org.apache.hadoop.hbase.regionserver.ScannerContext
    ScannerContext instances encapsulate limit tracking AND progress towards those limits during invocations of InternalScanner.next(java.util.List) and InternalScanner.next(java.util.List).
    org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
     
    org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
    The various scopes where a limit can be enforced.
    org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
    The possible states a scanner may be in following a call to InternalScanner.next(List)
    org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
    Generate a new style scanner id to prevent collision with previous started server or other RSs.
    org.apache.hadoop.hbase.regionserver.ScanOptions
    This class gives you the ability to change the max versions and TTL options before opening a scanner for a Store.
    org.apache.hadoop.hbase.regionserver.ScanType
    Enum to distinguish general scan types.
    org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
    Bulk loads in secure mode.
    org.apache.hadoop.hbase.regionserver.Segment
    This is an abstraction of a segment maintained in a memstore, e.g., the active cell set or its snapshot.
    org.apache.hadoop.hbase.regionserver.SegmentFactory
    A singleton store segment factory.
    org.apache.hadoop.hbase.regionserver.SegmentScanner
    A scanner of a single memstore segment.
    org.apache.hadoop.hbase.regionserver.SequenceId
    Interface which abstracts implementations on log sequenceId assignment
    org.apache.hadoop.hbase.regionserver.ServerNonceManager
    Implementation of nonce manager that stores nonces in a hash map and cleans them up after some time; if nonce group/client ID is supplied, nonces are stored by client ID.
    org.apache.hadoop.hbase.regionserver.Shipper
    This interface denotes a scanner as one which can ship cells.
    org.apache.hadoop.hbase.regionserver.ShipperListener
    Implementors of this interface are the ones who needs to do some action when the Shipper.shipped() is called
    org.apache.hadoop.hbase.regionserver.ShutdownHook
    Manage regionserver shutdown hooks.
    org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
    Constructs a SimpleRpcScheduler.
    org.apache.hadoop.hbase.regionserver.SnapshotRegionCallable
     
    org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
    A basic SegmentScanner used against an ImmutableScanner snapshot Used flushing where we do a single pass, no reverse scanning or inserts happening.
    org.apache.hadoop.hbase.regionserver.SnapshotVerifyCallable
     
    org.apache.hadoop.hbase.regionserver.SplitLogWorker
    Deprecated.
    since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALRemoteProcedure
    org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor
    Objects implementing this interface actually do the task that has been acquired by a SplitLogWorker.
    org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
     
    org.apache.hadoop.hbase.regionserver.SplitWALCallable
    This callable is used to do the real split WAL task.
    org.apache.hadoop.hbase.regionserver.SplitWALCallable.ErrorWALSplitException
     
    org.apache.hadoop.hbase.regionserver.SplitWALCallable.PreemptedWALSplitException
     
    org.apache.hadoop.hbase.regionserver.SplitWALCallable.ResignedWALSplitException
     
    org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy
     
    org.apache.hadoop.hbase.regionserver.Store
    Interface for objects that hold a column family in a Region.
    org.apache.hadoop.hbase.regionserver.StoreConfigInformation
    A more restricted interface for HStore.
    org.apache.hadoop.hbase.regionserver.StoreContext
    This carries the immutable information and references on some of the meta data about the HStore.
    org.apache.hadoop.hbase.regionserver.StoreContext.Builder
     
    org.apache.hadoop.hbase.regionserver.StoreEngine<SF extends org.apache.hadoop.hbase.regionserver.StoreFlusher,CP extends org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy,C extends org.apache.hadoop.hbase.regionserver.compactions.Compactor<?>,SFM extends org.apache.hadoop.hbase.regionserver.StoreFileManager>
    StoreEngine is a factory that can create the objects necessary for HStore to operate.
    org.apache.hadoop.hbase.regionserver.StoreFile
    An interface to describe a store data file.
    org.apache.hadoop.hbase.regionserver.StoreFileInfo
    Describe a StoreFile (hfile, reference, link)
    org.apache.hadoop.hbase.regionserver.StoreFileManager
    Manages the store files and basic metadata about that that determines the logical structure (e.g.
    org.apache.hadoop.hbase.regionserver.StoreFileReader
    Reader for a StoreFile.
    org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
    A chore for refreshing the store files for secondary regions hosted in the region server.
    org.apache.hadoop.hbase.regionserver.StoreFileScanner
    KeyValueScanner adaptor over the Reader.
    org.apache.hadoop.hbase.regionserver.StoreFileWriter
    A StoreFile writer.
    org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
     
    org.apache.hadoop.hbase.regionserver.StoreScanner
    Scanner scans both the memstore and the Store.
    org.apache.hadoop.hbase.regionserver.StoreUtils
    Utility functions for region server storage layer.
    org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
    Base class for cell sink that separates the provided cells into multiple files for stripe compaction.
    org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
    MultiWriter that separates the cells based on fixed row-key boundaries.
    org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
    MultiWriter that separates the cells based on target cell number per file and file count.
    org.apache.hadoop.hbase.regionserver.StripeStoreConfig
    Configuration class for stripe store and compactions.
    org.apache.hadoop.hbase.regionserver.StripeStoreEngine
    The storage engine that implements the stripe-based store/compaction scheme.
    org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
    Stripe implementation of StoreFileManager.
    org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
    Stripe implementation of StoreFlusher.
    org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
    Stripe flush request wrapper based on boundaries.
    org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
    Stripe flush request wrapper based on size.
    org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
    Stripe flush request wrapper that writes a non-striped file.
    org.apache.hadoop.hbase.regionserver.TimeRangeTracker
    Stores minimum and maximum timestamp values, it is [minimumTimestamp, maximumTimestamp] in interval notation.
    org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
     
    org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
     
    org.apache.hadoop.hbase.regionserver.TimeRangeTracker.Type
     
    org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
    A list of segment managers coupled with the version of the memstore (version at the time it was created).
    org.apache.hadoop.hbase.regionserver.WrongRegionException
    Thrown when a request contains a key which is not part of this region