Package org.apache.hadoop.hbase
package org.apache.hadoop.hbase
-
ClassDescriptionInterface to support the aborting of a given server or client.This is a
Tag
implementation in which value is backed by an on heap byte array.Deprecated.HBase version of Hadoop's Configured class that doesn't initialize the configuration viaBaseConfigurable.setConf(Configuration)
in the constructor, but only sets the configuration through theBaseConfigurable.setConf(Configuration)
methodThis class is a server side extension to theCell
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).This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferThis is aTag
implementation in which value is backed byByteBuffer
Used to merge CacheEvictionStats.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.Helper class for generating/parsing "info" family cells in meta table.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.Create a 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.Utility methods helpful for slingingCell
instances.ChoreService is a service that can be used to schedule instances ofScheduledChore
to run periodically while sharing threads.Custom ThreadFactory used with the ScheduledThreadPoolExecutor so that all the threads are daemon threads, and thus, don't prevent the JVM from shutting downThe (asynchronous) meta table accessor used at client side.Implementations 'visit' a catalog table row but with close() at the end.Collects all returned.AClientMetaTableAccessor.Visitor
that collects content out of passedResult
.Implementations 'visit' a catalog table row.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 ClusterMetricsGeneric set of comparison operators.Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.Factory for classes supplied by hadoop compatibility modules.Do a shallow merge of multiple KV configuration pools.Thrown when a table has been modified concurrentlyImplementations 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.CoprocessorEnvironment<C extends Coprocessor>Coprocessor environment state.Subclass if exception is not meant to be retried: e.g.Thrown during flush if the possibility snapshot content was not properly persisted into store files.The Class ExecutorStatusChore for collect Executor status info periodically and report to metrics systemExtension 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.Adds HBase configuration files to a ConfigurationThis class defines constants for different classes of hbase limited private apisAll hbase specific IOExceptions should be subclasses of HBaseIOExceptionHBaseRpcServicesBase<S extends HBaseServerBase<?>>Base class for Master and RegionServer RpcServices.HBaseServerBase<R extends HBaseRpcServicesBase<?>>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.A tracker for tracking and validating table rows generated withHBaseTestingUtility.loadTable(Table, byte[])
Deprecated.since 3.0.0, will be removed in 4.0.0.POJO 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.HConstants holds a bunch of HBase-related constantsStatus 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.Comparator used to sort hosts based on weightImplementations 'visit' hostAndWeight.The Class HealthCheckChore for running health checker regularly.A utility for executing an external script that checks the health of the node.The Class HealthReport containing information about health of the node.This class runs performance benchmarks forHFile
.Data structure to hold RegionInfo and the address for the hosting HRegionServer.Compare two HBase cells inner store, skip compare family for better performance.Thrown if a request is table schema modification is requested but made for an invalid family name.ScheduledThreadPoolExecutor that will add some jitter to the RunnableScheduledFuture.getDelay.Pluggable JMX Agent for HBase(to fix the 2 random TCP ports issue of the out-of-the-box JMX Agent): 1)connector port can share with the registry port if SSL is OFF 2)support password authentication 3)support subset of SSL (with default configuration)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.Avoids redundant comparisons for better performance.Key type.static convenience methods for dealing with KeyValues and collections of KeyValuesThis class creates a single process HBase cluster.Thrown if the master is not runningEnum describing all possible memory compaction policiesThe field or the parameter to which this annotation can be applied only when it holds mutations for hbase:meta table.A cache of meta region location metadata.Read/write operations onhbase:meta
region as well as assignment information stored tohbase:meta
.Deprecated.since 3.0.0, will be removed in 4.0.0.Subclass so can get at protected methods (none at moment).Alternate shutdown hook.Basic mock region server services.Exception thrown when the result needs to be chunked on the server side.Namespace POJO class.Thrown when a namespace exists but should notThrown when a namespace can not be locatedAn extension of the ByteBufferKeyValue where the tags length is always 0An extension of the KeyValue where the tags length is always 0Thrown when an operation requires the root and all meta regions to be onlineThrown by a region server if it is sent a request for a region it is not serving.Script used evaluating HBase performance and scalability.Base class for operations that are CAS-like; that read a value and then set it based off what they read.Describes a command.Enum for map metrics.MapReduce job that runs a performance evaluation client in each map task.Implementations can have their status set.Wraps up options passed toPerformanceEvaluation
.Code shared by PE tests.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.Thrown if the master requires restart.Utility methods helpful slingingCell
instances.These 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.Constants intended to be used internally.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).Factory for creating cells for CPs.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.The listener interface for receiving region state events.Thrown by a region server if it will block and wait to serve a request.Thrown when a replication peer can not be foundA simple performance evaluation tool for single client and MR scans and snapshot scans.ScanPerformanceEvaluation.MyMapper<KEYOUT,VALUEOUT> 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 Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferThis class is an extension to KeyValue where rowLen and keyLen are cached.This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferThis class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.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 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManagerAvoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566Deprecated.since 3.0.0, will be removed in 4.0.0.Builder pattern for creating anStartMiniClusterOption
.Implementers are Stoppable.Get, remove and modify table descriptors.Thrown when a table exists but should not.Failed to find.tableinfo
file under the table directory.Immutable POJO class for representing a table name.Thrown if a table should be offline but is not.Thrown if a table should be enabled but is not.Thrown when a table cannot be located.Tags are part of cells and helps to add metadata about them.Builder implementation to createTag
Call setTagValue(byte[]) method to createArrayBackedTag
Factory to create Tags.Thrown when we are asked to operate on a region we know nothing about.Thrown if a region server is passed an unknown scanner ID.Encapsulates per-user load metrics.This exception is thrown by the master when a region server reports and is already being processed as dead.Contains a set of methods for the collaboration between the start/stop scripts and the servers.Thrown if the client can't connect to ZooKeeper.
InterfaceAudience.Private
in 4.0.0.