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. |
ClassFinder
A class that finds a set of classes that are locally accessible
(from .class or .jar files), and satisfy the conditions that are
imposed by name and class filters provided by the user.
|
ClassFinder.ClassFilter |
ClassFinder.FileNameFilter |
ClassFinder.ResourcePathFilter |
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.
|
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.
|
GenericTestUtils.LogCapturer |
HadoopShims
A compatibility shim layer for interacting with different versions of Hadoop.
|
HBaseCluster
This class defines methods that can help with managing HBase clusters
from unit tests and system tests.
|
HBaseCommonTestingUtility
Common helpers for testing HBase that do not depend on specific server/etc.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HBaseTestCase.FlushCache
Deprecated.
Implementors can flushcache.
|
HBaseTestCase.Incommon
Deprecated.
Interface used by tests so can do common operations against an HTable
or an HRegion.
|
HBaseTestCase.ScannerIncommon
Deprecated.
|
HBaseTestingUtility
Facility for testing HBase.
|
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.
|
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... |
IntegrationTestBase
Base class for HBase integration tests that want to use the Chaos Monkey.
|
IntegrationTestIngest
A base class for tests that do something with the cluster while running
LoadTestTool to write and verify some data. |
IntegrationTestingUtility
Facility for integration/system tests.
|
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.
|
LocalHBaseCluster
This class creates a single process HBase cluster.
|
MasterNotRunningException
Thrown if the master is not running
|
MetaTableAccessor.Visitor
Implementations 'visit' a catalog table row.
|
MiniHBaseCluster
This class creates a single process HBase cluster.
|
MiniHBaseCluster.MiniHBaseClusterRegionServer
Subclass so can get at protected methods (none at moment).
|
MultithreadedTestUtil.RepeatingTestThread
A test thread that performs a repeating operation.
|
MultithreadedTestUtil.TestContext |
MultithreadedTestUtil.TestThread
A thread that can be added to a test context, and properly
passes exceptions through.
|
NamespaceDescriptor
Namespace POJO class.
|
NamespaceDescriptor.Builder |
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
PerformanceEvaluation.Counter
Enum for map metrics.
|
PerformanceEvaluation.RunResult |
ProcedureInfo
Procedure information
|
RandomStringGenerator |
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.
|
ResourceChecker
Utility class to check the resources:
- log them before and after each test method
- check them against a minimum or maximum
- check that they don't leak during the test
|
ResourceCheckerJUnitListener
Listen to the test progress and check the usage of:
- threads
- open file descriptor
- max open file descriptor
When surefire forkMode=once/always/perthread, this code is executed on the forked process.
|
ScanPerformanceEvaluation.ScanCounter |
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.
|
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.
|
TestIOFencing.CompactionBlockerRegion |
Waiter.ExplainingPredicate
A mixin interface, can be used with
Waiter to explain failed state. |
Waiter.Predicate
A predicate 'closure' used by the
Waiter.waitFor(Configuration, long, Predicate) and
Waiter.waitFor(Configuration, long, Predicate) and
{@link Waiter#waitFor(Configuration, long, long, boolean, Predicate) methods. |
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
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 |
---|
ClusterStatus
Status information on the HBase cluster.
|
HBaseCluster
This class defines methods that can help with managing HBase clusters
from unit tests and system tests.
|
IntegrationTestingUtility
Facility for integration/system tests.
|
ServerName
Instance of an HBase ServerName.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
IntegrationTestingUtility
Facility for integration/system tests.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
IntegrationTestingUtility
Facility for integration/system tests.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
IntegrationTestingUtility
Facility for integration/system tests.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
IntegrationTestingUtility
Facility for integration/system tests.
|
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.
|
ClusterStatus
Status information on the HBase cluster.
|
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
|
HBaseTestingUtility
Facility for testing HBase.
|
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.
|
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 |
---|
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.
|
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:
|
KeyValue
An HBase Key/Value.
|
Class and Description |
---|
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.
|
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.
|
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
|
HBaseTestingUtility
Facility for testing HBase.
|
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 |
---|
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.KVComparator
Compare KeyValues.
|
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
An HBase Key/Value.
|
KeyValue.KVComparator
Compare KeyValues.
|
KeyValue.Type
Key type.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
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 |
---|
HBaseTestingUtility
Facility for testing HBase.
|
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 |
---|
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 |
Cell
The unit of storage in HBase consisting of the following fields:
|
Coprocessor
Coprocessor interface.
|
HBaseTestingUtility
Facility for testing HBase.
|
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... |
IntegrationTestBase
Base class for HBase integration tests that want to use the Chaos Monkey.
|
IntegrationTestingUtility
Facility for integration/system tests.
|
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. |
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.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HBaseTestingUtility
Facility for testing HBase.
|
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.MetadataHandler
An interface for objects that process lock metadata.
|
MiniHBaseCluster.MiniHBaseClusterRegionServer
Subclass so can get at protected methods (none at moment).
|
NamespaceDescriptor
Namespace POJO class.
|
ProcedureInfo
Procedure information
|
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.
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Class and Description |
---|
ClusterStatus
Status information on the HBase cluster.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HRegionInfo
Information about a region.
|
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.
|
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 |
---|
CoordinatedStateException
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
|
Coprocessor
Coprocessor interface.
|
HBaseTestingUtility
Facility for testing HBase.
|
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... |
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
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.
|
HBaseTestingUtility
Facility for testing HBase.
|
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 |
---|
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 |
---|
Coprocessor
Coprocessor interface.
|
CoprocessorEnvironment
Coprocessor environment state.
|
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.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
ProcedureInfo
Procedure information
|
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:
|
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.
|
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.Type
Key type.
|
NamespaceDescriptor
Namespace POJO class.
|
ServerName
Instance of an HBase ServerName.
|
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
|
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.
|
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:
|
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.
|
HBaseConfiguration
Adds HBase configuration files to a Configuration
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HBaseTestingUtility
Facility for testing HBase.
|
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.
|
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.
|
KeyValue.Type
Key type.
|
MetaMutationAnnotation
The field or the parameter to which this annotation can be applied only when it
holds mutations for hbase:meta table.
|
MiniHBaseCluster.MiniHBaseClusterRegionServer
Subclass so can get at protected methods (none at moment).
|
MultithreadedTestUtil.RepeatingTestThread
A test thread that performs a repeating operation.
|
MultithreadedTestUtil.TestContext |
MultithreadedTestUtil.TestThread
A thread that can be added to a test context, and properly
passes exceptions through.
|
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.
|
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:
|
KeyValue
An HBase Key/Value.
|
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 |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Coprocessor
Coprocessor interface.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HBaseTestingUtility
Facility for testing HBase.
|
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... |
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:
|
Coprocessor
Coprocessor interface.
|
HBaseTestingUtility
Facility for testing HBase.
|
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 |
---|
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.
|
CellScanner
An interface for iterating through a sequence of cells.
|
Coprocessor
Coprocessor interface.
|
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.
|
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:
|
HBaseTestingUtility
Facility for testing HBase.
|
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 |
---|
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.
|
HBaseTestingUtility
Facility for testing HBase.
|
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.
|
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
|
HBaseTestingUtility
Facility for testing HBase.
|
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... |
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 |
---|
Coprocessor
Coprocessor interface.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HBaseTestingUtility
Facility for testing HBase.
|
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:
|
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... |
IntegrationTestBase
Base class for HBase integration tests that want to use the Chaos Monkey.
|
IntegrationTestIngest
A base class for tests that do something with the cluster while running
LoadTestTool to write and verify some data. |
IntegrationTestingUtility
Facility for integration/system tests.
|
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.
|
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.
|
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.
|
CoordinatedStateManager
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
Coprocessor
Coprocessor interface.
|
HBaseTestingUtility
Facility for testing HBase.
|
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.KVComparator
Compare KeyValues.
|
MasterNotRunningException
Thrown if the master is not running
|
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.
|
TableNotFoundException
Thrown when a table can not be located
|
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Class and Description |
---|
HBaseTestingUtility
Facility for testing HBase.
|
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 |
---|
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.
|
CoordinatedStateManager
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
|
HBaseTestingUtility
Facility for testing HBase.
|
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 |
---|
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
|
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.
|