Package org.apache.hadoop.hbase


package org.apache.hadoop.hbase
  • Class
    Description
    org.apache.hadoop.hbase.Abortable
    Interface to support the aborting of a given server or client.
    org.apache.hadoop.hbase.ArrayBackedTag
    This is a Tag implementation in which value is backed by an on heap byte array.
    org.apache.hadoop.hbase.AsyncMetaTableAccessor
    The asynchronous meta table accessor.
    org.apache.hadoop.hbase.AuthUtil
    Deprecated.
    since 2.2.0, to be marked as InterfaceAudience.Private in 4.0.0.
    org.apache.hadoop.hbase.BaseConfigurable
    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 the BaseConfigurable.setConf(Configuration) method
    org.apache.hadoop.hbase.ByteBufferExtendedCell
    This class is a server side extension to the Cell interface.
    org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
    This 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).
    org.apache.hadoop.hbase.ByteBufferKeyValue
    This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
    org.apache.hadoop.hbase.ByteBufferTag
    This is a Tag implementation in which value is backed by ByteBuffer
    org.apache.hadoop.hbase.CacheEvictionStats
     
    org.apache.hadoop.hbase.CacheEvictionStatsAggregator
    Used to merge CacheEvictionStats.
    org.apache.hadoop.hbase.CacheEvictionStatsBuilder
     
    org.apache.hadoop.hbase.CallDroppedException
    Returned to the clients when their request was discarded due to server being overloaded.
    org.apache.hadoop.hbase.CallQueueTooBigException
    Returned to clients when their request was dropped because the call queue was too big to accept a new call.
    org.apache.hadoop.hbase.CatalogReplicaMode
    There are two modes with catalog replica support.
    org.apache.hadoop.hbase.Cell
    The unit of storage in HBase consisting of the following fields:
    org.apache.hadoop.hbase.Cell.Type
    The valid types for user to build the cell.
    org.apache.hadoop.hbase.CellBuilder
    Use CellBuilderFactory to get CellBuilder instance.
    org.apache.hadoop.hbase.CellBuilderFactory
    Create a CellBuilder instance.
    org.apache.hadoop.hbase.CellBuilderType
    Used by CellBuilderFactory and ExtendedCellBuilderFactory.
    Comparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestamp
    org.apache.hadoop.hbase.CellComparatorImpl
    Compare two HBase cells.
    org.apache.hadoop.hbase.CellScannable
    Implementer can return a CellScanner over its Cell content.
    org.apache.hadoop.hbase.CellScanner
    An interface for iterating through a sequence of cells.
    org.apache.hadoop.hbase.CellUtil
    Utility methods helpful for slinging Cell instances.
    org.apache.hadoop.hbase.ChoreService
    ChoreService is a service that can be used to schedule instances of ScheduledChore to run periodically while sharing threads.
    org.apache.hadoop.hbase.ClockOutOfSyncException
    This exception is thrown by the master when a region server clock skew is too high.
    org.apache.hadoop.hbase.ClusterId
    The identifier for this cluster.
    org.apache.hadoop.hbase.ClusterMetrics
    Metrics information on the HBase cluster.
    org.apache.hadoop.hbase.ClusterMetrics.Option
    Kinds of ClusterMetrics
    org.apache.hadoop.hbase.ClusterMetricsBuilder
     
    org.apache.hadoop.hbase.ClusterStatus
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics instead.
    org.apache.hadoop.hbase.CompareOperator
    Generic set of comparison operators.
    org.apache.hadoop.hbase.CompatibilityFactory
    Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.
    org.apache.hadoop.hbase.CompatibilitySingletonFactory
    Factory for classes supplied by hadoop compatibility modules.
    org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
     
    org.apache.hadoop.hbase.CompoundConfiguration
    Do a shallow merge of multiple KV configuration pools.
    org.apache.hadoop.hbase.ConcurrentTableModificationException
    Thrown when a table has been modified concurrently
    org.apache.hadoop.hbase.CoordinatedStateManager
    Implementations of this interface will keep and return to clients implementations of classes providing API to execute coordinated operations.
    org.apache.hadoop.hbase.Coprocessor
    Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.
    org.apache.hadoop.hbase.Coprocessor.State
    Lifecycle state of a given coprocessor instance.
    org.apache.hadoop.hbase.CoprocessorEnvironment<C extends org.apache.hadoop.hbase.Coprocessor>
    Coprocessor environment state.
    org.apache.hadoop.hbase.DaemonThreadFactory
    Thread factory that creates daemon threads
    org.apache.hadoop.hbase.DoNotRetryIOException
    Subclass if exception is not meant to be retried: e.g.
    org.apache.hadoop.hbase.DroppedSnapshotException
    Thrown during flush if the possibility snapshot content was not properly persisted into store files.
    org.apache.hadoop.hbase.ExtendedCell
    Extension to Cell with server side required functions.
    org.apache.hadoop.hbase.ExtendedCellBuilder
    For internal purpose.
    org.apache.hadoop.hbase.ExtendedCellBuilderFactory
     
    org.apache.hadoop.hbase.ExtendedCellBuilderImpl
     
    org.apache.hadoop.hbase.FailedCloseWALAfterInitializedErrorException
    Throw when failed cleanup unsuccessful initialized wal
    org.apache.hadoop.hbase.HBaseConfiguration
    Adds HBase configuration files to a Configuration
    org.apache.hadoop.hbase.HBaseInterfaceAudience
    This class defines constants for different classes of hbase limited private apis
    org.apache.hadoop.hbase.HBaseIOException
    All hbase specific IOExceptions should be subclasses of HBaseIOException
    org.apache.hadoop.hbase.HBaseServerException
    Base class for exceptions thrown by an HBase server.
    org.apache.hadoop.hbase.HbckEmptyRegionInfo
    POJO to present Empty Region Info from Catalog Janitor Inconsistencies Report via REST API.
    org.apache.hadoop.hbase.HbckInconsistentRegions
    POJO to present HBCK Inconsistent Regions from HBCK Inconsistencies Report via REST API.
    org.apache.hadoop.hbase.HbckOrphanRegionsOnFS
    POJO to present Orphan Region on FS from HBCK Inconsistencies Report via REST API.
    org.apache.hadoop.hbase.HbckOrphanRegionsOnRS
    POJO to present Orphan Region on RS from HBCK Inconsistencies Report via REST API.
    org.apache.hadoop.hbase.HbckOverlapRegions
    POJO to present Region Overlap from Catalog Janitor Inconsistencies Report via REST API.
    org.apache.hadoop.hbase.HbckRegionDetails
    POJO class for HBCK RegionInfo in HBCK Inconsistencies report.
    org.apache.hadoop.hbase.HbckRegionHoles
    POJO to present Region Holes from Catalog Janitor Inconsistencies Report via REST API.
    org.apache.hadoop.hbase.HbckServerName
    POJO class for ServerName in HBCK Inconsistencies report.
    org.apache.hadoop.hbase.HbckUnknownServers
    POJO to present Unknown Regions from Catalog Janitor Inconsistencies Report via REST API.
    org.apache.hadoop.hbase.HColumnDescriptor
    Deprecated.
    org.apache.hadoop.hbase.HConstants
    HConstants holds a bunch of HBase-related constants
    org.apache.hadoop.hbase.HConstants.OperationStatusCode
    Status codes used for return values of bulk operations.
    org.apache.hadoop.hbase.HDFSBlocksDistribution
    Data structure to describe the distribution of HDFS blocks among hosts.
    org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
    Stores the hostname and weight for that hostname.
    org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
    Comparator used to sort hosts based on weight
    org.apache.hadoop.hbase.HDFSBlocksDistribution.Visitor
    Implementations 'visit' hostAndWeight.
    org.apache.hadoop.hbase.HealthCheckChore
    The Class HealthCheckChore for running health checker regularly.
    org.apache.hadoop.hbase.HRegionInfo
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.HRegionLocation
    Data structure to hold RegionInfo and the address for the hosting HRegionServer.
    org.apache.hadoop.hbase.HTableDescriptor
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.IndividualBytesFieldCell
     
    org.apache.hadoop.hbase.InnerStoreCellComparator
    Compare two HBase cells inner store, skip compare family for better performance.
    org.apache.hadoop.hbase.InvalidFamilyOperationException
    Thrown if a request is table schema modification is requested but made for an invalid family name.
    org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl
    ScheduledThreadPoolExecutor that will add some jitter to the RunnableScheduledFuture.getDelay.
    org.apache.hadoop.hbase.JMXListener
    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)
    org.apache.hadoop.hbase.KeepDeletedCells
    Ways to keep cells marked for delete around.
    org.apache.hadoop.hbase.KeyValue
    An HBase Key/Value.
    org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
    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.
    org.apache.hadoop.hbase.KeyValue.KVComparator
    Deprecated.
    : Use CellComparatorImpl.
    org.apache.hadoop.hbase.KeyValue.MetaComparator
    Deprecated.
    : MetaCellComparator.META_COMPARATOR to be used.
    org.apache.hadoop.hbase.KeyValue.SamePrefixComparator<T>
    Avoids redundant comparisons for better performance.
    org.apache.hadoop.hbase.KeyValue.Type
    Key type.
    org.apache.hadoop.hbase.KeyValueTestUtil
     
    org.apache.hadoop.hbase.KeyValueUtil
    static convenience methods for dealing with KeyValues and collections of KeyValues
    org.apache.hadoop.hbase.LocalHBaseCluster
    This class creates a single process HBase cluster.
    org.apache.hadoop.hbase.MasterNotRunningException
    Thrown if the master is not running
    org.apache.hadoop.hbase.MemoryCompactionPolicy
    Enum describing all possible memory compaction policies
    org.apache.hadoop.hbase.MetaCellComparator
    A CellComparatorImpl for hbase:meta catalog table KeyValues.
    org.apache.hadoop.hbase.MetaMutationAnnotation
    The field or the parameter to which this annotation can be applied only when it holds mutations for hbase:meta table.
    org.apache.hadoop.hbase.MetaRegionLocationCache
    A cache of meta region location metadata.
    org.apache.hadoop.hbase.MetaTableAccessor
    Read/write operations on hbase:meta region as well as assignment information stored to hbase:meta.
    org.apache.hadoop.hbase.MetaTableAccessor.CloseableVisitor
    Implementations 'visit' a catalog table row but with close() at the end.
    org.apache.hadoop.hbase.MetaTableAccessor.DefaultVisitorBase
    A Visitor that skips offline regions and split parents
    org.apache.hadoop.hbase.MetaTableAccessor.QueryType
     
    org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
     
    org.apache.hadoop.hbase.MetaTableAccessor.TableVisitorBase
    A Visitor for a table.
    org.apache.hadoop.hbase.MetaTableAccessor.Visitor
    Implementations 'visit' a catalog table row.
    org.apache.hadoop.hbase.MultiActionResultTooLarge
    Exception thrown when the result needs to be chunked on the server side.
    org.apache.hadoop.hbase.NamespaceDescriptor
    Namespace POJO class.
    org.apache.hadoop.hbase.NamespaceDescriptor.Builder
     
    org.apache.hadoop.hbase.NamespaceExistException
    Thrown when a namespace exists but should not
    org.apache.hadoop.hbase.NamespaceNotFoundException
    Thrown when a namespace can not be located
    org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
    An extension of the ByteBufferKeyValue where the tags length is always 0
    org.apache.hadoop.hbase.NoTagsKeyValue
    An extension of the KeyValue where the tags length is always 0
    org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
    Thrown when an operation requires the root and all meta regions to be online
    org.apache.hadoop.hbase.NotServingRegionException
    Thrown by a region server if it is sent a request for a region it is not serving.
    org.apache.hadoop.hbase.PleaseHoldException
    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.
    org.apache.hadoop.hbase.PleaseRestartMasterException
    Thrown if the master requires restart.
    org.apache.hadoop.hbase.PrivateCellUtil
    Utility methods helpful slinging Cell instances.
    org.apache.hadoop.hbase.RawCell
    An extended version of Cell that allows CPs manipulate Tags.
    org.apache.hadoop.hbase.RawCellBuilder
    Allows creating a cell with Tag An instance of this type can be acquired by using RegionCoprocessorEnvironment#getCellBuilder (for prod code) and RawCellBuilderFactory (for unit tests).
    org.apache.hadoop.hbase.RawCellBuilderFactory
    Factory for creating cells for CPs.
    org.apache.hadoop.hbase.RegionException
    Thrown when something happens related to region handling.
    org.apache.hadoop.hbase.RegionLoad
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionMetrics instead.
    org.apache.hadoop.hbase.RegionLocations
    Container for holding a list of HRegionLocation's that correspond to the same range.
    org.apache.hadoop.hbase.RegionMetrics
    Encapsulates per-region load metrics.
    org.apache.hadoop.hbase.RegionMetricsBuilder
     
    org.apache.hadoop.hbase.RegionStateListener
    The listener interface for receiving region state events.
    org.apache.hadoop.hbase.RegionTooBusyException
    Thrown by a region server if it will block and wait to serve a request.
    org.apache.hadoop.hbase.ReplicationPeerNotFoundException
    Thrown when a replication peer can not be found
    org.apache.hadoop.hbase.RetryImmediatelyException
     
    org.apache.hadoop.hbase.RSGroupTableAccessor
    Read rs group information from hbase:rsgroup.
    org.apache.hadoop.hbase.ScheduledChore
    ScheduledChore is a task performed on a period in hbase.
    org.apache.hadoop.hbase.Server
    Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).
    org.apache.hadoop.hbase.ServerLoad
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerMetrics instead.
    org.apache.hadoop.hbase.ServerMetrics
    This class is used for exporting current state of load on a RegionServer.
    org.apache.hadoop.hbase.ServerMetricsBuilder
     
    org.apache.hadoop.hbase.ServerName
    Name of a particular incarnation of an HBase Server.
    org.apache.hadoop.hbase.ServerTask
    Information about active monitored server tasks
    org.apache.hadoop.hbase.ServerTask.State
    Task state
    org.apache.hadoop.hbase.ServerTaskBuilder
    Builder for information about active monitored server tasks
    org.apache.hadoop.hbase.ServiceNotRunningException
     
    org.apache.hadoop.hbase.SharedConnection
    Wraps a Connection to make it can't be closed or aborted.
    org.apache.hadoop.hbase.Size
    It is used to represent the size with different units.
    org.apache.hadoop.hbase.Size.Unit
     
    org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
    This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
    org.apache.hadoop.hbase.SizeCachedKeyValue
    This class is an extension to KeyValue where rowLen and keyLen are cached.
    org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
    This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
    org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
    This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.
    org.apache.hadoop.hbase.SplitLogCounters
    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
    org.apache.hadoop.hbase.SplitLogTask
    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
    org.apache.hadoop.hbase.SplitLogTask.Done
     
    org.apache.hadoop.hbase.SplitLogTask.Err
     
    org.apache.hadoop.hbase.SplitLogTask.Owned
     
    org.apache.hadoop.hbase.SplitLogTask.Resigned
     
    org.apache.hadoop.hbase.SplitLogTask.Unassigned
     
    org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
    Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
    org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
    Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
    org.apache.hadoop.hbase.Stoppable
    Implementers are Stoppable.
    org.apache.hadoop.hbase.TableDescriptors
    Get, remove and modify table descriptors.
    org.apache.hadoop.hbase.TableExistsException
    Thrown when a table exists but should not.
    org.apache.hadoop.hbase.TableInfoMissingException
    Failed to find .tableinfo file under the table directory.
    org.apache.hadoop.hbase.TableName
    Immutable POJO class for representing a table name.
    org.apache.hadoop.hbase.TableNotDisabledException
    Thrown if a table should be offline but is not.
    org.apache.hadoop.hbase.TableNotEnabledException
    Thrown if a table should be enabled but is not.
    org.apache.hadoop.hbase.TableNotFoundException
    Thrown when a table cannot be located.
    org.apache.hadoop.hbase.Tag
    Tags are part of cells and helps to add metadata about them.
    org.apache.hadoop.hbase.TagBuilder
    Builder implementation to create Tag Call setTagValue(byte[]) method to create ArrayBackedTag
    org.apache.hadoop.hbase.TagBuilderFactory
    Factory to create Tags.
    org.apache.hadoop.hbase.TagType
     
    org.apache.hadoop.hbase.TagUtil
     
    org.apache.hadoop.hbase.UnknownRegionException
    Thrown when we are asked to operate on a region we know nothing about.
    org.apache.hadoop.hbase.UnknownScannerException
    Thrown if a region server is passed an unknown scanner ID.
    Encapsulates per-user load metrics.
    org.apache.hadoop.hbase.UserMetrics.ClientMetrics
     
    org.apache.hadoop.hbase.UserMetricsBuilder
     
    org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
     
    org.apache.hadoop.hbase.YouAreDeadException
    This exception is thrown by the master when a region server reports and is already being processed as dead.
    org.apache.hadoop.hbase.ZKNamespaceManager
    Class servers two purposes: 1.
    org.apache.hadoop.hbase.ZNodeClearer
    Contains a set of methods for the collaboration between the start/stop scripts and the servers.
    org.apache.hadoop.hbase.ZooKeeperConnectionException
    Thrown if the client can't connect to ZooKeeper.