Package org.apache.hadoop.hbase.regionserver

Interface Summary
ChangedReadersObserver If set of MapFile.Readers in Store change, implementors are notified.
ColumnTracker Implementing classes of this interface will be used for the tracking and enforcement of columns and numbers of versions and timeToLive during the course of a Get or Scan operation.
CompactionRequestor  
DeleteTracker This interface is used for the tracking and enforcement of Deletes during the course of a Get or Scan operation.
FlushRequester Request a flush.
HRegion.BulkLoadListener Listener class to enable callers of bulkLoadHFile() to perform any necessary pre/post processing of a given bulkload call
InternalScanner Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.
KeyValueScanner Scanner that returns the next KeyValue.
LastSequenceId Last flushed sequence Ids for the regions on region server
LeaseListener LeaseListener is an interface meant to be implemented by users of the Leases class.
MetricsRegionAggregateSource This interface will be implemented by a MetricsSource that will export metrics from multiple regions into the hadoop metrics system.
MetricsRegionServerSource Interface for classes that expose metrics about the regionserver.
MetricsRegionServerSourceFactory Interface of a factory to create Metrics Sources used inside of regionservers.
MetricsRegionServerWrapper This is the interface that will expose RegionServer information to hadoop1/hadoop2 implementations of the MetricsRegionServerSource.
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.
MetricsRegionWrapper Interface of class that will wrap an HRegion and export numbers so they can be used in MetricsRegionSource
RegionScanner RegionScanner describes iterators over rows in an HRegion.
RegionServerServices Services provided by HRegionServer
ReplicationService Gateway to Cluster Replication.
ReplicationSinkService A sink for a replication stream has to expose this service.
ReplicationSourceService A source for a replication stream has to expose this service.
RowProcessor<S extends Message,T extends Message> Defines the procedure to atomically perform multiple scans and mutations on a HRegion.
RpcSchedulerFactory A factory class that constructs an RpcScheduler for a region server.
SplitLogWorker.TaskExecutor Objects implementing this interface actually do the task that has been acquired by a SplitLogWorker.
Store Interface for objects that hold a column family in a Region.
StoreConfigInformation A more restricted interface for HStore.
StoreFileManager Manages the store files and basic metadata about that that determines the logical structure (e.g.
StripeMultiFileWriter.WriterFactory  
 

Class Summary
BaseRowProcessor<S extends Message,T extends Message> Base class for RowProcessor with some default implementations.
ColumnCount Simple wrapper for a byte buffer and a counter.
CompactionTool  
CompactSplitThread Compact region on request and then run split if appropriate
ConstantSizeRegionSplitPolicy A RegionSplitPolicy implementation which splits a region as soon as any of its store files exceeds a maximum configurable size.
DefaultStoreEngine Default StoreEngine creates the default compactor, policy, and store file manager, or their derivatives.
DefaultStoreFlusher Default implementation of StoreFlusher.
DelimitedKeyPrefixRegionSplitPolicy A custom RegionSplitPolicy implementing a SplitPolicy that groups rows by a prefix of the row-key with a delimiter.
DisabledRegionSplitPolicy A RegionSplitPolicy that disables region splits.
ExplicitColumnTracker This class is used for the tracking and enforcement of columns and numbers of versions during the course of a Get or Scan operation, when explicit column qualifiers have been asked for in the query.
HeapMemoryManager Manages heap memory related tasks.
HRegion HRegion stores data for a certain region of a table.
HRegion.FlushResult Objects from this class are created when flushing to describe all the different states that that method ends up in.
HRegion.RowLock Row lock held by a given thread.
HRegionFileSystem View to an on-disk Region.
HRegionServer HRegionServer makes a set of HRegions available to clients.
HRegionServer.MovedRegionsCleaner Creates a Chore thread to clean the moved region cache.
HRegionServerCommandLine Class responsible for parsing the command line and starting the RegionServer.
HStore A Store holds a column family in a Region.
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.
InternalScan Special scanner, currently used for increment operations to allow additional server-side arguments for Scan operations.
KeyPrefixRegionSplitPolicy A custom RegionSplitPolicy implementing a SplitPolicy that groups rows by a prefix of the row-key This ensures that a region is not split "inside" a prefix of a row key.
KeyValueHeap Implements a heap merge across any number of KeyValueScanners.
KeyValueHeap.KVScannerComparator  
KeyValueSkipListSet A Set of KeyValues implemented on top of a ConcurrentSkipListMap.
Leases Leases There are several server classes in HBase that need to track external clients that occasionally send heartbeats.
LruHashMap<K extends HeapSize,V extends HeapSize> The LruHashMap is a memory-aware HashMap with a configurable maximum memory footprint.
LruHashMap.Entry<K extends HeapSize,V extends HeapSize> Entry to store key/value mappings.
MemStore The MemStore holds in-memory modifications to the Store.
MemStoreChunkPool A pool of MemStoreLAB.Chunk instances.
MemStoreLAB A memstore-local allocation buffer.
MemStoreLAB.Allocation The result of a single allocation.
MetricsRegion This is the glue between the HRegion and whatever hadoop shim layer is loaded (hbase-hadoop1-compat or hbase-hadoop2-compat).
MetricsRegionAggregateSourceImpl  
MetricsRegionServer This class is for maintaining the various regionserver statistics and publishing them through the metrics interfaces.
MetricsRegionServerSourceFactoryImpl Factory to create MetricsRegionServerSource when given a MetricsRegionServerWrapper
MetricsRegionServerSourceImpl Hadoop2 implementation of MetricsRegionServerSource.
MetricsRegionSourceImpl  
MetricsRegionWrapperImpl  
MiniBatchOperationInProgress<T> Wraps together the mutations which are applied as a batch to the region and their operation status and WALEdits.
MultiVersionConsistencyControl Manages the read/write consistency within memstore.
MultiVersionConsistencyControl.WriteEntry  
NonLazyKeyValueScanner A "non-lazy" scanner which always does a real seek operation.
NonReversedNonLazyKeyValueScanner A "non-reversed & non-lazy" scanner which does not support backward scanning and always does a real seek operation.
OperationStatus This class stores the Operation status code and the exception message that occurs in case of failure of operations like put, delete, etc.
RegionCoprocessorHost Implements the coprocessor environment and runtime support for coprocessors loaded within a HRegion.
RegionMergeTransaction Executes region merge as a "transaction".
RegionServerAccounting RegionServerAccounting keeps record of some basic real time information about the Region Server.
RegionServerCoprocessorHost  
RegionSplitPolicy A split policy determines when a region should be split.
ReversedKeyValueHeap ReversedKeyValueHeap is used for supporting reversed scanning.
RSDumpServlet  
RSStatusServlet  
ScanDeleteTracker This class is responsible for the tracking and enforcement of Deletes during the course of a Scan operation.
ScanInfo Immutable information for scans over a store.
ScanQueryMatcher A query matcher that is specifically designed for the scan case.
ScanWildcardColumnTracker Keeps track of the columns for a scan if they are not explicitly specified
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.
ShutdownHook Manage regionserver shutdown hooks.
SimpleRpcSchedulerFactory Constructs a SimpleRpcScheduler.
SplitLogWorker This worker is spawned in every regionserver (should we also spawn one in the master?).
SplitTransaction Executes region split as a "transaction".
StoreEngine<SF extends StoreFlusher,CP extends CompactionPolicy,C extends Compactor,SFM extends StoreFileManager> StoreEngine is a factory that can create the objects necessary for HStore to operate.
StoreFile A Store data file.
StoreFile.Comparators Useful comparators for comparing StoreFiles.
StoreFile.Reader Reader for a StoreFile.
StoreFile.Writer A StoreFile writer.
StoreFile.WriterBuilder  
StoreFileInfo Describe a StoreFile (hfile, reference, link)
StoreFileScanner KeyValueScanner adaptor over the Reader.
StoreScanner Scanner scans both the memstore and the Store.
StoreUtils Utility functions for region server storage layer.
StripeMultiFileWriter Base class for cell sink that separates the provided cells into multiple files.
StripeMultiFileWriter.BoundaryMultiWriter MultiWriter that separates the cells based on fixed row-key boundaries.
StripeMultiFileWriter.SizeMultiWriter MultiWriter that separates the cells based on target cell number per file and file count.
StripeStoreConfig Configuration class for stripe store and compactions.
StripeStoreEngine The storage engine that implements the stripe-based store/compaction scheme.
StripeStoreFileManager Stripe implementation of StoreFileManager.
StripeStoreFlusher Stripe implementation of StoreFlusher.
StripeStoreFlusher.BoundaryStripeFlushRequest Stripe flush request wrapper based on boundaries.
StripeStoreFlusher.SizeStripeFlushRequest Stripe flush request wrapper based on size.
StripeStoreFlusher.StripeFlushRequest Stripe flush request wrapper that writes a non-striped file.
TimeRangeTracker Stores the minimum and maximum timestamp values (both are inclusive).
 

Enum Summary
BloomType  
DeleteTracker.DeleteCompare Return codes for comparison of two Deletes.
DeleteTracker.DeleteResult Returns codes for delete result.
HRegion.Operation Operation enum is used in HRegion.startRegionOperation() to provide operation context for startRegionOperation to possibly invoke different checks before any region operations.
MetricsRegionServerSourceFactoryImpl.FactoryStorage  
RegionOpeningState  
ScanQueryMatcher.MatchCode ScanQueryMatcher.match(org.apache.hadoop.hbase.KeyValue) return codes.
ScanType Enum to distinguish general scan types.
SplitLogWorker.TaskExecutor.Status  
 

Exception Summary
LeaseException Reports a problem with a lease
Leases.LeaseStillHeldException Thrown if we are asked create a lease but lease on passed name already exists.
NoSuchColumnFamilyException Thrown if request for nonexistent column family.
RegionAlreadyInTransitionException This exception is thrown when a region server is asked to open or close a region but it's already processing it
RegionServerRunningException Thrown if the region server log directory exists (which indicates another region server is running at the same address)
RegionServerStoppedException Thrown by the region server when it is in shutting down state.
WrongRegionException Thrown when a request contains a key which is not part of this region
 

Annotation Types Summary
HRegionServer.QosPriority  
 



Copyright © 2015 The Apache Software Foundation. All rights reserved.