Uses of Package
org.apache.hadoop.hbase
Package
Description
Provides HBase Client
Table of Contents
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next()
.Provides implementations of
HFile
and HFile
BlockCache
.Tools to help define network clients and servers.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
HBase REST
Provides an HBase Thrift
service.
-
ClassDescriptionInterface to support the aborting of a given server or client.This class is a server side extension to the
Cell
interface.This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferReturned to the clients when their request was discarded due to server being overloaded.There are two modes with catalog replica support.The unit of storage in HBase consisting of the following fields:The valid types for user to build the cell.UseCellBuilderFactory
to get CellBuilder instance.Used byCellBuilderFactory
andExtendedCellBuilderFactory
.Comparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestampCompare two HBase cells.Implementer can return a CellScanner over its Cell content.An interface for iterating through a sequence of cells.ChoreService is a service that can be used to schedule instances ofScheduledChore
to run periodically while sharing threads.Implementations 'visit' a catalog table row.The identifier for this cluster.Metrics information on the HBase cluster.Kinds of ClusterMetricsGeneric set of comparison operators.Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.Do a shallow merge of multiple KV configuration pools.Implementations of this interface will keep and return to clients implementations of classes providing API to execute coordinated operations.Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.Lifecycle state of a given coprocessor instance.Coprocessor environment state.Subclass if exception is not meant to be retried: e.g.Extension toCell
with server side required functions.For internal purpose.We use this class in HBase internally for gettingExtendedCell
directly without casting.We use this class in HBase internally for gettingExtendedCell
directly without casting.Deprecated.since 3.0.0, will be removed in 4.0.0.Deprecated.since 3.0.0, will be removed in 4.0.0.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionBase class for Master and RegionServer RpcServices.Base class for hbase services, such as master or region server.Base class for exceptions thrown by an HBase server.Deprecated.since 3.0.0, will be removed in 4.0.0.POJO class for HBCK RegionInfo in HBCK Inconsistencies report.POJO class for ServerName in HBCK Inconsistencies report.Status codes used for return values of bulk operations.Data structure to describe the distribution of HDFS blocks among hosts.Stores the hostname and weight for that hostname.Data structure to hold RegionInfo and the address for the hosting HRegionServer.Compare two HBase cells inner store, skip compare family for better performance.Ways to keep cells marked for delete around.An HBase Key/Value.A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly used in places where we need to compare two cells.Key type.This class creates a single process HBase cluster.Enum describing all possible memory compaction policiesACellComparatorImpl
forhbase:meta
catalog tableKeyValue
s.A cache of meta region location metadata.Deprecated.since 3.0.0, will be removed in 4.0.0.Deprecated.Subclass so can get at protected methods (none at moment).Namespace POJO class.An extension of the ByteBufferKeyValue where the tags length is always 0Enum for map metrics.An extended version of Cell that allows CPs manipulate Tags.Allows creating a cell withTag
An instance of this type can be acquired by using RegionCoprocessorEnvironment#getCellBuilder (for prod code) andRawCellBuilderFactory
(for unit tests).Container for holding a list ofHRegionLocation
's that correspond to the same range.Encapsulates per-region load metrics.ScheduledChore is a task performed on a period in hbase.Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).This class is used for exporting current state of load on a RegionServer.Name of a particular incarnation of an HBase Server.Information about active monitored server tasksTask stateBuilder for information about active monitored server tasksIt is used to represent the size with different units.This class is an extension to KeyValue where rowLen and keyLen are cached.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 SplitWALManagerDeprecated.since 3.0.0, will be removed in 4.0.0.Deprecated.Builder pattern for creating anStartMiniClusterOption
.Implementers are Stoppable.Get, remove and modify table descriptors.Immutable POJO class for representing a table name.Tags are part of cells and helps to add metadata about them.Builder implementation to createTag
Call setTagValue(byte[]) method to createArrayBackedTag
Encapsulates per-user load metrics. -
ClassDescriptionInterface to support the aborting of a given server or client.HBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration)
in the constructor, but only sets the configuration through theBaseConfigurable.setConf(Configuration)
methodBase interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.Implementers are Stoppable.Immutable POJO class for representing a table name. -
ClassDescriptionInterface to support the aborting of a given server or client.The unit of storage in HBase consisting of the following fields:The valid types for user to build the cell.Use
CellBuilderFactory
to get CellBuilder instance.Used byCellBuilderFactory
andExtendedCellBuilderFactory
.Implementer can return a CellScanner over its Cell content.An interface for iterating through a sequence of cells.Metrics information on the HBase cluster.Kinds of ClusterMetricsGeneric set of comparison operators.Subclass if exception is not meant to be retried: e.g.Extension toCell
with server side required functions.We use this class in HBase internally for gettingExtendedCell
directly without casting.We use this class in HBase internally for gettingExtendedCell
directly without casting.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionData structure to hold RegionInfo and the address for the hosting HRegionServer.Ways to keep cells marked for delete around.Enum describing all possible memory compaction policiesNamespace POJO class.Thrown when a namespace can not be locatedThrown when something happens related to region handling.Container for holding a list ofHRegionLocation
's that correspond to the same range.Encapsulates per-region load metrics.Name of a particular incarnation of an HBase Server.Thrown when a table exists but should not.Immutable POJO class for representing a table name.Thrown when a table cannot be located. -
-
-
-
-
-
ClassDescriptionAn interface for iterating through a sequence of cells.Extension to
Cell
with server side required functions.We use this class in HBase internally for gettingExtendedCell
directly without casting.All hbase specific IOExceptions should be subclasses of HBaseIOException -
ClassDescriptionImplementations of this interface will keep and return to clients implementations of classes providing API to execute coordinated operations.Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Name of a particular incarnation of an HBase Server.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 SplitWALManager
-
ClassDescriptionInterface to support the aborting of a given server or client.The unit of storage in HBase consisting of the following fields:Metrics information on the HBase cluster.Generic set of comparison operators.Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.Coprocessor environment state.Subclass if exception is not meant to be retried: e.g.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionThe field or the parameter to which this annotation can be applied only when it holds mutations for hbase:meta table.Namespace POJO class.Allows creating a cell with
Tag
An instance of this type can be acquired by using RegionCoprocessorEnvironment#getCellBuilder (for prod code) andRawCellBuilderFactory
(for unit tests).Name of a particular incarnation of an HBase Server.Immutable POJO class for representing a table name. -
ClassDescriptionSubclass if exception is not meant to be retried: e.g.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionThrown by a region server if it is sent a request for a region it is not serving.Name of a particular incarnation of an HBase Server.
-
ClassDescriptionAll hbase specific IOExceptions should be subclasses of HBaseIOExceptionName of a particular incarnation of an HBase Server.Implementers are Stoppable.Immutable POJO class for representing a table name.
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Generic set of comparison operators.
-
-
-
ClassDescriptionAn interface for iterating through a sequence of cells.Extension to
Cell
with server side required functions.We use this class in HBase internally for gettingExtendedCell
directly without casting.Immutable POJO class for representing a table name. -
ClassDescriptionComparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestampExtension to
Cell
with server side required functions. -
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Comparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestampSubclass if exception is not meant to be retried: e.g.Extension to
Cell
with server side required functions.All hbase specific IOExceptions should be subclasses of HBaseIOException -
ClassDescriptionInterface to support the aborting of a given server or client.Returned to clients when their request was dropped because the call queue was too big to accept a new call.Implementer can return a CellScanner over its Cell content.Subclass if exception is not meant to be retried: e.g.We use this class in HBase internally for getting
ExtendedCell
directly without casting.We use this class in HBase internally for gettingExtendedCell
directly without casting.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionBase class for Master and RegionServer RpcServices.Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Name of a particular incarnation of an HBase Server.Immutable POJO class for representing a table name. -
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Extension to
Cell
with server side required functions.Data structure to describe the distribution of HDFS blocks among hosts.An HBase Key/Value.Immutable POJO class for representing a table name.Tags are part of cells and helps to add metadata about them. -
ClassDescriptionInterface to support the aborting of a given server or client.The identifier for this cluster.Metrics information on the HBase cluster.Kinds of ClusterMetricsAll hbase specific IOExceptions should be subclasses of HBaseIOExceptionBase class for Master and RegionServer RpcServices.Base class for hbase services, such as master or region server.Data structure to hold RegionInfo and the address for the hosting HRegionServer.The field or the parameter to which this annotation can be applied only when it holds mutations for hbase:meta table.Namespace POJO class.ScheduledChore is a task performed on a period in hbase.Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).This class is used for exporting current state of load on a RegionServer.Name of a particular incarnation of an HBase Server.Implementers are Stoppable.Get, remove and modify table descriptors.Immutable POJO class for representing a table name.Thrown if a table should be offline but is not.Thrown when a table cannot be located.This exception is thrown by the master when a region server reports and is already being processed as dead.
-
-
ClassDescriptionHBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration)
in the constructor, but only sets the configuration through theBaseConfigurable.setConf(Configuration)
methodImplementers are Stoppable. -
ClassDescriptionHBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration)
in the constructor, but only sets the configuration through theBaseConfigurable.setConf(Configuration)
methodThe unit of storage in HBase consisting of the following fields:Extension toCell
with server side required functions.ScheduledChore is a task performed on a period in hbase.Implementers are Stoppable.Immutable POJO class for representing a table name.Tags are part of cells and helps to add metadata about them. -
ClassDescriptionScheduledChore is a task performed on a period in hbase.Implementers are Stoppable.Immutable POJO class for representing a table name.
-
ClassDescriptionNamespace POJO class.Immutable POJO class for representing a table name.
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.Coprocessor environment state.Subclass if exception is not meant to be retried: e.g.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionNamespace POJO class.The listener interface for receiving region state events.ScheduledChore is a task performed on a period in hbase.Implementers are Stoppable.Immutable POJO class for representing a table name.
-
-
ClassDescriptionInterface to support the aborting of a given server or client.This class is a server side extension to the
Cell
interface.This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferThe unit of storage in HBase consisting of the following fields:Comparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestampChoreService is a service that can be used to schedule instances ofScheduledChore
to run periodically while sharing threads.Generic set of comparison operators.Subclass if exception is not meant to be retried: e.g.Extension toCell
with server side required functions.We use this class in HBase internally for gettingExtendedCell
directly without casting.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionBase class for Master and RegionServer RpcServices.Base class for hbase services, such as master or region server.Status codes used for return values of bulk operations.Data structure to describe the distribution of HDFS blocks among hosts.Data structure to hold RegionInfo and the address for the hosting HRegionServer.Ways to keep cells marked for delete around.An HBase Key/Value.Enum describing all possible memory compaction policiesAn extension of the ByteBufferKeyValue where the tags length is always 0Thrown by a region server if it is sent a request for a region it is not serving.An extended version of Cell that allows CPs manipulate Tags.ScheduledChore is a task performed on a period in hbase.Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Name of a particular incarnation of an HBase Server.Implementers are Stoppable.Get, remove and modify table descriptors.Immutable POJO class for representing a table name. -
-
ClassDescriptionComparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestampExtension to
Cell
with server side required functions.Ways to keep cells marked for delete around. -
ClassDescriptionAll hbase specific IOExceptions should be subclasses of HBaseIOExceptionImmutable POJO class for representing a table name.
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Thrown by a region server if it will block and wait to serve a request.Implementers are Stoppable.
-
ClassDescriptionInterface to support the aborting of a given server or client.The unit of storage in HBase consisting of the following fields:Extension to
Cell
with server side required functions.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionName of a particular incarnation of an HBase Server.Immutable POJO class for representing a table name. -
ClassDescriptionInterface to support the aborting of a given server or client.The unit of storage in HBase consisting of the following fields:Extension to
Cell
with server side required functions.We use this class in HBase internally for gettingExtendedCell
directly without casting.Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Name of a particular incarnation of an HBase Server.Get, remove and modify table descriptors.Immutable POJO class for representing a table name. -
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Name of a particular incarnation of an HBase Server.
-
ClassDescriptionMetrics information on the HBase cluster.Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.Coprocessor environment state.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionName of a particular incarnation of an HBase Server.Implementers are Stoppable.Immutable POJO class for representing a table name.
-
ClassDescriptionHBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration)
in the constructor, but only sets the configuration through theBaseConfigurable.setConf(Configuration)
methodSubclass if exception is not meant to be retried: e.g.All hbase specific IOExceptions should be subclasses of HBaseIOException -
ClassDescriptionThe unit of storage in HBase consisting of the following fields:An interface for iterating through a sequence of cells.Kinds of ClusterMetricsGeneric set of comparison operators.Subclass if exception is not meant to be retried: e.g.Extension to
Cell
with server side required functions.For internal purpose.We use this class in HBase internally for gettingExtendedCell
directly without casting.Data structure to hold RegionInfo and the address for the hosting HRegionServer.Key type.Namespace POJO class.Name of a particular incarnation of an HBase Server.Information about active monitored server tasksImmutable POJO class for representing a table name. -
-
ClassDescriptionSubclass if exception is not meant to be retried: e.g.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionImmutable POJO class for representing a table name.
-
-
-
ClassDescriptionThis class is a server side extension to the
Cell
interface.The unit of storage in HBase consisting of the following fields:Comparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestampThe identifier for this cluster.Extension toCell
with server side required functions.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionData structure to describe the distribution of HDFS blocks among hosts.Thrown if the master is not runningAn extended version of Cell that allows CPs manipulate Tags.Name of a particular incarnation of an HBase Server.Implementers are Stoppable.Get, remove and modify table descriptors.Immutable POJO class for representing a table name.Thrown if the client can't connect to ZooKeeper. -
-
ClassDescriptionInterface to support the aborting of a given server or client.The unit of storage in HBase consisting of the following fields:Extension to
Cell
with server side required functions.We use this class in HBase internally for gettingExtendedCell
directly without casting.Name of a particular incarnation of an HBase Server.Immutable POJO class for representing a table name. -
ClassDescriptionInterface to support the aborting of a given server or client.The identifier for this cluster.Thrown when an operation requires the root and all meta regions to be onlineName of a particular incarnation of an HBase Server.Implementers are Stoppable.Thrown if the client can't connect to ZooKeeper.