Uses of Package
org.apache.hadoop.hbase
Package
Description
Provides HBase Client
Provides client classes for invoking Coprocessor RPC protocols
Overview
Example Usage
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
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.
This package should be in the hbase-http module as
a.a.h.h.http.gson
.The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
Multi Cluster Replication
HBase REST
Provides an HBase Thrift
service.
Provides an HBase Thrift
service.
This package provides fully-functional exemplar Java code demonstrating
simple usage of the hbase-client API, for incorporation into a Maven
archetype with hbase-client dependency.
This package provides fully-functional exemplar Java code demonstrating
simple usage of the hbase-client API, for incorporation into a Maven
archetype with hbase-shaded-client dependency.
-
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.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.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionBase class for exceptions thrown by an HBase server.POJO class for HBCK RegionInfo in HBCK Inconsistencies report.POJO class for ServerName in HBCK Inconsistencies report.Deprecated.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.Implementations 'visit' hostAndWeight.A utility for executing an external script that checks the health of the node.The Class HealthReport containing information about health of the node.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Data structure to hold RegionInfo and the address for the hosting HRegionServer.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.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.Deprecated.: UseCellComparatorImpl
.Deprecated.:MetaCellComparator.META_COMPARATOR
to be used.Avoids redundant comparisons for better performance.Key type.Enum describing all possible memory compaction policiesAMetaTableAccessor.Visitor
that collects content out of passedResult
.A Visitor that skips offline regions and split parentsImplementations 'visit' a catalog table row.Namespace POJO class.An extension of the ByteBufferKeyValue where the tags length is always 0These cells are used in reseeks/seeks to improve the read performance.These cells are used in reseeks/seeks to improve the read performance.This can be used when a Cell has to change with addition/removal of one or more tags.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).Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionMetrics
instead.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.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseServerMetrics
instead.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 SplitWALManagerImplementers are Stoppable.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. -
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.Thrown if the client can't connect to ZooKeeper. -
ClassDescriptionThe unit of storage in HBase consisting of the following fields:All hbase specific IOExceptions should be subclasses of HBaseIOExceptionImmutable 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)
methodImplementers are Stoppable. -
-
-
ClassDescriptionInterface to support the aborting of a given server or client.There are two modes with catalog replica support.The unit of storage in HBase consisting of the following fields: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 of
ScheduledChore
to run periodically while sharing threads.Metrics information on the HBase cluster.Kinds of ClusterMetricsDeprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseClusterMetrics
instead.Generic set of comparison operators.Subclass if exception is not meant to be retried: e.g.Extension toCell
with server side required functions.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionDeprecated.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Data structure to hold RegionInfo and the address for the hosting HRegionServer.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Ways to keep cells marked for delete around.An HBase Key/Value.Thrown if the master is not runningEnum describing all possible memory compaction policiesNamespace POJO class.Thrown when a namespace can not be locatedAn extended version of Cell that allows CPs manipulate Tags.Thrown 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.ScheduledChore is a task performed on a period in hbase.Name of a particular incarnation of an HBase Server.Implementers are Stoppable.Thrown when a table exists but should not.Immutable POJO class for representing a table name.Thrown when a table cannot be located.Tags are part of cells and helps to add metadata about them.Thrown if the client can't connect to ZooKeeper. -
-
-
-
-
-
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:An interface for iterating through a sequence of cells.For internal purpose.All hbase specific IOExceptions should be subclasses of HBaseIOException
-
ClassDescriptionBase 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 HBaseIOExceptionDeprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.
-
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.Lifecycle state of a given coprocessor instance.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. -
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Use
CellBuilderFactory
to get CellBuilder instance.Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.Coprocessor environment state.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.
-
ClassDescriptionDefines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).
-
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.
-
ClassDescriptionThis class is a server side extension to the
Cell
interface.The unit of storage in HBase consisting of the following fields:The valid types for user to build the cell.Generic set of comparison operators.Extension toCell
with server side required functions.An extended version of Cell that allows CPs manipulate Tags.Tags are part of cells and helps to add metadata about them. -
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.
-
-
ClassDescriptionMetrics information on the HBase cluster.Encapsulates per-region load metrics.This class is used for exporting current state of load on a RegionServer.
-
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:An interface for iterating through a sequence of cells.Immutable POJO class for representing a table name.
-
ClassDescriptionThis class is a server side extension to the
Cell
interface.This is a key only Cell implementation which is identical toKeyValue.KeyOnlyKeyValue
with respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).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 timestampExtension toCell
with server side required functions.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.An extended version of Cell that allows CPs manipulate Tags. -
ClassDescriptionThis is a key only Cell implementation which is identical to
KeyValue.KeyOnlyKeyValue
with respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).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 timestampSubclass 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. -
ClassDescriptionInterface to support the aborting of a given server or client.Returned to the clients when their request was discarded due to server being overloaded.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.An interface for iterating through a sequence of cells.Subclass if exception is not meant to be retried: e.g.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionDefines 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.
-
ClassDescriptionDeprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.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.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.An HBase Key/Value.Name of a particular incarnation of an HBase Server.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.ChoreService is a service that can be used to schedule instances of
ScheduledChore
to run periodically while sharing threads.This exception is thrown by the master when a region server clock skew is too high.The identifier for this cluster.Metrics information on the HBase cluster.Kinds of ClusterMetricsCoprocessor environment state.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionThis class creates a single process HBase cluster.Thrown if the master is not runningThe field or the parameter to which this annotation can be applied only when it holds mutations for hbase:meta table.Namespace POJO class.This exception is thrown by the master when a region server was shut down and restarted so fast that the master still hasn't processed the server shutdown of the first instance, or when master is initializing and client call admin operations, or when an operation is performed on a region server that is still starting.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.Class servers two purposes: 1. -
ClassDescriptionAll hbase specific IOExceptions should be subclasses of HBaseIOExceptionData structure to hold RegionInfo and the address for the hosting HRegionServer.This exception is thrown by the master when a region server was shut down and restarted so fast that the master still hasn't processed the server shutdown of the first instance, or when master is initializing and client call admin operations, or when an operation is performed on a region server that is still starting.Name of a particular incarnation of an HBase Server.Immutable POJO class for representing a table name.
-
ClassDescriptionMetrics information on the HBase cluster.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionData structure to describe the distribution of HDFS blocks among hosts.Encapsulates per-region load metrics.ScheduledChore is a task performed on a period in hbase.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.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)
methodScheduledChore is a task performed on a period in hbase.Implementers are Stoppable. -
ClassDescriptionScheduledChore is a task performed on a period in hbase.Name of a particular incarnation of an HBase Server.
-
ClassDescriptionMetrics information on the HBase cluster.Data structure to hold RegionInfo and the address for the hosting HRegionServer.Encapsulates per-region load metrics.Name of a particular incarnation of an HBase Server.It is used to represent the size with different units.Immutable POJO class for representing a table name.
-
ClassDescriptionMetrics information on the HBase cluster.Name of a particular incarnation of an HBase Server.
-
ClassDescriptionMetrics information on the HBase cluster.Kinds of ClusterMetricsThis class is used for exporting current state of load on a RegionServer.Name of a particular incarnation of an HBase Server.
-
-
ClassDescriptionPOJO to present Empty Region Info from Catalog Janitor Inconsistencies Report via REST API.POJO to present HBCK Inconsistent Regions from HBCK Inconsistencies Report via REST API.POJO to present Orphan Region on FS from HBCK Inconsistencies Report via REST API.POJO to present Orphan Region on RS from HBCK Inconsistencies Report via REST API.POJO to present Region Overlap from Catalog Janitor Inconsistencies Report via REST API.POJO to present Region Holes from Catalog Janitor Inconsistencies Report via REST API.POJO to present Unknown Regions from Catalog Janitor Inconsistencies Report via REST API.
-
ClassDescriptionPOJO to present Empty Region Info from Catalog Janitor Inconsistencies Report via REST API.POJO to present HBCK Inconsistent Regions from HBCK Inconsistencies Report via REST API.POJO to present Orphan Region on FS from HBCK Inconsistencies Report via REST API.POJO to present Orphan Region on RS from HBCK Inconsistencies Report via REST API.POJO to present Region Overlap from Catalog Janitor Inconsistencies Report via REST API.POJO class for HBCK RegionInfo in HBCK Inconsistencies report.POJO to present Region Holes from Catalog Janitor Inconsistencies Report via REST API.POJO class for ServerName in HBCK Inconsistencies report.POJO to present Unknown Regions from Catalog Janitor Inconsistencies Report via REST API.Name of a particular incarnation of an HBase Server.
-
ClassDescriptionImplementations 'visit' a catalog table row but with close() at the end.Implementations 'visit' a catalog table row.Container for holding a list of
HRegionLocation
's that correspond to the same range.ScheduledChore is a task performed on a period in hbase.Name of a particular incarnation of an HBase Server.Immutable POJO class for representing a table name. -
-
ClassDescriptionScheduledChore is a task performed on a period in hbase.Implementers are Stoppable.Get, remove and modify table descriptors.
-
ClassDescriptionScheduledChore is a task performed on a period in hbase.Immutable POJO class for representing a table name.
-
ClassDescriptionAll hbase specific IOExceptions should be subclasses of HBaseIOExceptionData structure to hold RegionInfo and the address for the hosting HRegionServer.Implementations 'visit' a catalog table row.Namespace POJO class.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 unit of storage in HBase consisting of the following fields:Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Immutable POJO class for representing a table name.
-
ClassDescriptionSubclass if exception is not meant to be retried: e.g.Name of a particular incarnation of an HBase Server.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)
methodName of a particular incarnation of an HBase Server.Implementers are Stoppable.Immutable POJO class for representing a table name. -
ClassDescriptionDefines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).
-
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: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.
-
-
-
ClassDescriptionAll hbase specific IOExceptions should be subclasses of HBaseIOException
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:All hbase specific IOExceptions should be subclasses of HBaseIOExceptionDefines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).
-
ClassDescriptionAll hbase specific IOExceptions should be subclasses of HBaseIOException
-
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 HBaseIOExceptionDeprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Namespace 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 timestampImplementer 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.Generic set of comparison operators.Implementations of this interface will keep and return to clients implementations of classes providing API to execute coordinated operations.Coprocessor environment state.Subclass if exception is not meant to be retried: e.g.Extension toCell
with server side required functions.All hbase specific IOExceptions should be subclasses of HBaseIOExceptionStatus codes used for return values of bulk operations.Data structure to describe the distribution of HDFS blocks among hosts.The Class HealthCheckChore for running health checker regularly.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.Enum describing all possible memory compaction policiesA cache of meta region location metadata.An 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.Allows creating a cell withTag
An instance of this type can be acquired by using RegionCoprocessorEnvironment#getCellBuilder (for prod code) andRawCellBuilderFactory
(for unit tests).Thrown by a region server if it will block and wait to serve a request.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 timestamp
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Name of a particular incarnation of an HBase Server.
-
-
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 timestampWays to keep cells marked for delete around.
-
-
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.
-
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:An interface for iterating through a sequence of cells.Coprocessor environment state.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:An interface for iterating through a sequence of cells.For internal purpose.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.
-
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.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:An interface for iterating through a sequence of cells.ChoreService is a service that can be used to schedule instances of
ScheduledChore
to run periodically while sharing threads.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.Data structure to hold RegionInfo and the address for the hosting HRegionServer.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. -
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Name of a particular incarnation of an HBase Server.Immutable POJO class for representing a table name.Thrown when a table cannot be located.
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.
-
ClassDescriptionMetrics information on the HBase cluster.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.Name 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 -
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:Generic set of comparison operators.Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.Coprocessor environment state.An HBase Key/Value.Thrown if the master is not runningNamespace POJO class.Name of a particular incarnation of an HBase Server.Implementers are Stoppable.Immutable POJO class for representing a table name.Thrown if the client can't connect to ZooKeeper. -
ClassDescriptionBase interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.Coprocessor environment state.Implementers are Stoppable.
-
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 timestampBase 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 HBaseIOExceptionKey type.Immutable POJO class for representing a table name.Tags are part of cells and helps to add metadata about them.
-
-
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.
-
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:Deprecated.Immutable POJO class for representing a table name.
-
ClassDescriptionThe unit of storage in HBase consisting of the following fields:The valid types for user to build the cell.Generic set of comparison operators.For internal purpose.Data structure to hold RegionInfo and the address for the hosting HRegionServer.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Ways to keep cells marked for delete around.Namespace POJO class.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.Metrics information on the HBase cluster.Kinds of ClusterMetricsGeneric set of comparison operators.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Namespace POJO class.Thrown when a namespace can not be locatedEncapsulates 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.
-
ClassDescriptionBase interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.Name of a particular incarnation of an HBase Server.Immutable POJO class for representing a table name.Thrown when a table cannot be located.
-
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 timestampChoreService is a service that can be used to schedule instances ofScheduledChore
to run periodically while sharing threads.The identifier for this cluster.Metrics information on the HBase 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.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.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. -
ClassDescriptionName 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:An interface for iterating through a sequence of cells.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.
-
-