Uses of Package
org.apache.hadoop.hbase.regionserver
Package
Description
Provides HBase Client
Table of Contents
Provides implementations of
HFile
and HFile
BlockCache
.Tools to help define network clients and servers.
Multi Cluster Replication
-
ClassDescriptionAbstraction that allows different modules in RegionServer to update/get the favored nodes information for regions.Request a flush.Manages tuning of Heap memory using
HeapMemoryTuner
.Regions store data for a certain region of a table.HRegionServer makes a set of HRegions available to clients.A Store holds a column family in a Region.Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.Last flushed sequence Ids for the regions and their stores on region serverLeases There are several server classes in HBase that need to track external clients that occasionally send heartbeats.Maintains regionserver statistics and publishes them through the metrics interfaces.Interface for classes that expose metrics about the regionserver.Interface to Map of online regions.Provides read-only access to the Regions presently online on the current RegionServerRegion is a subset of HRegion with operations required for theCoprocessors
.RegionServerAccounting keeps record of some basic real time information about the Region Server.A curated subset of services provided byHRegionServer
.Context for postOpenDeployTasks().A source for a replication stream has to expose this service.Bulk loads in secure mode.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. -
-
-
ClassDescriptionA curated subset of services provided by
HRegionServer
.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 SplitWALRemoteProcedureDeprecated.Objects implementing this interface actually do the task that has been acquired by aSplitLogWorker
. -
ClassDescriptionUsed to track flush execution.Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.Wraps together the mutations which are applied as a batch to the region and their operation status and WALEdits.Provides read-only access to the Regions presently online on the current RegionServerRegion is a subset of HRegion with operations required for the
Coprocessors
.Operation enum is used inRegion.startRegionOperation()
and elsewhere to provide context for various checks.RegionScanner describes iterators over rows in an HRegion.A curated subset of services provided byHRegionServer
.This class gives you the ability to change the max versions and TTL options before opening a scanner for a Store.Enum to distinguish general scan types.Interface for objects that hold a column family in a Region.An interface to describe a store data file.Reader for a StoreFile. -
ClassDescriptionDescribe a StoreFile (hfile, reference, link)Reader for a StoreFile.
-
ClassDescriptionA sink of cells that allows appending cells to the Writers that implement it.Regions store data for a certain region of a table.This interface denotes a scanner as one which can ship cells.Implementors of this interface are the ones who needs to do some action when the
Shipper.shipped()
is called -
-
ClassDescriptionA sink of cells that allows appending cells to the Writers that implement it.Default StoreEngine creates the default compactor, policy, and store file manager, or their derivatives.Default implementation of StoreFlusher.Used to track flush execution.The store implementation to save MOBs (medium objects), it extends the HStore.HRegionServer makes a set of HRegions available to clients.A Store holds a column family in a Region.A Store data file.Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.
MemStoreSnapshot
is a Context Object to hold details of the snapshot taken on a MemStore.This carries the immutable information and references on some of the meta data about the HStore.StoreEngine is a factory that can create the objects necessary for HStore to operate.KeyValueScanner adaptor over the Reader.A StoreFile writer. -
ClassDescriptionHRegionServer makes a set of HRegions available to clients.Region is a subset of HRegion with operations required for the
Coprocessors
.A curated subset of services provided byHRegionServer
. -
-
ClassDescriptionAn abstract class, which implements the behaviour shared by all concrete memstore instances.Base class for cell sink that separates the provided cells into multiple files.This Chore, every time it runs, will clear the unsused HFiles in the data folder.CellFlatMap stores a constant number of elements and is immutable after creation stage.A
Set
ofCell
s, where an add will overwrite the entry if already exists in the set.A sink of cells that allows appending cells to the Writers that implement it.If set of MapFile.Readers in Store change, implementors are notified.A chunk of memory out of which allocations are sliced.Does the management of memstoreLAB chunk creations.Types of chunks, based on their sizesA 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.A memstore implementation which supports in-memory compaction.Types of indexes (part of immutable segments) to be used after flattening, compaction, or merge are applied.Compact region on request and then run split if appropriateThe CompositeImmutableSegments is created as a collection of ImmutableSegments and supports the interface of a single ImmutableSegments.ARegionSplitPolicy
implementation which splits a region as soon as any of its store files exceeds a maximum configurable size.CSLMImmutableSegment is an abstract class that extends the API supported by aSegment
, andImmutableSegment
.Abstraction that allows different modules in RegionServer to update/get the favored nodes information for regions.Factory to use when you want to use theFifoRpcScheduler
AFlushPolicy
that only flushes store larger a given threshold.Used to track flush execution.A flush policy determines the stores that need to be flushed when flushing a region.Request a flush.Listener which will get notified regarding flush requests of regions.Manages tuning of Heap memory usingHeapMemoryTuner
.Every class that wants to observe heap memory tune actions must implement this interface.POJO to pass all the relevant information required to do the heap memory tuning.POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.Regions store data for a certain region of a table.Listener class to enable callers of bulkLoadHFile() to perform any necessary pre/post processing of a given bulkload callObjects from this class are created when flushing to describe all the different states that that method ends up in.A result object from prepare flush cache stageView to an on-disk Region.HRegionServer makes a set of HRegions available to clients.A Store holds a column family in a Region.A Store data file.ImmutableSegment is an abstract class that extends the API supported by aSegment
, and is not needed for aMutableSegment
.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.Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.Implements a heap merge across any number of KeyValueScanners.Scanner that returns the next KeyValue.Last flushed sequence Ids for the regions and their stores on region serverReports a problem with a leaseLeaseListener is an interface meant to be implemented by users of the Leases class.Leases There are several server classes in HBase that need to track external clients that occasionally send heartbeats.Thrown if we are asked to create a lease but lease on passed name already exists.Runs periodically to determine if the WAL should be rolled.The MemStore holds in-memory modifications to the Store.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.Types of actions to be done on the pipeline upon MemStoreCompaction invocation.The ongoing MemStore Compaction manager, dispatches a solo running compaction and interrupts the compaction if requested.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.A memstore-local allocation buffer.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 timeData structure of three longs.Accounting of current heap and data sizes.MemStoreSnapshot
is a Context Object to hold details of the snapshot taken on a MemStore.This interface will be implemented by a MetricsSource that will export metrics from HeapMemoryManager in RegionServer into the hadoop metrics system.This is the glue between the HRegion and whatever hadoop shim layer is loaded (hbase-hadoop1-compat or hbase-hadoop2-compat).This interface will be implemented by a MetricsSource that will export metrics from multiple regions into the hadoop metrics system.Maintains regionserver statistics and publishes them through the metrics interfaces.A collection of exposed metrics for space quotas from an HBase RegionServer.Interface for classes that expose metrics about the regionserver.Interface of a factory to create Metrics Sources used inside of regionservers.This is the interface that will expose RegionServer information to hadoop1/hadoop2 implementations of the MetricsRegionServerSource.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.Interface of class that will wrap an HRegion and export numbers so they can be used in MetricsRegionSourceThis interface will be implemented by a MetricsSource that will export metrics from multiple regions of a table into the hadoop metrics system.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.Interface of class that will wrap a MetricsTableSource and export numbers so they can be used in MetricsTableSourceThis interface will be implemented by a MetricsSource that will export metrics from multiple users into the hadoop metrics system.Wraps together the mutations which are applied as a batch to the region and their operation status and WALEdits.Manages the read/write consistency.Write number and whether write has completed given out at start of a write transaction.Interface to Map of online regions.A mutable segment in memstore, specifically the active segment.A "non-lazy" scanner which always does a real seek operation.A "non-reversed & non-lazy" scanner which does not support backward scanning and always does a real seek operation.Provides read-only access to the Regions presently online on the current RegionServerThis class stores the Operation status code and the exception message that occurs in case of failure of operations like put, delete, etc.Region is a subset of HRegion with operations required for theCoprocessors
.Operation enum is used inRegion.startRegionOperation()
and elsewhere to provide context for various checks.Row lock held by a given thread.Implements the coprocessor environment and runtime support for coprocessors loaded within aRegion
.RegionScanner describes iterators over rows in an HRegion.RegionServerAccounting keeps record of some basic real time information about the Region Server.A curated subset of services provided byHRegionServer
.Context for postOpenDeployTasks().Thrown by the region server when it is in shutting down state.Services a Store needs from a Region.A split policy determines when a Region should be split.A split restriction that restricts the pattern of the split point.Gateway to Cluster Replication.A sink for a replication stream has to expose this service.A source for a replication stream has to expose this service.ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.A factory class that constructs anRpcScheduler
.Implements the regionserver RPC services.Immutable information for scans over a store.ScannerContext instances encapsulate limit tracking AND progress towards those limits during invocations ofInternalScanner.next(java.util.List)
andInternalScanner.next(java.util.List)
.The various scopes where a limit can be enforced.The possible states a scanner may be in following a call toInternalScanner.next(List)
This class gives you the ability to change the max versions and TTL options before opening a scanner for a Store.Enum to distinguish general scan types.Bulk loads in secure mode.This is an abstraction of a segment maintained in a memstore, e.g., the active cell set or its snapshot.A singleton store segment factory.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.This interface denotes a scanner as one which can ship cells.Implementors of this interface are the ones who needs to do some action when theShipper.shipped()
is calledDeprecated.Objects implementing this interface actually do the task that has been acquired by aSplitLogWorker
.Interface for objects that hold a column family in a Region.A more restricted interface for HStore.This carries the immutable information and references on some of the meta data about the HStore.StoreEngine is a factory that can create the objects necessary for HStore to operate.An interface to describe a store data file.Describe a StoreFile (hfile, reference, link)Manages the store files and basic metadata about that that determines the logical structure (e.g.Reader for a StoreFile.KeyValueScanner adaptor over the Reader.A StoreFile writer.Scanner scans both the memstore and the Store.Base class for cell sink that separates the provided cells into multiple files for stripe compaction.Configuration class for stripe store and compactions.Stripe implementation ofStoreFileManager
.Stripe flush request wrapper that writes a non-striped file.Stores minimum and maximum timestamp values, it is [minimumTimestamp, maximumTimestamp] in interval notation.A list of segment managers coupled with the version of the memstore (version at the time it was created). -
-
ClassDescriptionImplements the coprocessor environment and runtime support for coprocessors loaded within a
Region
.Immutable information for scans over a store.Enum to distinguish general scan types.Implementors of this interface are the ones who needs to do some action when theShipper.shipped()
is called -
-
ClassDescriptionView to an on-disk Region.This carries the immutable information and references on some of the meta data about the HStore.Describe a StoreFile (hfile, reference, link)A StoreFile writer.
-
ClassDescriptionA Store holds a column family in a Region.Region is a subset of HRegion with operations required for the
Coprocessors
.A curated subset of services provided byHRegionServer
. -
-
ClassDescriptionGateway to Cluster Replication.A sink for a replication stream has to expose this service.
-
ClassDescriptionRegions store data for a certain region of a table.View to an on-disk Region.Describe a StoreFile (hfile, reference, link)
-
ClassDescriptionProvides read-only access to the Regions presently online on the current RegionServerRegion is a subset of HRegion with operations required for the
Coprocessors
. -
ClassDescriptionA sink of cells that allows appending cells to the Writers that implement it.Regions store data for a certain region of a table.HRegionServer makes a set of HRegions available to clients.Scanner that returns the next KeyValue.A "non-lazy" scanner which always does a real seek operation.A "non-reversed & non-lazy" scanner which does not support backward scanning and always does a real seek operation.This interface denotes a scanner as one which can ship cells.Implementors of this interface are the ones who needs to do some action when the
Shipper.shipped()
is calledDescribe a StoreFile (hfile, reference, link) -
ClassDescriptionView to an on-disk Region.Describe a StoreFile (hfile, reference, link)
-
ClassDescriptionLast flushed sequence Ids for the regions and their stores on region serverManages the read/write consistency.Write number and whether write has completed given out at start of a write transaction.A curated subset of services provided by
HRegionServer
.Interface which abstracts implementations on log sequenceId assignment