Interface | Description |
---|---|
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.
|
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.
|
MemStoreFlusher.FlushQueueEntry | |
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
|
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.
|
StoreFlushContext |
A package protected interface for a store flushing.
|
StripeMultiFileWriter.WriterFactory |
Class | Description |
---|---|
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.
|
CellSkipListSet | |
ColumnCount |
Simple wrapper for a byte buffer and a counter.
|
CompactionTool | |
CompactionTool.CompactionInputFormat |
Input format that uses store files block location as input split locality.
|
CompactionTool.CompactionMapper | |
CompactionTool.CompactionWorker |
Class responsible to execute the Compaction on the specified path.
|
CompactSplitThread |
Compact region on request and then run split if appropriate
|
CompactSplitThread.Rejection |
Cleanup class to use when rejecting a compaction request from the queue.
|
ConstantSizeRegionSplitPolicy |
A
RegionSplitPolicy implementation which splits a region
as soon as any of its store files exceeds a maximum configurable
size. |
DefaultHeapMemoryTuner |
The default implementation for the HeapMemoryTuner.
|
DefaultMemStore |
The MemStore holds in-memory modifications to the Store.
|
DefaultMemStore.Member | |
DefaultStoreEngine |
Default StoreEngine creates the default compactor, policy, and store file manager, or
their derivatives.
|
DefaultStoreFileManager |
Default implementation of StoreFileManager.
|
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.
|
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.
|
GetClosestRowBeforeTracker |
State and utility processing
HRegion.getClosestRowBefore(byte[], byte[]) . |
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.
|
HeapMemStoreLAB.Chunk |
A chunk of memory out of which allocations are sliced.
|
HRegion | |
HRegion.BatchOperationInProgress<T> |
Struct-like class that tracks the progress of a batch operation,
accumulating status codes and tracking the index at which processing
is proceeding.
|
HRegion.FlushResultImpl |
Objects from this class are created when flushing to describe all the different states that
that method ends up in.
|
HRegion.MutationBatch | |
HRegion.PrepareFlushResult |
A result object from prepare flush cache stage
|
HRegion.ReplayBatch | |
HRegion.RowLockImpl |
Class used to represent a lock on a row.
|
HRegion.WriteState | |
HRegionFileSystem |
View to an on-disk Region.
|
HRegionServer |
HRegionServer makes a set of HRegions available to clients.
|
HRegionServer.CompactionChecker | |
HRegionServer.MovedRegionInfo | |
HRegionServer.MovedRegionsCleaner |
Creates a Chore thread to clean the moved region cache.
|
HRegionServer.PeriodicMemstoreFlusher | |
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.
|
Leases.Lease |
This class tracks a single Lease.
|
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. |
MemStoreChunkPool.StatisticsThread | |
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.
|
MemStoreFlusher.FlushRegionEntry |
Datastructure used in the flush queue.
|
MemStoreFlusher.WakeupFlushThread |
Token to insert into the flush queue that ensures that the flusher does not sleep
|
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.
|
MetricsRegionServerWrapperImpl |
Impl for exposing HRegionServer Information through Hadoop's metrics 2 system.
|
MetricsRegionSourceImpl | |
MetricsRegionWrapperImpl | |
MiniBatchOperationInProgress<T> |
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
MultiRowMutationProcessor |
A
MultiRowProcessor that performs multiple puts and deletes. |
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 . |
RegionCoprocessorHost.CoprocessorOperation | |
RegionCoprocessorHost.EndpointOperation | |
RegionCoprocessorHost.EndpointOperationWithResult<T> | |
RegionCoprocessorHost.RegionEnvironment |
Encapsulation of the environment of each coprocessor
|
RegionCoprocessorHost.RegionOperation | |
RegionCoprocessorHost.RegionOperationWithResult<T> | |
RegionCoprocessorHost.TableCoprocessorAttribute | |
RegionMergeRequest |
Handles processing region merges.
|
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 | |
RegionServerCoprocessorHost.CoprocessOperationWithResult<T> | |
RegionServerCoprocessorHost.CoprocessorOperation | |
RegionServerCoprocessorHost.EnvironmentPriorityComparator |
Environment priority comparator.
|
RegionServerCoprocessorHost.RegionServerEnvironment |
Coprocessor environment extension providing access to region server
related services.
|
RegionServerServices.PostOpenDeployContext |
Context for postOpenDeployTasks().
|
RegionServerServices.RegionStateTransitionContext | |
RegionSplitPolicy |
A split policy determines when a region should be split.
|
ReversedKeyValueHeap |
ReversedKeyValueHeap is used for supporting reversed scanning.
|
ReversedKeyValueHeap.ReversedKVScannerComparator |
In ReversedKVScannerComparator, we compare the row of scanners' peek values
first, sort bigger one before the smaller one.
|
ReversedRegionScannerImpl |
ReversibleRegionScannerImpl extends from RegionScannerImpl, and is used to
support reversed scanning.
|
ReversedStoreScanner |
ReversedStoreScanner extends from StoreScanner, and is used to support
reversed scanning.
|
RSDumpServlet | |
RSRpcServices |
Implements the regionserver RPC services.
|
RSRpcServices.RegionScannerHolder |
Holder class which holds the RegionScanner and nextCallSeq together.
|
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.
|
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.LimitFields |
The different fields that can be used as limits in calls to
InternalScanner.next(java.util.List) and InternalScanner.next(java.util.List) |
ScannerIdGenerator |
Generate a new style scanner id to prevent collision with previous started server or other RSs.
|
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.
|
ServerNonceManager.OperationContext | |
ShutdownHook |
Manage regionserver shutdown hooks.
|
ShutdownHook.DoNothingStoppable | |
ShutdownHook.DoNothingThread | |
ShutdownHook.ShutdownHookThread | |
SimpleRpcSchedulerFactory |
Constructs a
SimpleRpcScheduler . |
SplitLogWorker |
This worker is spawned in every regionserver, including master.
|
SplitRequest |
Handles processing region splits.
|
SplitTransactionFactory |
A factory for creating SplitTransactions, which execute region split as a "transaction".
|
SplitTransactionImpl | |
SplitTransactionImpl.JournalEntryImpl | |
SplitTransactionImpl.LoggingProgressable | |
SteppingSplitPolicy | |
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.Comparators.GetBulkTime | |
StoreFile.Comparators.GetFileSize | |
StoreFile.Comparators.GetPathName | |
StoreFile.Comparators.GetSeqId | |
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.
|
StoreFlusher |
Store flusher interface.
|
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.
|
StripeStoreFileManager.KeyBeforeConcatenatedLists |
An extension of ConcatenatedLists that has several peculiar properties.
|
StripeStoreFileManager.State |
The state class.
|
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).
|
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).
|
UnexpectedStateException | |
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.