Interface | Description |
---|---|
AbstractMultiFileWriter.WriterFactory | |
ChangedReadersObserver |
If set of MapFile.Readers in Store change, implementors are notified.
|
CompactionRequestor | |
DeleteTracker |
This interface is used for the tracking and enforcement of Deletes during the course of a Get or
Scan operation.
|
FavoredNodesForRegion |
Abstraction that allows different modules in RegionServer to update/get
the favored nodes information for regions.
|
FlushRequester |
Request a flush.
|
FlushRequestListener |
Listener which will get notified regarding flush requests of regions.
|
HeapMemoryTuner |
Makes the decision regarding proper sizing of the heap memory.
|
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 and their stores on region server
|
LeaseListener |
LeaseListener is an interface meant to be implemented by users of the Leases
class.
|
MemStore |
The MemStore holds in-memory modifications to the Store.
|
MemStoreLAB |
A memstore-local allocation buffer.
|
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
|
MetricsTableAggregateSource |
This interface will be implemented by a MetricsSource that will export metrics from
multiple regions of a table into the hadoop metrics system.
|
MetricsTableLatencies |
Latency metrics for a specific table in a RegionServer.
|
MetricsTableQueryMeter |
Query Per Second for each table in a 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.
|
MetricsTableWrapperAggregate |
Interface of class that will wrap a MetricsTableSource and export numbers so they can be
used in MetricsTableSource
|
OnlineRegions |
Interface to Map of online regions.
|
Region |
Regions store data for a certain region of a table.
|
Region.BulkLoadListener |
Listener class to enable callers of
bulkLoadHFile() to perform any necessary
pre/post processing of a given bulkload call
|
Region.FlushResult | |
Region.RowLock |
Row lock held by a given thread.
|
RegionMergeTransaction |
Executes region merge as a "transaction".
|
RegionMergeTransaction.JournalEntry |
Split transaction journal entry
|
RegionMergeTransaction.TransactionListener |
Split transaction listener
|
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 com.google.protobuf.Message,T extends com.google.protobuf.Message> |
Defines the procedure to atomically perform multiple scans and mutations
on a HRegion.
|
RpcSchedulerFactory |
A factory class that constructs an
RpcScheduler . |
SequenceId |
Interface which abstracts implementations on log sequenceId assignment
|
SplitLogWorker.TaskExecutor |
Objects implementing this interface actually do the task that has been
acquired by a
SplitLogWorker . |
SplitTransaction |
Executes region split as a "transaction".
|
SplitTransaction.JournalEntry |
Split transaction journal entry
|
SplitTransaction.TransactionListener |
Split transaction listener
|
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.
|
Class | Description |
---|---|
AbstractMultiFileWriter |
Base class for cell sink that separates the provided cells into multiple files.
|
AnnotationReadingPriorityFunction |
Reads special method annotations and table names to figure a priority for use by QoS facility in
ipc; e.g: rpcs to hbase:meta get priority.
|
BaseRowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
Base class for RowProcessor with some default implementations.
|
BusyRegionSplitPolicy |
This class represents a split policy which makes the split decision based
on how busy a region is.
|
CellSkipListSet | |
CompactedHFilesDischargeHandler |
Event handler that handles the removal and archival of the compacted hfiles
|
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 with these compacted
file entries
|
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. |
DateTieredMultiFileWriter |
class for cell sink that separates the provided cells into multiple files for date tiered
compaction.
|
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.
|
DefaultMemStore |
The MemStore holds in-memory modifications to the Store.
|
DefaultMemStore.MemStoreScanner | |
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. |
FifoRpcSchedulerFactory |
Factory to use when you want to use the
FifoRpcScheduler |
FlushAllStoresPolicy |
A
FlushPolicy that always flushes all stores for a given region. |
FlushLargeStoresPolicy |
A
FlushPolicy that only flushes store larger a given threshold. |
FlushPolicy |
A flush policy determines the stores that need to be flushed when flushing a region.
|
FlushPolicyFactory |
The class that creates a flush policy from a conf and HTableDescriptor.
|
HeapMemoryManager |
Manages tuning of Heap memory using
HeapMemoryTuner . |
HeapMemoryManager.TunerContext |
POJO to pass all the relevant information required to do the heap memory tuning.
|
HeapMemoryManager.TunerResult |
POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.
|
HeapMemStoreLAB |
A memstore-local allocation buffer.
|
HRegion | |
HRegion.FlushResultImpl |
Objects from this class are created when flushing to describe all the different states that
that method ends up in.
|
HRegion.RowLockImpl |
Class used to represent a lock on a row.
|
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 | |
Leases |
Leases
There are several server classes in HBase that need to track external
clients that occasionally send heartbeats.
|
LogRoller |
Runs periodically to determine if the WAL should be rolled.
|
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.
|
MemStoreChunkPool |
A pool of
HeapMemStoreLAB.Chunk instances. |
MemStoreSnapshot |
Holds details of the snapshot taken on a MemStore.
|
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 | |
MetricsTable | |
MetricsTableAggregateSourceImpl | |
MetricsTableLatenciesImpl |
Implementation of
MetricsTableLatencies to track latencies for one table in a
RegionServer. |
MetricsTableLatenciesImpl.TableHistograms | |
MetricsTableQueryMeterImpl |
Implementation of
MetricsTableQueryMeter to track query per second for each table in
a RegionServer. |
MetricsTableSourceImpl | |
MetricsTableWrapperAggregateImpl | |
MiniBatchOperationInProgress<T> |
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
MultiVersionConcurrencyControl |
Manages the read/write consistency.
|
MultiVersionConcurrencyControl.WriteEntry |
Write number and whether write has completed given out at start of a write transaction.
|
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) . |
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.
|
NoOpHeapMemoryTuner |
An implementation of HeapMemoryTuner which is not doing any tuning activity but just allows to
continue with old style fixed proportions.
|
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
Region . |
RegionMergeTransactionFactory |
A factory for creating RegionMergeTransactions, which execute region split as a "transaction".
|
RegionMergeTransactionImpl | |
RegionMergeTransactionImpl.JournalEntryImpl | |
RegionServerAccounting |
RegionServerAccounting keeps record of some basic real time information about
the Region Server.
|
RegionServerCoprocessorHost | |
RegionServerServices.PostOpenDeployContext |
Context for postOpenDeployTasks().
|
RegionServerServices.RegionStateTransitionContext | |
RegionServerTableMetrics |
Captures operation metrics by table.
|
RegionSplitPolicy |
A split policy determines when a region should be split.
|
ReversedKeyValueHeap |
ReversedKeyValueHeap is used for supporting reversed scanning.
|
RSDumpServlet | |
RSRpcServices |
Implements the regionserver RPC services.
|
RSStatusServlet | |
ScanInfo |
Immutable information for scans over a store.
|
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) . |
ScannerContext.Builder | |
ScannerIdGenerator |
Generate a new style scanner id to prevent collision with previous started server or other RSs.
|
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, including master.
|
SplitTransactionFactory |
A factory for creating SplitTransactions, which execute region split as a "transaction".
|
SplitTransactionImpl | |
SplitTransactionImpl.JournalEntryImpl | |
SteppingSplitPolicy | |
StoreEngine<SF extends org.apache.hadoop.hbase.regionserver.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)
|
StorefileRefresherChore |
A chore for refreshing the store files for secondary regions hosted in the region server.
|
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 for stripe
compaction.
|
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 minimum and maximum timestamp values, it is [minimumTimestamp, maximumTimestamp] in
interval notation.
|
Enum | Description |
---|---|
BloomType | |
DeleteTracker.DeleteCompare |
Return codes for comparison of two Deletes.
|
DeleteTracker.DeleteResult |
Returns codes for delete result.
|
MetricsRegionServerSourceFactoryImpl.FactoryStorage | |
Region.FlushResult.Result | |
Region.Operation |
Operation enum is used in
Region.startRegionOperation() to provide context for
various checks before any region operation begins. |
RegionMergeTransaction.RegionMergeTransactionPhase |
Each enum is a step in the merge transaction.
|
RegionOpeningState | |
ScannerContext.LimitScope |
The various scopes where a limit can be enforced.
|
ScannerContext.NextState |
The possible states a scanner may be in following a call to
InternalScanner.next(List) |
ScanType |
Enum to distinguish general scan types.
|
SplitLogWorker.TaskExecutor.Status | |
SplitTransaction.SplitTransactionPhase |
Each enum is a step in the split transaction.
|
Exception | Description |
---|---|
LeaseException |
Reports a problem with a lease
|
Leases.LeaseStillHeldException |
Thrown if we are asked to 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
|
RegionServerAbortedException |
Thrown by the region server when it is aborting.
|
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.
|
RowTooBigException |
Gets or Scans throw this exception if running without in-row scan flag
set and row size appears to exceed max configured size (configurable via
hbase.table.max.rowsize).
|
WrongRegionException |
Thrown when a request contains a key which is not part of this region
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.