Class and 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:
|
CellComparator
Compare two HBase cells.
|
CellScannable
Implementer can return a CellScanner over its Cell content.
|
CellScanner
An interface for iterating through a sequence of cells.
|
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.SingletonStorage |
CompoundConfiguration
Do a shallow merge of multiple KV configuration pools.
|
CompoundConfiguration.ImmutableConfigMap |
CoordinatedStateException
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
|
CoordinatedStateManager
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
Coprocessor
Coprocessor interface.
|
Coprocessor.State
Lifecycle state of a given coprocessor instance.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HConstants.Modify
modifyTable op for replacing the table descriptor
|
HConstants.OperationStatusCode
Status codes used for return values of bulk operations.
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HDFSBlocksDistribution.HostAndWeight
Stores the hostname and weight for that hostname.
|
HealthChecker
A utility for executing an external script that checks the health of
the node.
|
HealthChecker.HealthCheckerExitStatus |
HealthReport
The Class HealthReport containing information about health of the node.
|
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... |
InterProcessLock
An interface for an application-specific lock.
|
InterProcessLock.MetadataHandler
An interface for objects that process lock metadata.
|
KeepDeletedCells
Ways to keep cells marked for delete around.
|
KeyValue
An HBase Key/Value.
|
KeyValue.KVComparator
Compare KeyValues.
|
KeyValue.SamePrefixComparator
Avoids redundant comparisons for better performance.
|
KeyValue.Type
Key type.
|
MetaTableAccessor.CollectingVisitor
A
MetaTableAccessor.Visitor that collects content out of passed Result . |
MetaTableAccessor.Visitor
Implementations 'visit' a catalog table row.
|
NamespaceDescriptor
Namespace POJO class.
|
NamespaceDescriptor.Builder |
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
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.
|
RetryImmediatelyException |
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ScheduledChore.ChoreServicer |
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerLoad
This class is used for exporting current state of load on a RegionServer.
|
ServerName
Instance of an HBase ServerName.
|
SettableSequenceId
Using this Interface one can mark a Cell as Sequence stampable.
|
SettableTimestamp
Using this Interface one can mark a Cell as timestamp changeable.
|
SplitLogTask
State of a WAL log split during distributed splitting.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
TableStateManager
Helper class for table state management for operations running inside
RegionServer or HMaster.
|
Tag
Tags are part of cells and helps to add metadata about the KVs.
|
Class and Description |
---|
HRegionInfo
Information about a region.
|
Class and Description |
---|
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 |
Stoppable
Implementers are Stoppable.
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Class and 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.
|
ClusterStatus
Status information on the HBase cluster.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
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... |
KeyValue
An HBase Key/Value.
|
KeyValue.KVComparator
Compare KeyValues.
|
KeyValue.MetaComparator |
MasterNotRunningException
Thrown if the master is not running
|
NamespaceDescriptor
Namespace POJO class.
|
ProcedureInfo
Procedure information
|
RegionException
Thrown when something happens related to region handling.
|
RegionLocations
Container for holding a list of
HRegionLocation 's that correspond to the
same range. |
ServerName
Instance of an HBase ServerName.
|
TableExistsException
Thrown when a table exists but should not
|
TableName
Immutable POJO class for representing a table name.
|
TableNotFoundException
Thrown when a table can not be located
|
Tag
Tags are part of cells and helps to add metadata about the KVs.
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Class and Description |
---|
ServerName
Instance of an HBase ServerName.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
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... |
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
KeyValue.KVComparator
Compare KeyValues.
|
SettableSequenceId
Using this Interface one can mark a Cell as Sequence stampable.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
KeyValue.Type
Key type.
|
SettableSequenceId
Using this Interface one can mark a Cell as Sequence stampable.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
Class and Description |
---|
Coprocessor
Coprocessor interface.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
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... |
Class and Description |
---|
CoordinatedStateException
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
|
CoordinatedStateManager
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
HRegionInfo
Information about a region.
|
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Instance of an HBase ServerName.
|
SplitLogTask
State of a WAL log split during distributed splitting.
|
TableStateManager
Helper class for table state management for operations running inside
RegionServer or HMaster.
|
Class and 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:
|
CellScanner
An interface for iterating through a sequence of cells.
|
Coprocessor
Coprocessor interface.
|
Coprocessor.State
Lifecycle state of a given coprocessor instance.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HRegionInfo
Information about a region.
|
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... |
MetaMutationAnnotation
The field or the parameter to which this annotation can be applied only when it
holds mutations for hbase:meta table.
|
NamespaceDescriptor
Namespace POJO class.
|
ProcedureInfo
Procedure information
|
ServerName
Instance of an HBase ServerName.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Coprocessor
Coprocessor interface.
|
CoprocessorEnvironment
Coprocessor environment state.
|
Class and Description |
---|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
NotServingRegionException
Thrown by a region server if it is sent a request for a region it is not
serving.
|
ServerName
Instance of an HBase ServerName.
|
Class and Description |
---|
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
KeyValue
An HBase Key/Value.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
HRegionInfo
Information about a region.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
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.SamePrefixComparator
Avoids redundant comparisons for better performance.
|
SettableSequenceId
Using this Interface one can mark a Cell as Sequence stampable.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
KeyValue.KVComparator
Compare KeyValues.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
CallQueueTooBigException |
CellScannable
Implementer can return a CellScanner over its Cell content.
|
CellScanner
An interface for iterating through a sequence of cells.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Instance of an HBase ServerName.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Compare two HBase cells.
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HRegionInfo
Information about a region.
|
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... |
KeyValue
An HBase Key/Value.
|
TableName
Immutable POJO class for representing a table name.
|
TableNotFoundException
Thrown when a table can not be located
|
Tag
Tags are part of cells and helps to add metadata about the KVs.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ChoreService
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
ClockOutOfSyncException
This exception is thrown by the master when a region server clock skew is
too high.
|
ClusterId
The identifier for this cluster.
|
ClusterStatus
Status information on the HBase cluster.
|
CoordinatedStateException
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
|
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.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HRegionInfo
Information about a region.
|
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... |
InterProcessLock
An interface for an application-specific lock.
|
InterProcessLock.MetadataHandler
An interface for objects that process lock metadata.
|
LocalHBaseCluster
This class creates a single process HBase cluster.
|
NamespaceDescriptor
Namespace POJO class.
|
NamespaceNotFoundException
Thrown when a namespace can not be located
|
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.
|
ProcedureInfo
Procedure information
|
RegionStateListener
The listener interface for receiving region state events.
|
RegionTransition
Current state of a region in transition.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerLoad
This class is used for exporting current state of load on a RegionServer.
|
ServerName
Instance of an HBase ServerName.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
TableNotDisabledException
Thrown if a table should be offline but is not
|
TableNotFoundException
Thrown when a table can not be located
|
TableStateManager
Helper class for table state management for operations running inside
RegionServer or HMaster.
|
YouAreDeadException
This exception is thrown by the master when a region server reports and is
already being processed as dead.
|
ZKNamespaceManager
Class servers two purposes:
1.
|
Class and Description |
---|
ClusterStatus
Status information on the HBase cluster.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HRegionInfo
Information about a region.
|
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... |
RegionLoad
Encapsulates per-region load metrics.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ServerName
Instance of an HBase ServerName.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
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 |
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
CoordinatedStateException
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
|
HRegionInfo
Information about a region.
|
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... |
InvalidFamilyOperationException
Thrown if a request is table schema modification is requested but
made for an invalid family name.
|
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
RegionLoad
Encapsulates per-region load metrics.
|
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Instance of an HBase ServerName.
|
TableExistsException
Thrown when a table exists but should not
|
TableName
Immutable POJO class for representing a table name.
|
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 can not be located
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HRegionInfo
Information about a region.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
CoordinatedStateException
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HRegionInfo
Information about a region.
|
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... |
ServerName
Instance of an HBase ServerName.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
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 |
HRegionInfo
Information about a region.
|
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... |
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
ServerName
Instance of an HBase ServerName.
|
Stoppable
Implementers are Stoppable.
|
TableExistsException
Thrown when a table exists but should not
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
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... |
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
HRegionInfo
Information about a region.
|
NamespaceDescriptor
Namespace POJO class.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
ProcedureInfo
Procedure information
|
Class and Description |
---|
ProcedureInfo
Procedure information
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
ProcedureInfo
Procedure information
|
Class and Description |
---|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HRegionInfo
Information about a region.
|
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... |
NamespaceDescriptor
Namespace POJO class.
|
RegionStateListener
The listener interface for receiving region state events.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and 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.
|
ChoreService
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
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.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HConstants.OperationStatusCode
Status codes used for return values of bulk operations.
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HealthCheckChore
The Class HealthCheckChore for running health checker regularly.
|
HRegionInfo
Information about a region.
|
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... |
KeepDeletedCells
Ways to keep cells marked for delete around.
|
KeyValue
An HBase Key/Value.
|
KeyValue.KVComparator
Compare KeyValues.
|
MetaMutationAnnotation
The field or the parameter to which this annotation can be applied only when it
holds mutations for hbase:meta table.
|
NotServingRegionException
Thrown by a region server if it is sent a request for a region it is not
serving.
|
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.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Instance of an HBase ServerName.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about the KVs.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
HRegionInfo
Information about a region.
|
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... |
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Instance of an HBase ServerName.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
Coprocessor
Coprocessor interface.
|
CoprocessorEnvironment
Coprocessor environment state.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
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... |
KeyValue
An HBase Key/Value.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ServerName
Instance of an HBase ServerName.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
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 |
Stoppable
Implementers are Stoppable.
|
Class and 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:
|
CellScanner
An interface for iterating through a sequence of cells.
|
ChoreService
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
CoordinatedStateManager
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
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... |
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Instance of an HBase ServerName.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
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... |
TableName
Immutable POJO class for representing a table name.
|
TableNotFoundException
Thrown when a table can not be located
|
Class and Description |
---|
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... |
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
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... |
Class and Description |
---|
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 |
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
Coprocessor
Coprocessor interface.
|
CoprocessorEnvironment
Coprocessor environment state.
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HRegionInfo
Information about a region.
|
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... |
KeyValue
An HBase Key/Value.
|
MasterNotRunningException
Thrown if the master is not running
|
NamespaceDescriptor
Namespace POJO class.
|
ProcedureInfo
Procedure information
|
ServerName
Instance of an HBase ServerName.
|
TableName
Immutable POJO class for representing a table name.
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Class and Description |
---|
Coprocessor
Coprocessor interface.
|
CoprocessorEnvironment
Coprocessor environment state.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Coprocessor
Coprocessor interface.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
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... |
KeyValue.Type
Key type.
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about the KVs.
|
Class and Description |
---|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HRegionInfo
Information about a region.
|
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... |
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
HRegionLocation
Data structure to hold HRegionInfo and the address for the hosting
HRegionServer.
|
Class and Description |
---|
ServerLoad
This class is used for exporting current state of load on a RegionServer.
|
ServerName
Instance of an HBase ServerName.
|
Class and Description |
---|
HRegionInfo
Information about a region.
|
Class and Description |
---|
Coprocessor
Coprocessor interface.
|
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HRegionInfo
Information about a region.
|
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... |
TableName
Immutable POJO class for representing a table name.
|
Class and 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:
|
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.
|
CoordinatedStateManager
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HRegionInfo
Information about a region.
|
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... |
KeyValue.KVComparator
Compare KeyValues.
|
MasterNotRunningException
Thrown if the master is not running
|
ServerName
Instance of an HBase ServerName.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
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.
|
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... |
ServerName
Instance of an HBase ServerName.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ClusterId
The identifier for this cluster.
|
CoordinatedStateException
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
|
HRegionInfo
Information about a region.
|
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
RegionTransition
Current state of a region in transition.
|
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Instance of an HBase ServerName.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
TableStateManager
Helper class for table state management for operations running inside
RegionServer or HMaster.
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Class and Description |
---|
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.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.