Interface | Description |
---|---|
Abortable |
Interface to support the aborting of a given server or client.
|
Cell |
The unit of storage in HBase consisting of the following fields:
|
CellScannable |
Implementer can return a CellScanner over its Cell content.
|
CellScanner |
An interface for iterating through a sequence of cells.
|
CoordinatedStateManager |
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
Coprocessor |
Coprocessor interface.
|
CoprocessorEnvironment |
Coprocessor environment state.
|
InterProcessLock |
An interface for an application-specific lock.
|
InterProcessLock.MetadataHandler |
An interface for objects that process lock metadata.
|
InterProcessReadWriteLock |
An interface for a distributed reader-writer lock.
|
KeyValue.SamePrefixComparator<T> |
Avoids redundant comparisons for better performance.
|
MetaTableAccessor.Visitor |
Implementations 'visit' a catalog table row.
|
RegionStateListener |
The listener interface for receiving region state events.
|
Server |
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
SettableSequenceId |
Using this Interface one can mark a Cell as Sequence stampable.
|
SettableTimestamp |
Using this Interface one can mark a Cell as timestamp changeable.
|
Stoppable |
Implementers are Stoppable.
|
TableDescriptors |
Get, remove and modify table descriptors.
|
TableStateManager |
Helper class for table state management for operations running inside
RegionServer or HMaster.
|
Class | Description |
---|---|
AsyncConsoleAppender |
Logger class that buffers before trying to log to the specified console.
|
AuthUtil |
Utility methods for helping with security tasks.
|
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 |
CellComparator |
Compare two HBase cells.
|
CellComparator.RowComparator |
Counter part for the KeyValue.RowOnlyComparator
|
CellUtil |
Utility methods helpful slinging
Cell instances. |
ChoreService |
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
ClusterId |
The identifier for this cluster.
|
ClusterStatus |
Status information on the HBase cluster.
|
CompatibilityFactory |
Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.
|
CompatibilitySingletonFactory |
Factory for classes supplied by hadoop compatibility modules.
|
CompoundConfiguration |
Do a shallow merge of multiple KV configuration pools.
|
CoordinatedStateManagerFactory |
Creates instance of
CoordinatedStateManager
based on configuration. |
DaemonThreadFactory |
Thread factory that creates daemon threads
|
HBaseConfiguration |
Adds HBase configuration files to a Configuration
|
HBaseInterfaceAudience |
This class defines constants for different classes of hbase limited private apis
|
HColumnDescriptor |
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HConstants |
HConstants holds a bunch of HBase-related constants
|
HDFSBlocksDistribution |
Data structure to describe the distribution of HDFS blocks among hosts.
|
HDFSBlocksDistribution.HostAndWeight |
Stores the hostname and weight for that hostname.
|
HDFSBlocksDistribution.HostAndWeight.WeightComparator |
comparator used to sort hosts based on weight
|
HealthCheckChore |
The Class HealthCheckChore for running health checker regularly.
|
HRegionInfo |
Information about a region.
|
HRegionLocation |
Data structure to hold HRegionInfo and the address for the hosting
HRegionServer.
|
HTableDescriptor |
HTableDescriptor contains the details about an HBase table such as the descriptors of
all the column families, is the table a catalog table,
-ROOT- or
hbase:meta , if the table is read only, the maximum size of the memstore,
when the region split should occur, coprocessors associated with it etc... |
JitterScheduledThreadPoolExecutorImpl |
ScheduledThreadPoolExecutor that will add some jitter to the RunnableScheduledFuture.getDelay.
|
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)
|
KeyValue |
An HBase Key/Value.
|
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.
|
KeyValue.KVComparator |
Compare KeyValues.
|
KeyValue.MetaComparator | |
KeyValue.RawBytesComparator |
This is a TEST only Comparator used in TestSeekTo and TestReseekTo.
|
KeyValue.RowOnlyComparator |
Comparator that compares row component only of a KeyValue.
|
KeyValueTestUtil | |
KeyValueUtil |
static convenience methods for dealing with KeyValues and collections of KeyValues
|
LocalHBaseCluster |
This class creates a single process HBase cluster.
|
MetaMigrationConvertingToPB | Deprecated
will be removed for the major release after 0.96.
|
MetaTableAccessor |
Read/write operations on region and assignment information store in
hbase:meta . |
NamespaceDescriptor |
Namespace POJO class.
|
NamespaceDescriptor.Builder | |
NoTagsKeyValue |
An extension of the KeyValue where the tags length is always 0
|
ProcedureInfo |
Procedure information
|
RegionLoad |
Encapsulates per-region load metrics.
|
RegionLocations |
Container for holding a list of
HRegionLocation 's that correspond to the
same range. |
RegionTransition |
Current state of a region in transition.
|
RemoteExceptionHandler |
An immutable class which contains a static method for handling
org.apache.hadoop.ipc.RemoteException exceptions.
|
ScheduledChore |
ScheduledChore is a task performed on a period in hbase.
|
ServerLoad |
This class is used for exporting current state of load on a RegionServer.
|
ServerName |
Instance of an HBase ServerName.
|
SplitLogCounters |
Counters kept by the distributed WAL split log process.
|
SplitLogTask |
State of a WAL log split during distributed splitting.
|
SplitLogTask.Done | |
SplitLogTask.Err | |
SplitLogTask.Owned | |
SplitLogTask.Resigned | |
SplitLogTask.Unassigned | |
SslRMIClientSocketFactorySecure |
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
|
SslRMIServerSocketFactorySecure |
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
|
TableName |
Immutable POJO class for representing a table name.
|
Tag |
Tags are part of cells and helps to add metadata about the KVs.
|
TagRewriteCell |
This can be used when a Cell has to change with addition/removal of one or more tags.
|
TagType | |
Version | |
ZKNamespaceManager |
Class servers two purposes:
1.
|
ZNodeClearer |
Contains a set of methods for the collaboration between the start/stop scripts and the
servers.
|
Enum | Description |
---|---|
CompatibilitySingletonFactory.SingletonStorage | |
Coprocessor.State |
Lifecycle state of a given coprocessor instance.
|
HConstants.Modify |
modifyTable op for replacing the table descriptor
|
HConstants.OperationStatusCode |
Status codes used for return values of bulk operations.
|
KeepDeletedCells |
Ways to keep cells marked for delete around.
|
KeyValue.Type |
Key type.
|
Exception | Description |
---|---|
CallDroppedException |
Returned to the clients when their request was discarded due to server being overloaded.
|
CallQueueTooBigException | |
ClockOutOfSyncException |
This exception is thrown by the master when a region server clock skew is
too high.
|
CoordinatedStateException |
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
|
DoNotRetryIOException |
Subclass if exception is not meant to be retried: e.g.
|
DroppedSnapshotException |
Thrown during flush if the possibility snapshot content was not properly
persisted into store files.
|
HBaseIOException |
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
InvalidFamilyOperationException |
Thrown if a request is table schema modification is requested but
made for an invalid family name.
|
MasterNotRunningException |
Thrown if the master is not running
|
MultiActionResultTooLarge |
Exception thrown when the result needs to be chunked on the server side.
|
NamespaceExistException |
Thrown when a namespace exists but should not
|
NamespaceNotFoundException |
Thrown when a namespace can not be located
|
NotAllMetaRegionsOnlineException |
Thrown when an operation requires the root and all meta regions to be online
|
NotServingRegionException |
Thrown by a region server if it is sent a request for a region it is not serving.
|
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.
|
RegionException |
Thrown when something happens related to region handling.
|
RegionTooBusyException |
Thrown by a region server if it will block and wait to serve a request.
|
RetryImmediatelyException | |
TableExistsException |
Thrown when a table exists but should not.
|
TableInfoMissingException |
Failed to find
.tableinfo file under the table directory. |
TableNotDisabledException |
Thrown if a table should be offline but is not.
|
TableNotEnabledException |
Thrown if a table should be enabled but is not.
|
TableNotFoundException |
Thrown when a table cannot be located.
|
UnknownRegionException |
Thrown when we are asked to operate on a region we know nothing about.
|
UnknownScannerException |
Thrown if a region server is passed an unknown scanner ID.
|
YouAreDeadException |
This exception is thrown by the master when a region server reports and is
already being processed as dead.
|
ZooKeeperConnectionException |
Thrown if the client can't connect to ZooKeeper.
|
Annotation Type | Description |
---|---|
MetaMutationAnnotation |
The field or the parameter to which this annotation can be applied only when it
holds mutations for hbase:meta table.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.