Class and Description |
---|
BloomType |
CompactionRequestor |
FavoredNodesForRegion
Abstraction that allows different modules in RegionServer to update/get
the favored nodes information for regions.
|
FlushRequester
Request a flush.
|
HeapMemoryManager
Manages tuning of Heap memory using
HeapMemoryTuner . |
HRegion |
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
HStore
A Store holds a column family in a Region.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on
HStoreKeys and byte[] instead of RowResults.
|
LastSequenceId
Last flushed sequence Ids for the regions and their stores on region server
|
Leases
Leases
There are several server classes in HBase that need to track external
clients that occasionally send heartbeats.
|
OnlineRegions
Interface to Map of online regions.
|
Region
Regions store data for a certain region of a table.
|
RegionServerAccounting
RegionServerAccounting keeps record of some basic real time information about
the Region Server.
|
RegionServerServices
Services provided by
HRegionServer |
RegionServerServices.PostOpenDeployContext
Context for postOpenDeployTasks().
|
RegionServerServices.RegionStateTransitionContext |
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.
|
Store
Interface for objects that hold a column family in a Region.
|
StoreConfigInformation
A more restricted interface for HStore.
|
StoreFile
A Store data file.
|
Class and Description |
---|
StoreFile
A Store data file.
|
Class and Description |
---|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on
HStoreKeys and byte[] instead of RowResults.
|
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
Class and Description |
---|
RowProcessor
Defines the procedure to atomically perform multiple scans and mutations
on a HRegion.
|
Class and Description |
---|
HRegion |
Region
Regions store data for a certain region of a table.
|
RegionServerServices
Services provided by
HRegionServer |
SplitLogWorker
This worker is spawned in every regionserver, including master.
|
SplitLogWorker.TaskExecutor
Objects implementing this interface actually do the task that has been
acquired by a
SplitLogWorker . |
Class and Description |
---|
BaseRowProcessor
Base class for RowProcessor with some default implementations.
|
DeleteTracker
This interface is used for the tracking and enforcement of Deletes
during the course of a Get or Scan operation.
|
HRegion |
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.
|
MiniBatchOperationInProgress
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
Region
Regions store data for a certain region of a table.
|
Region.Operation
Operation enum is used in
Region.startRegionOperation() to provide context for
various checks before any region operation begins. |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
RegionServerServices
Services provided by
HRegionServer |
RowProcessor
Defines the procedure to atomically perform multiple scans and mutations
on a HRegion.
|
ScanType
Enum to distinguish general scan types.
|
Store
Interface for objects that hold a column family in a Region.
|
StoreFile
A Store data file.
|
StoreFile.Reader
Reader for a StoreFile.
|
Class and Description |
---|
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.
|
ScanInfo
Immutable information for scans over a store.
|
ScanType
Enum to distinguish general scan types.
|
Store
Interface for objects that hold a column family in a Region.
|
Class and Description |
---|
StoreFile.Reader
Reader for a StoreFile.
|
Class and Description |
---|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on
HStoreKeys and byte[] instead of RowResults.
|
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
Class and Description |
---|
FavoredNodesForRegion
Abstraction that allows different modules in RegionServer to update/get
the favored nodes information for regions.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
LastSequenceId
Last flushed sequence Ids for the regions and their stores on region server
|
OnlineRegions
Interface to Map of online regions.
|
RegionOpeningState |
RegionServerServices
Services provided by
HRegionServer |
RSRpcServices
Implements the regionserver RPC services.
|
Class and Description |
---|
Region
Regions store data for a certain region of a table.
|
Class and Description |
---|
RegionServerServices
Services provided by
HRegionServer |
Class and Description |
---|
Region
Regions store data for a certain region of a table.
|
RegionServerServices
Services provided by
HRegionServer |
Class and Description |
---|
RegionOpeningState |
Class and Description |
---|
Region
Regions store data for a certain region of a table.
|
RegionServerServices
Services provided by
HRegionServer |
Class and Description |
---|
BloomType |
ChangedReadersObserver
If set of MapFile.Readers in Store change, implementors are notified.
|
ColumnCount
Simple wrapper for a byte buffer and a counter.
|
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 |
CompactSplitThread
Compact region on request and then run split if appropriate
|
DefaultStoreEngine
Default StoreEngine creates the default compactor, policy, and store file manager, or
their derivatives.
|
DefaultStoreFlusher
Default implementation of StoreFlusher.
|
DeleteTracker
This interface is used for the tracking and enforcement of Deletes
during the course of a Get or Scan operation.
|
DeleteTracker.DeleteCompare
Return codes for comparison of two Deletes.
|
DeleteTracker.DeleteResult
Returns codes for delete result.
|
FavoredNodesForRegion
Abstraction that allows different modules in RegionServer to update/get
the favored nodes information for regions.
|
FlushPolicy
A flush policy determines the stores that need to be flushed when flushing a region.
|
FlushRequester
Request a flush.
|
FlushRequestListener
Listener which will get notified regarding flush requests of regions.
|
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.
|
HeapMemoryTuner
Makes the decision regarding proper sizing of the heap memory.
|
HRegion |
HRegion.RowLockImpl |
HRegionFileSystem
View to an on-disk Region.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
HStore
A Store holds a column family in a Region.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on
HStoreKeys and byte[] instead of RowResults.
|
KeyValueHeap
Implements a heap merge across any number of KeyValueScanners.
|
KeyValueHeap.KVScannerComparator |
KeyValueScanner
Scanner that returns the next KeyValue.
|
LastSequenceId
Last flushed sequence Ids for the regions and their stores on region server
|
LeaseException
Reports a problem with a lease
|
LeaseListener
LeaseListener is an interface meant to be implemented by users of the Leases
class.
|
Leases
Leases
There are several server classes in HBase that need to track external
clients that occasionally send heartbeats.
|
Leases.LeaseStillHeldException
Thrown if we are asked to create a lease but lease on passed name already
exists.
|
LogRoller
Runs periodically to determine if the WAL should be rolled.
|
LruHashMap.Entry
Entry to store key/value mappings.
|
MemStore
The MemStore holds in-memory modifications to the Store.
|
MemStoreLAB
A memstore-local allocation buffer.
|
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).
|
MetricsRegionAggregateSource
This interface will be implemented by a MetricsSource that will export metrics from
multiple regions into the hadoop metrics system.
|
MetricsRegionAggregateSourceImpl |
MetricsRegionServer
This class is for maintaining the various regionserver statistics
and publishing them through the metrics interfaces.
|
MetricsRegionServerSource
Interface for classes that expose metrics about the regionserver.
|
MetricsRegionServerSourceFactory
Interface of a factory to create Metrics Sources used inside of regionservers.
|
MetricsRegionServerSourceFactoryImpl.FactoryStorage |
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
|
MiniBatchOperationInProgress
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.
|
NoSuchColumnFamilyException
Thrown if request for nonexistent column family.
|
OnlineRegions
Interface to Map of online regions.
|
OperationStatus
This class stores the Operation status code and the exception message
that occurs in case of failure of operations like put, delete, etc.
|
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.FlushResult.Result |
Region.Operation
Operation enum is used in
Region.startRegionOperation() to provide context for
various checks before any region operation begins. |
Region.RowLock
Row lock held by a given thread.
|
RegionAlreadyInTransitionException
This exception is thrown when a region server is asked to open or close
a region but it's already processing it
|
RegionCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors
loaded within a
Region . |
RegionMergeTransaction
Executes region merge as a "transaction".
|
RegionMergeTransaction.JournalEntry
Split transaction journal entry
|
RegionMergeTransaction.RegionMergeTransactionPhase
Each enum is a step in the merge transaction.
|
RegionMergeTransaction.TransactionListener
Split transaction listener
|
RegionMergeTransactionImpl |
RegionOpeningState |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
RegionServerAccounting
RegionServerAccounting keeps record of some basic real time information about
the Region Server.
|
RegionServerCoprocessorHost |
RegionServerServices
Services provided by
HRegionServer |
RegionServerServices.PostOpenDeployContext
Context for postOpenDeployTasks().
|
RegionServerServices.RegionStateTransitionContext |
RegionServerStoppedException
Thrown by the region server when it is in shutting down state.
|
RegionSplitPolicy
A split policy determines when a region should be split.
|
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
Defines the procedure to atomically perform multiple scans and mutations
on a HRegion.
|
RpcSchedulerFactory
A factory class that constructs an
RpcScheduler . |
RSRpcServices
Implements the regionserver RPC services.
|
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 |
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) |
ScanQueryMatcher
A query matcher that is specifically designed for the scan case.
|
ScanQueryMatcher.MatchCode
ScanQueryMatcher.match(org.apache.hadoop.hbase.Cell) return codes. |
ScanType
Enum to distinguish general scan types.
|
SequenceId
Interface which abstracts implementations on log sequenceId assignment
|
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.
|
SplitLogWorker.TaskExecutor
Objects implementing this interface actually do the task that has been
acquired by a
SplitLogWorker . |
SplitLogWorker.TaskExecutor.Status |
SplitTransaction
Executes region split as a "transaction".
|
SplitTransaction.JournalEntry
Split transaction journal entry
|
SplitTransaction.SplitTransactionPhase
Each enum is a step in the split transaction.
|
SplitTransaction.TransactionListener
Split transaction listener
|
SplitTransactionImpl |
StatefulStoreMockMaker
This class is a helper that allows to create a partially-implemented, stateful mocks of
Store.
|
Store
Interface for objects that hold a column family in a Region.
|
StoreConfigInformation
A more restricted interface for HStore.
|
StoreEngine
StoreEngine is a factory that can create the objects necessary for HStore to operate.
|
StoreFile
A Store data file.
|
StoreFile.Reader
Reader for a StoreFile.
|
StoreFile.Writer
A StoreFile writer.
|
StoreFile.WriterBuilder |
StoreFileInfo
Describe a StoreFile (hfile, reference, link)
|
StoreFileManager
Manages the store files and basic metadata about that that determines the logical structure
(e.g.
|
StoreFileScanner
KeyValueScanner adaptor over the Reader.
|
StoreScanner
Scanner scans both the memstore and the Store.
|
StripeMultiFileWriter
Base class for cell sink that separates the provided cells into multiple files.
|
StripeMultiFileWriter.WriterFactory |
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.StripeFlushRequest
Stripe flush request wrapper that writes a non-striped file.
|
TestCompaction
Test compaction framework and common functions
|
TestCompaction.BlockingStoreMockMaker.BlockingCompactionContext |
TestRegionMergeTransactionOnCluster
Like
TestRegionMergeTransaction in that we're testing
RegionMergeTransactionImpl only the below tests are against a running
cluster where TestRegionMergeTransaction is tests against bare
HRegion . |
TestSplitTransactionOnCluster
Like TestSplitTransaction in that we're testing
SplitTransactionImpl
only the below tests are against a running cluster where TestSplitTransaction
is tests against a bare HRegion . |
TimeRangeTracker
Stores the minimum and maximum timestamp values (both are inclusive).
|
UnexpectedStateException |
Class and Description |
---|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on
HStoreKeys and byte[] instead of RowResults.
|
RegionServerServices
Services provided by
HRegionServer |
ScanType
Enum to distinguish general scan types.
|
Store
Interface for objects that hold a column family in a Region.
|
StoreConfigInformation
A more restricted interface for HStore.
|
StoreFile
A Store data file.
|
StoreFileScanner
KeyValueScanner adaptor over the Reader.
|
StripeStoreConfig
Configuration class for stripe store and compactions.
|
StripeStoreFlusher.StripeFlushRequest
Stripe flush request wrapper that writes a non-striped file.
|
Class and Description |
---|
HRegion |
KeyValueScanner
Scanner that returns the next KeyValue.
|
RegionServerServices
Services provided by
HRegionServer |
SplitLogWorker.TaskExecutor
Objects implementing this interface actually do the task that has been
acquired by a
SplitLogWorker . |
Class and Description |
---|
Region
Regions store data for a certain region of a table.
|
RegionServerServices
Services provided by
HRegionServer |
Class and Description |
---|
DefaultStoreFlusher
Default implementation of StoreFlusher.
|
MemStoreSnapshot
Holds details of the snapshot taken on a MemStore.
|
SequenceId
Interface which abstracts implementations on log sequenceId assignment
|
Store
Interface for objects that hold a column family in a Region.
|
Class and Description |
---|
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.
|
Class and Description |
---|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on
HStoreKeys and byte[] instead of RowResults.
|
MiniBatchOperationInProgress
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
Region
Regions store data for a certain region of a table.
|
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
ScanType
Enum to distinguish general scan types.
|
Store
Interface for objects that hold a column family in a Region.
|
Class and Description |
---|
DeleteTracker
This interface is used for the tracking and enforcement of Deletes
during the course of a Get or Scan operation.
|
DeleteTracker.DeleteResult
Returns codes for delete result.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on
HStoreKeys and byte[] instead of RowResults.
|
MiniBatchOperationInProgress
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
OperationStatus
This class stores the Operation status code and the exception message
that occurs in case of failure of operations like put, delete, etc.
|
Region
Regions store data for a certain region of a table.
|
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
ScanDeleteTracker
This class is responsible for the tracking and enforcement of Deletes
during the course of a Scan operation.
|
Class and Description |
---|
HRegion |
Class and Description |
---|
MiniBatchOperationInProgress
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
Class and Description |
---|
BloomType |
HRegion |
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
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.
|
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.
|
ScanType
Enum to distinguish general scan types.
|
Store
Interface for objects that hold a column family in a Region.
|
StoreFileInfo
Describe a StoreFile (hfile, reference, link)
|
Class and Description |
---|
LastSequenceId
Last flushed sequence Ids for the regions and their stores on region server
|
SequenceId
Interface which abstracts implementations on log sequenceId assignment
|
Class and Description |
---|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|