Package org.apache.hadoop.hbase
package org.apache.hadoop.hbase
-
ClassDescriptionorg.apache.hadoop.hbase.AbortableInterface to support the aborting of a given server or client.org.apache.hadoop.hbase.ArrayBackedTagThis is a
Tag
implementation in which value is backed by an on heap byte array.org.apache.hadoop.hbase.AuthUtilDeprecated.org.apache.hadoop.hbase.BaseConfigurableHBase 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)
methodorg.apache.hadoop.hbase.ByteBufferExtendedCellThis class is a server side extension to theCell
interface.org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValueThis 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).org.apache.hadoop.hbase.ByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferorg.apache.hadoop.hbase.ByteBufferTagThis is aTag
implementation in which value is backed byByteBuffer
org.apache.hadoop.hbase.CacheEvictionStatsorg.apache.hadoop.hbase.CacheEvictionStatsAggregatorUsed to merge CacheEvictionStats.org.apache.hadoop.hbase.CacheEvictionStatsBuilderorg.apache.hadoop.hbase.CallDroppedExceptionReturned to the clients when their request was discarded due to server being overloaded.org.apache.hadoop.hbase.CallQueueTooBigExceptionReturned to clients when their request was dropped because the call queue was too big to accept a new call.org.apache.hadoop.hbase.CatalogFamilyFormatHelper class for generating/parsing "info" family cells in meta table.org.apache.hadoop.hbase.CatalogReplicaModeThere are two modes with catalog replica support.org.apache.hadoop.hbase.CellThe unit of storage in HBase consisting of the following fields:org.apache.hadoop.hbase.Cell.TypeThe valid types for user to build the cell.org.apache.hadoop.hbase.CellBuilderUseCellBuilderFactory
to get CellBuilder instance.org.apache.hadoop.hbase.CellBuilderFactoryCreate a CellBuilder instance.org.apache.hadoop.hbase.CellBuilderTypeUsed byCellBuilderFactory
andExtendedCellBuilderFactory
.Comparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestamporg.apache.hadoop.hbase.CellComparatorImplCompare two HBase cells.org.apache.hadoop.hbase.CellScannableImplementer can return a CellScanner over its Cell content.org.apache.hadoop.hbase.CellScannerAn interface for iterating through a sequence of cells.org.apache.hadoop.hbase.CellUtilUtility methods helpful for slingingCell
instances.org.apache.hadoop.hbase.ChoreServiceChoreService is a service that can be used to schedule instances ofScheduledChore
to run periodically while sharing threads.org.apache.hadoop.hbase.ClientMetaTableAccessorThe (asynchronous) meta table accessor used at client side.org.apache.hadoop.hbase.ClientMetaTableAccessor.CloseableVisitorImplementations 'visit' a catalog table row but with close() at the end.org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryTypeorg.apache.hadoop.hbase.ClientMetaTableAccessor.VisitorImplementations 'visit' a catalog table row.org.apache.hadoop.hbase.ClockOutOfSyncExceptionThis exception is thrown by the master when a region server clock skew is too high.org.apache.hadoop.hbase.ClusterIdThe identifier for this cluster.org.apache.hadoop.hbase.ClusterMetricsMetrics information on the HBase cluster.org.apache.hadoop.hbase.ClusterMetrics.OptionKinds of ClusterMetricsorg.apache.hadoop.hbase.ClusterMetricsBuilderorg.apache.hadoop.hbase.CompareOperatorGeneric set of comparison operators.org.apache.hadoop.hbase.CompatibilityFactoryClass that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.org.apache.hadoop.hbase.CompatibilitySingletonFactoryFactory for classes supplied by hadoop compatibility modules.org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorageorg.apache.hadoop.hbase.CompoundConfigurationDo a shallow merge of multiple KV configuration pools.org.apache.hadoop.hbase.ConcurrentTableModificationExceptionThrown when a table has been modified concurrentlyorg.apache.hadoop.hbase.CoordinatedStateManagerImplementations of this interface will keep and return to clients implementations of classes providing API to execute coordinated operations.org.apache.hadoop.hbase.CoprocessorBase interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.org.apache.hadoop.hbase.Coprocessor.StateLifecycle 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.DoNotRetryIOExceptionSubclass if exception is not meant to be retried: e.g.org.apache.hadoop.hbase.DroppedSnapshotExceptionThrown during flush if the possibility snapshot content was not properly persisted into store files.org.apache.hadoop.hbase.ExecutorStatusChoreThe Class ExecutorStatusChore for collect Executor status info periodically and report to metrics systemorg.apache.hadoop.hbase.ExtendedCellExtension toCell
with server side required functions.org.apache.hadoop.hbase.ExtendedCellBuilderFor internal purpose.org.apache.hadoop.hbase.ExtendedCellBuilderFactoryorg.apache.hadoop.hbase.ExtendedCellBuilderImplorg.apache.hadoop.hbase.ExtendedCellScannableWe use this class in HBase internally for gettingExtendedCell
directly without casting.org.apache.hadoop.hbase.ExtendedCellScannerWe use this class in HBase internally for gettingExtendedCell
directly without casting.org.apache.hadoop.hbase.HBaseClusterDeprecated.since 3.0.0, will be removed in 4.0.0.org.apache.hadoop.hbase.HBaseCommonTestingUtilityDeprecated.since 3.0.0, will be removed in 4.0.0.org.apache.hadoop.hbase.HBaseConfigurationAdds HBase configuration files to a Configurationorg.apache.hadoop.hbase.HBaseInterfaceAudienceThis class defines constants for different classes of hbase limited private apisorg.apache.hadoop.hbase.HBaseIOExceptionAll hbase specific IOExceptions should be subclasses of HBaseIOExceptionorg.apache.hadoop.hbase.HBaseRpcServicesBase<S extends org.apache.hadoop.hbase.HBaseServerBase<?>>Base class for Master and RegionServer RpcServices.org.apache.hadoop.hbase.HBaseServerBase<R extends org.apache.hadoop.hbase.HBaseRpcServicesBase<?>>Base class for hbase services, such as master or region server.org.apache.hadoop.hbase.HBaseServerExceptionBase class for exceptions thrown by an HBase server.org.apache.hadoop.hbase.HBaseTestingUtilityDeprecated.since 3.0.0, will be removed in 4.0.0.org.apache.hadoop.hbase.HBaseTestingUtility.SeenRowTrackerA tracker for tracking and validating table rows generated withHBaseTestingUtility.loadTable(Table, byte[])
org.apache.hadoop.hbase.HBaseZKTestingUtilityDeprecated.since 3.0.0, will be removed in 4.0.0.org.apache.hadoop.hbase.HbckEmptyRegionInfoPOJO to present Empty Region Info from Catalog Janitor Inconsistencies Report via REST API.org.apache.hadoop.hbase.HbckInconsistentRegionsPOJO to present HBCK Inconsistent Regions from HBCK Inconsistencies Report via REST API.org.apache.hadoop.hbase.HbckOrphanRegionsOnFSPOJO to present Orphan Region on FS from HBCK Inconsistencies Report via REST API.org.apache.hadoop.hbase.HbckOrphanRegionsOnRSPOJO to present Orphan Region on RS from HBCK Inconsistencies Report via REST API.org.apache.hadoop.hbase.HbckOverlapRegionsPOJO to present Region Overlap from Catalog Janitor Inconsistencies Report via REST API.org.apache.hadoop.hbase.HbckRegionDetailsPOJO class for HBCK RegionInfo in HBCK Inconsistencies report.org.apache.hadoop.hbase.HbckRegionHolesPOJO to present Region Holes from Catalog Janitor Inconsistencies Report via REST API.org.apache.hadoop.hbase.HbckServerNamePOJO class for ServerName in HBCK Inconsistencies report.org.apache.hadoop.hbase.HbckUnknownServersPOJO to present Unknown Regions from Catalog Janitor Inconsistencies Report via REST API.org.apache.hadoop.hbase.HConstantsHConstants holds a bunch of HBase-related constantsorg.apache.hadoop.hbase.HConstants.OperationStatusCodeStatus codes used for return values of bulk operations.org.apache.hadoop.hbase.HDFSBlocksDistributionData structure to describe the distribution of HDFS blocks among hosts.org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeightStores the hostname and weight for that hostname.org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparatorComparator used to sort hosts based on weightorg.apache.hadoop.hbase.HDFSBlocksDistribution.VisitorImplementations 'visit' hostAndWeight.org.apache.hadoop.hbase.HealthCheckChoreThe Class HealthCheckChore for running health checker regularly.org.apache.hadoop.hbase.HFilePerformanceEvaluationThis class runs performance benchmarks forHFile
.org.apache.hadoop.hbase.HRegionLocationData structure to hold RegionInfo and the address for the hosting HRegionServer.org.apache.hadoop.hbase.IndividualBytesFieldCellorg.apache.hadoop.hbase.InnerStoreCellComparatorCompare two HBase cells inner store, skip compare family for better performance.org.apache.hadoop.hbase.InvalidFamilyOperationExceptionThrown if a request is table schema modification is requested but made for an invalid family name.org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImplScheduledThreadPoolExecutor that will add some jitter to the RunnableScheduledFuture.getDelay.org.apache.hadoop.hbase.JMXListenerPluggable 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.KeepDeletedCellsWays to keep cells marked for delete around.org.apache.hadoop.hbase.KeyValueAn HBase Key/Value.org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValueA 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.SamePrefixComparator<T>Avoids redundant comparisons for better performance.org.apache.hadoop.hbase.KeyValue.TypeKey type.org.apache.hadoop.hbase.KeyValueTestUtilorg.apache.hadoop.hbase.KeyValueUtilstatic convenience methods for dealing with KeyValues and collections of KeyValuesorg.apache.hadoop.hbase.LocalHBaseClusterThis class creates a single process HBase cluster.org.apache.hadoop.hbase.MasterNotRunningExceptionThrown if the master is not runningorg.apache.hadoop.hbase.MemoryCompactionPolicyEnum describing all possible memory compaction policiesorg.apache.hadoop.hbase.MetaCellComparatorACellComparatorImpl
forhbase:meta
catalog tableKeyValue
s.org.apache.hadoop.hbase.MetaMutationAnnotationThe field or the parameter to which this annotation can be applied only when it holds mutations for hbase:meta table.org.apache.hadoop.hbase.MetaRegionLocationCacheA cache of meta region location metadata.org.apache.hadoop.hbase.MetaTableAccessorRead/write operations onhbase:meta
region as well as assignment information stored tohbase:meta
.org.apache.hadoop.hbase.MiniHBaseClusterDeprecated.since 3.0.0, will be removed in 4.0.0.org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServerSubclass so can get at protected methods (none at moment).org.apache.hadoop.hbase.MockRegionServerServicesBasic mock region server services.org.apache.hadoop.hbase.MultiActionResultTooLargeException thrown when the result needs to be chunked on the server side.org.apache.hadoop.hbase.NamespaceDescriptorNamespace POJO class.org.apache.hadoop.hbase.NamespaceDescriptor.Builderorg.apache.hadoop.hbase.NamespaceExistExceptionThrown when a namespace exists but should notorg.apache.hadoop.hbase.NamespaceNotFoundExceptionThrown when a namespace can not be locatedorg.apache.hadoop.hbase.NoTagsByteBufferKeyValueAn extension of the ByteBufferKeyValue where the tags length is always 0org.apache.hadoop.hbase.NoTagsKeyValueAn extension of the KeyValue where the tags length is always 0org.apache.hadoop.hbase.NotAllMetaRegionsOnlineExceptionThrown when an operation requires the root and all meta regions to be onlineorg.apache.hadoop.hbase.NotServingRegionExceptionThrown by a region server if it is sent a request for a region it is not serving.org.apache.hadoop.hbase.PerformanceEvaluationScript used evaluating HBase performance and scalability.org.apache.hadoop.hbase.PerformanceEvaluation.CounterEnum for map metrics.org.apache.hadoop.hbase.PerformanceEvaluation.EvaluationMapTaskMapReduce job that runs a performance evaluation client in each map task.org.apache.hadoop.hbase.PerformanceEvaluation.RunResultorg.apache.hadoop.hbase.PerformanceEvaluationCommonsCode shared by PE tests.org.apache.hadoop.hbase.PleaseHoldExceptionThis 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.PleaseRestartMasterExceptionThrown if the master requires restart.org.apache.hadoop.hbase.PrivateCellUtilUtility methods helpful slingingCell
instances.org.apache.hadoop.hbase.PrivateConstantsConstants intended to be used internally.org.apache.hadoop.hbase.RawCellAn extended version of Cell that allows CPs manipulate Tags.org.apache.hadoop.hbase.RawCellBuilderAllows creating a cell withTag
An instance of this type can be acquired by using RegionCoprocessorEnvironment#getCellBuilder (for prod code) andRawCellBuilderFactory
(for unit tests).org.apache.hadoop.hbase.RawCellBuilderFactoryFactory for creating cells for CPs.org.apache.hadoop.hbase.RegionExceptionThrown when something happens related to region handling.org.apache.hadoop.hbase.RegionLocationsContainer for holding a list ofHRegionLocation
's that correspond to the same range.org.apache.hadoop.hbase.RegionMetricsEncapsulates per-region load metrics.org.apache.hadoop.hbase.RegionMetricsBuilderorg.apache.hadoop.hbase.RegionStateListenerThe listener interface for receiving region state events.org.apache.hadoop.hbase.RegionTooBusyExceptionThrown by a region server if it will block and wait to serve a request.org.apache.hadoop.hbase.ReplicationPeerNotFoundExceptionThrown when a replication peer can not be foundorg.apache.hadoop.hbase.RetryImmediatelyExceptionorg.apache.hadoop.hbase.ScanPerformanceEvaluationA simple performance evaluation tool for single client and MR scans and snapshot scans.org.apache.hadoop.hbase.ScanPerformanceEvaluation.MyMapper<KEYOUT,VALUEOUT> org.apache.hadoop.hbase.ScanPerformanceEvaluation.ScanCounterorg.apache.hadoop.hbase.ScheduledChoreScheduledChore is a task performed on a period in hbase.org.apache.hadoop.hbase.ServerDefines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).org.apache.hadoop.hbase.ServerMetricsThis class is used for exporting current state of load on a RegionServer.org.apache.hadoop.hbase.ServerMetricsBuilderorg.apache.hadoop.hbase.ServerNameName of a particular incarnation of an HBase Server.org.apache.hadoop.hbase.ServerTaskInformation about active monitored server tasksorg.apache.hadoop.hbase.ServerTask.StateTask stateorg.apache.hadoop.hbase.ServerTaskBuilderBuilder for information about active monitored server tasksorg.apache.hadoop.hbase.ServiceNotRunningExceptionorg.apache.hadoop.hbase.SizeIt is used to represent the size with different units.org.apache.hadoop.hbase.Size.Unitorg.apache.hadoop.hbase.SizeCachedByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferorg.apache.hadoop.hbase.SizeCachedKeyValueThis class is an extension to KeyValue where rowLen and keyLen are cached.org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferorg.apache.hadoop.hbase.SizeCachedNoTagsKeyValueThis class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.org.apache.hadoop.hbase.SplitLogCountersDeprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManagerorg.apache.hadoop.hbase.SplitLogTaskDeprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManagerorg.apache.hadoop.hbase.SplitLogTask.Doneorg.apache.hadoop.hbase.SplitLogTask.Errorg.apache.hadoop.hbase.SplitLogTask.Ownedorg.apache.hadoop.hbase.SplitLogTask.Resignedorg.apache.hadoop.hbase.SplitLogTask.Unassignedorg.apache.hadoop.hbase.SslRMIClientSocketFactorySecureAvoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566org.apache.hadoop.hbase.SslRMIServerSocketFactorySecureAvoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566org.apache.hadoop.hbase.StartMiniClusterOptionDeprecated.since 3.0.0, will be removed in 4.0.0.org.apache.hadoop.hbase.StartMiniClusterOption.BuilderBuilder pattern for creating anStartMiniClusterOption
.org.apache.hadoop.hbase.StoppableImplementers are Stoppable.org.apache.hadoop.hbase.TableDescriptorsGet, remove and modify table descriptors.org.apache.hadoop.hbase.TableExistsExceptionThrown when a table exists but should not.org.apache.hadoop.hbase.TableInfoMissingExceptionFailed to find.tableinfo
file under the table directory.org.apache.hadoop.hbase.TableNameImmutable POJO class for representing a table name.org.apache.hadoop.hbase.TableNotDisabledExceptionThrown if a table should be offline but is not.org.apache.hadoop.hbase.TableNotEnabledExceptionThrown if a table should be enabled but is not.org.apache.hadoop.hbase.TableNotFoundExceptionThrown when a table cannot be located.org.apache.hadoop.hbase.TagTags are part of cells and helps to add metadata about them.org.apache.hadoop.hbase.TagBuilderBuilder implementation to createTag
Call setTagValue(byte[]) method to createArrayBackedTag
org.apache.hadoop.hbase.TagBuilderFactoryFactory to create Tags.org.apache.hadoop.hbase.TagTypeorg.apache.hadoop.hbase.TagUtilorg.apache.hadoop.hbase.UnknownRegionExceptionThrown when we are asked to operate on a region we know nothing about.org.apache.hadoop.hbase.UnknownScannerExceptionThrown if a region server is passed an unknown scanner ID.Encapsulates per-user load metrics.org.apache.hadoop.hbase.UserMetrics.ClientMetricsorg.apache.hadoop.hbase.UserMetricsBuilderorg.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImplorg.apache.hadoop.hbase.YouAreDeadExceptionThis exception is thrown by the master when a region server reports and is already being processed as dead.org.apache.hadoop.hbase.ZNodeClearerContains a set of methods for the collaboration between the start/stop scripts and the servers.org.apache.hadoop.hbase.ZooKeeperConnectionExceptionThrown if the client can't connect to ZooKeeper.
InterfaceAudience.Private
in 4.0.0.