Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
ByteBufferKeyValue
This Cell is an implementation of
ByteBufferExtendedCell where the data resides in
off heap/ on heap ByteBuffer |
CacheEvictionStats |
CacheEvictionStatsBuilder |
Cell
The unit of storage in HBase consisting of the following fields:
|
Cell.Type
The valid types for user to build the cell.
|
CellBuilder
Use
CellBuilderFactory to get CellBuilder instance. |
CellBuilderType
Used by
CellBuilderFactory and ExtendedCellBuilderFactory . |
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
CellComparatorImpl
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.
|
ClusterMetrics
Metrics information on the HBase cluster.
|
ClusterMetrics.Option
Kinds of ClusterMetrics
|
ClusterMetricsBuilder |
CompareOperator
Generic set of comparison operators.
|
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.
|
CoordinatedStateManager
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
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.
|
ExtendedCell
Extension to
Cell with server side required functions. |
ExtendedCellBuilder
For internal purpose.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
Deprecated.
|
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.
|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
use
RegionInfoBuilder to build RegionInfo . |
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting
HRegionServer.
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
TableDescriptorBuilder to build HTableDescriptor . |
KeepDeletedCells
Ways to keep cells marked for delete around.
|
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
Deprecated.
: Use
CellComparatorImpl . Deprecated for hbase 2.0, remove for hbase 3.0. |
KeyValue.SamePrefixComparator
Avoids redundant comparisons for better performance.
|
KeyValue.Type
Key type.
|
MemoryCompactionPolicy
Enum describing all possible memory compaction policies
|
MetaTableAccessor.DefaultVisitorBase
A Visitor that skips offline regions and split parents
|
MetaTableAccessor.QueryType |
MetaTableAccessor.ReplicationBarrierResult |
MetaTableAccessor.Visitor
Implementations 'visit' a catalog table row.
|
NamespaceDescriptor
Namespace POJO class.
|
NamespaceDescriptor.Builder |
RawCell
An extended version of cell that gives more power to CPs
|
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). |
RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionMetrics instead. |
RegionLocations
Container for holding a list of
HRegionLocation 's that correspond to the
same range. |
RegionMetrics
Encapsulates per-region load metrics.
|
RegionMetricsBuilder |
RetryImmediatelyException |
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
ServerMetrics instead. |
ServerMetrics
This class is used for exporting current state of load on a RegionServer.
|
ServerMetricsBuilder |
ServerName
Name of a particular incarnation of an HBase Server.
|
Size
It is used to represent the size with different units.
|
Size.Unit |
SizeCachedKeyValue
This class is an extension to KeyValue where rowLen and keyLen are cached.
|
SplitLogTask
State of a WAL log split during distributed splitting.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
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.
|
CacheEvictionStats |
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.
|
ClusterMetrics
Metrics information on the HBase cluster.
|
ClusterMetrics.Option
Kinds of ClusterMetrics
|
ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
ClusterMetrics instead. |
CompareOperator
Generic set of comparison operators.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
Deprecated.
|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
use
RegionInfoBuilder to build RegionInfo . |
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting
HRegionServer.
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
TableDescriptorBuilder to build HTableDescriptor . |
KeepDeletedCells
Ways to keep cells marked for delete around.
|
MasterNotRunningException
Thrown if the master is not running
|
MemoryCompactionPolicy
Enum describing all possible memory compaction policies
|
NamespaceDescriptor
Namespace POJO class.
|
NamespaceNotFoundException
Thrown when a namespace can not be located
|
RegionException
Thrown when something happens related to region handling.
|
RegionLocations
Container for holding a list of
HRegionLocation 's that correspond to the
same range. |
RegionMetrics
Encapsulates per-region load metrics.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
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
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Class and Description |
---|
ServerName
Name of a particular incarnation of an HBase Server.
|
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 |
---|
Abortable
Interface to support the aborting of a given server or client.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
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:
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
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
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
TableDescriptorBuilder to build HTableDescriptor . |
Class and Description |
---|
CoordinatedStateManager
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
SplitLogTask
State of a WAL log split during distributed splitting.
|
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:
|
ClusterMetrics
Metrics information on the HBase cluster.
|
CompareOperator
Generic set of comparison operators.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
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
|
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.
|
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). |
ServerName
Name of a particular incarnation of an HBase Server.
|
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
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
TableName
Immutable POJO class for representing a table name.
|
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
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CompareOperator
Generic set of comparison operators.
|
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.
|
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
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
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 |
---|
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 a curated set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
use
RegionInfoBuilder to build RegionInfo . |
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
TableDescriptorBuilder to build HTableDescriptor . |
KeyValue
An HBase Key/Value.
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ClusterId
The identifier for this cluster.
|
ClusterMetrics
Metrics information on the HBase cluster.
|
ClusterMetrics.Option
Kinds of ClusterMetrics
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
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.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerMetrics
This class is used for exporting current state of load on a RegionServer.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
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
|
YouAreDeadException
This exception is thrown by the master when a region server reports and is
already being processed as dead.
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting
HRegionServer.
|
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.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
YouAreDeadException
This exception is thrown by the master when a region server reports and is
already being processed as dead.
|
Class and Description |
---|
ClusterMetrics
Metrics information on the HBase cluster.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
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 |
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
NamespaceDescriptor
Namespace POJO class.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
ServerName
Name of a particular incarnation of an HBase Server.
|
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 |
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Server
Defines a curated 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:
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
NamespaceDescriptor
Namespace POJO class.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Class and Description |
---|
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.
|
ExtendedCellBuilder
For internal purpose.
|
KeyValue.Type
Key type.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
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
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
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
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
TableDescriptorBuilder to build HTableDescriptor . |
NamespaceDescriptor
Namespace POJO class.
|
RegionStateListener
The listener interface for receiving region state events.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
ByteBufferKeyValue
This Cell is an implementation of
ByteBufferExtendedCell where the data resides in
off heap/ on heap ByteBuffer |
CacheEvictionStats |
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
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. |
CompareOperator
Generic set of comparison operators.
|
CoordinatedStateManager
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
ExtendedCell
Extension to
Cell with server side required functions. |
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HConstants.OperationStatusCode
Status codes used for return values of bulk operations.
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
KeepDeletedCells
Ways to keep cells marked for delete around.
|
KeyValue
An HBase Key/Value.
|
MemoryCompactionPolicy
Enum describing all possible memory compaction policies
|
NoTagsByteBufferKeyValue
An extension of the ByteBufferKeyValue where the tags length is always 0
|
NotServingRegionException
Thrown by a region server if it is sent a request for a region it is not
serving.
|
RawCell
An extended version of cell that gives more power to CPs
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
KeepDeletedCells
Ways to keep cells marked for delete around.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
RegionTooBusyException
Thrown by a region server if it will block and wait to serve a request.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
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:
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
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 |
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
CellScanner
An interface for iterating through a sequence of cells.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Class and Description |
---|
CompareOperator
Generic set of comparison operators.
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
TableDescriptorBuilder to build HTableDescriptor . |
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
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
TableDescriptorBuilder to build HTableDescriptor . |
Class and Description |
---|
ClusterMetrics
Metrics information on the HBase cluster.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
NamespaceDescriptor
Namespace POJO class.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
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 |
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:
|
CompareOperator
Generic set of comparison operators.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
KeyValue
An HBase Key/Value.
|
MasterNotRunningException
Thrown if the master is not running
|
NamespaceDescriptor
Namespace POJO class.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Class and Description |
---|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
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
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
Class and Description |
---|
CacheEvictionStats |
CellScannable
Implementer can return a CellScanner over its Cell content.
|
CellScanner
An interface for iterating through a sequence of cells.
|
ClusterMetrics.Option
Kinds of ClusterMetrics
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting
HRegionServer.
|
NamespaceDescriptor
Namespace POJO class.
|
RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionMetrics instead. |
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
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
|
TableName
Immutable POJO class for representing a table name.
|
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:
|
HColumnDescriptor
Deprecated.
|
Class and Description |
---|
CompareOperator
Generic set of comparison operators.
|
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting
HRegionServer.
|
Class and Description |
---|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
TableNotFoundException
Thrown when a table can not be located
|
Class and Description |
---|
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
ClusterId
The identifier for this cluster.
|
ExtendedCell
Extension to
Cell with server side required functions. |
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
use
RegionInfoBuilder to build RegionInfo . |
MasterNotRunningException
Thrown if the master is not running
|
RawCell
An extended version of cell that gives more power to CPs
|
ServerName
Name of a particular incarnation of an HBase Server.
|
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 |
---|
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.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
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.
|
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Copyright © 2007–2019 Cloudera. All rights reserved.