Interface | Description |
---|---|
Abortable |
Interface to support the aborting of a given server or client.
|
Cell |
The unit of storage in HBase consisting of the following fields:
|
CellScannable |
Implementer can return a CellScanner over its Cell content.
|
CellScanner |
An interface for iterating through a sequence of cells.
|
ClassFinder.ClassFilter | |
ClassFinder.FileNameFilter | |
ClassFinder.ResourcePathFilter | |
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.
|
HadoopShims |
A compatibility shim layer for interacting with different versions of Hadoop.
|
HBaseTestCase.FlushCache |
Implementors can flushcache.
|
HBaseTestCase.Incommon |
Interface used by tests so can do common operations against an HTable
or an HRegion.
|
HBaseTestCase.ScannerIncommon | |
InterProcessLock |
An interface for an application-specific lock.
|
InterProcessLock.MetadataHandler |
An interface for objects that process lock metadata.
|
InterProcessReadWriteLock |
An interface for a distributed reader-writer lock.
|
KeyValue.SamePrefixComparator<T> |
Avoids redundant comparisons for better performance.
|
MetaTableAccessor.Visitor |
Implementations 'visit' a catalog table row.
|
RandomStringGenerator | |
Server |
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
SettableSequenceId |
Using this Interface one can mark a Cell as Sequence stampable.
|
SettableTimestamp |
Using this Interface one can mark a Cell as timestamp changeable.
|
Stoppable |
Implementers are Stoppable.
|
TableDescriptors |
Get, remove and modify table descriptors.
|
TableStateManager |
Helper class for table state management for operations running inside
RegionServer or HMaster.
|
Waiter.ExplainingPredicate<E extends Exception> |
A mixin interface, can be used with
Waiter to explain failed state. |
Waiter.Predicate<E extends Exception> |
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. |
Class | Description |
---|---|
AuthUtil |
Utility methods for helping with security tasks.
|
BaseConfigurable |
HBase version of Hadoop's Configured class that doesn't initialize the
configuration via
BaseConfigurable.setConf(Configuration) in the constructor, but
only sets the configuration through the BaseConfigurable.setConf(Configuration)
method |
CellComparator |
Compare two HBase cells.
|
CellComparator.RowComparator |
Counter part for the KeyValue.RowOnlyComparator
|
CellUtil |
Utility methods helpful slinging
Cell instances. |
ChoreService |
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
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.And | |
ClassFinder.Not | |
ClassTestFinder |
ClassFinder that is pre-configured with filters that will only allow test classes.
|
ClassTestFinder.TestClassFilter | |
ClassTestFinder.TestFileNameFilter | |
ClusterId |
The identifier for this cluster.
|
ClusterStatus |
Status information on the HBase cluster.
|
CompatibilityFactory |
Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.
|
CompatibilitySingletonFactory |
Factory for classes supplied by hadoop compatibility modules.
|
CompoundConfiguration |
Do a shallow merge of multiple KV configuration pools.
|
CoordinatedStateManagerFactory |
Creates instance of
CoordinatedStateManager
based on configuration. |
DaemonThreadFactory |
Thread factory that creates daemon threads
|
DistributedHBaseCluster |
Manages the interactions with an already deployed distributed cluster (as opposed to
a pseudo-distributed, or mini/local cluster).
|
GenericTestUtils |
Test provides some very generic helpers which might be used across the tests
|
GenericTestUtils.DelayAnswer |
Mockito answer helper that triggers one latch as soon as the
method is called, then waits on another before continuing.
|
GenericTestUtils.DelegateAnswer |
An Answer implementation that simply forwards all calls through
to a delegate.
|
GenericTestUtils.LogCapturer | |
GenericTestUtils.SleepAnswer |
An Answer implementation which sleeps for a random number of milliseconds
between 0 and a configurable value before delegating to the real
implementation of the method.
|
HadoopShimsImpl |
Compatibility shim layer implementation for Hadoop-2.
|
HBaseCluster |
This class defines methods that can help with managing HBase clusters
from unit tests and system tests.
|
HBaseClusterManager |
A default cluster manager for HBase.
|
HBaseCommonTestingUtility |
Common helpers for testing HBase that do not depend on specific server/etc.
|
HBaseConfiguration |
Adds HBase configuration files to a Configuration
|
HBaseInterfaceAudience |
This class defines constants for different classes of hbase limited private apis
|
HBaseTestCase | Deprecated
Write junit4 unit tests using
HBaseTestingUtility |
HBaseTestCase.ClientScannerIncommon | |
HBaseTestCase.HRegionIncommon |
A class that makes a
HBaseTestCase.Incommon out of a HRegion |
HBaseTestCase.HTableIncommon |
A class that makes a
HBaseTestCase.Incommon out of a HTable |
HBaseTestCase.InternalScannerIncommon | |
HBaseTestingUtility |
Facility for testing HBase.
|
HBaseTestingUtility.SeenRowTracker |
A tracker for tracking and validating table rows
generated with
HBaseTestingUtility#loadTable(HTable, byte[]) |
HColumnDescriptor |
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
HConstants |
HConstants holds a bunch of HBase-related constants
|
HDFSBlocksDistribution |
Data structure to describe the distribution of HDFS blocks among hosts.
|
HDFSBlocksDistribution.HostAndWeight |
Stores the hostname and weight for that hostname.
|
HDFSBlocksDistribution.HostAndWeight.WeightComparator |
comparator used to sort hosts based on weight
|
HealthCheckChore |
The Class HealthCheckChore for running health checker regularly.
|
HFilePerformanceEvaluation |
This class runs performance benchmarks for
HFile . |
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... |
HTestConst |
Similar to
HConstants but for tests. |
IntegrationTestAcidGuarantees |
This Integration Test verifies acid guarantees across column families by frequently writing
values to rows with multiple column families and concurrently reading entire rows that expect all
column families.
|
IntegrationTestBase |
Base class for HBase integration tests that want to use the Chaos Monkey.
|
IntegrationTestDDLMasterFailover |
Integration test that verifies Procedure V2.
|
IntegrationTestIngest |
A base class for tests that do something with the cluster while running
LoadTestTool to write and verify some data. |
IntegrationTestIngestStripeCompactions |
A test class that does the same things as IntegrationTestIngest but with stripe
compactions.
|
IntegrationTestIngestWithACL |
/**
An Integration class for tests that does something with the cluster while running
LoadTestTool to write and verify some data. |
IntegrationTestIngestWithEncryption | |
IntegrationTestIngestWithTags | |
IntegrationTestIngestWithVisibilityLabels | |
IntegrationTestingUtility |
Facility for integration/system tests.
|
IntegrationTestLazyCfLoading |
Integration test that verifies lazy CF loading during scans by doing repeated scans
with this feature while multiple threads are continuously writing values; and
verifying the result.
|
IntegrationTestManyRegions |
An integration test to detect regressions in HBASE-7220.
|
IntegrationTestMetaReplicas |
An integration test that starts the cluster with three replicas for the meta
It then creates a table, flushes the meta, kills the server holding the primary.
|
IntegrationTestRegionReplicaPerf |
Test for comparing the performance impact of region replicas.
|
IntegrationTestRegionReplicaReplication |
Integration test for testing async wal replication to secondary region replicas.
|
IntegrationTestRegionReplicaReplication.DelayingMultiThreadedUpdater |
This extends MultiThreadedWriter to add a configurable delay to the keys written by the writer
threads to become available to the MultiThradedReader threads.
|
IntegrationTestRegionReplicaReplication.DelayingMultiThreadedWriter |
This extends MultiThreadedWriter to add a configurable delay to the keys written by the writer
threads to become available to the MultiThradedReader threads.
|
IntegrationTestsDriver |
This class drives the Integration test suite execution.
|
JMXListener |
Pluggable JMX Agent for HBase(to fix the 2 random TCP ports issue
of the out-of-the-box JMX Agent):
1)connector port can share with the registry port if SSL is OFF
2)support password authentication
3)support subset of SSL (with default configuration)
|
KeyValue |
An HBase Key/Value.
|
KeyValue.KeyOnlyKeyValue |
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[]
Mainly used in places where we need to compare two cells.
|
KeyValue.KVComparator |
Compare KeyValues.
|
KeyValue.MetaComparator | |
KeyValue.RawBytesComparator |
This is a TEST only Comparator used in TestSeekTo and TestReseekTo.
|
KeyValue.RowOnlyComparator |
Comparator that compares row component only of a KeyValue.
|
KeyValueTestUtil | |
KeyValueUtil |
static convenience methods for dealing with KeyValues and collections of KeyValues
|
LocalHBaseCluster |
This class creates a single process HBase cluster.
|
MapFilePerformanceEvaluation | Deprecated
HBase does not use MapFiles any more.
|
MetaMigrationConvertingToPB | Deprecated
will be removed for the major release after 0.96.
|
MetaMockingUtil |
Mocking utility for common hbase:meta functionality
|
MetaTableAccessor |
Read/write operations on region and assignment information store in
hbase:meta . |
MiniHBaseCluster |
This class creates a single process HBase cluster.
|
MiniHBaseCluster.MiniHBaseClusterRegionServer |
Subclass so can get at protected methods (none at moment).
|
MockRegionServerServices |
Basic mock region server services.
|
MultithreadedTestUtil | |
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 | |
NoTagsKeyValue |
An extension of the KeyValue where the tags length is always 0
|
PerformanceEvaluation |
Script used evaluating HBase performance and scalability.
|
PerformanceEvaluation.EvaluationMapTask |
MapReduce job that runs a performance evaluation client in each map task.
|
PerformanceEvaluation.RunResult | |
PerformanceEvaluationCommons |
Code shared by PE tests.
|
ProcedureInfo |
Procedure information
|
RandomStringGeneratorImpl | |
RegionLoad |
Encapsulates per-region load metrics.
|
RegionLocations |
Container for holding a list of
HRegionLocation 's that correspond to the
same range. |
RegionTransition |
Current state of a region in transition.
|
RemoteExceptionHandler |
An immutable class which contains a static method for handling
org.apache.hadoop.ipc.RemoteException exceptions.
|
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.
|
RESTApiClusterManager |
A ClusterManager implementation designed to control Cloudera Manager (http://www.cloudera.com)
clusters via REST API.
|
ScanPerformanceEvaluation |
A simple performance evaluation tool for single client and MR scans
and snapshot scans.
|
ScanPerformanceEvaluation.MyMapper<KEYOUT,VALUEOUT> | |
ScheduledChore |
ScheduledChore is a task performed on a period in hbase.
|
ServerLoad |
This class is used for exporting current state of load on a RegionServer.
|
ServerName |
Instance of an HBase ServerName.
|
ServerResourceCheckerJUnitListener |
Monitor the resources.
|
SplitLogCounters |
Counters kept by the distributed WAL split log process.
|
SplitLogTask |
State of a WAL log split during distributed splitting.
|
SplitLogTask.Done | |
SplitLogTask.Err | |
SplitLogTask.Owned | |
SplitLogTask.Resigned | |
SplitLogTask.Unassigned | |
StripeCompactionsPerformanceEvaluation |
A perf test which does large data ingestion using stripe compactions and regular compactions.
|
StripeCompactionsPerformanceEvaluation.SeqShardedDataGenerator | |
TableName |
Immutable POJO class for representing a table name.
|
Tag |
Tags are part of cells and helps to add metadata about the KVs.
|
TagRewriteCell |
This can be used when a Cell has to change with addition/removal of one or more tags.
|
TagType | |
TestAcidGuarantees |
Test case that uses multiple threads to read and write multifamily rows
into a table, verifying that reads never see partially-complete writes.
|
TestAcidGuarantees.AtomicGetReader |
Thread that does single-row reads in a table, looking for partially
completed rows.
|
TestAcidGuarantees.AtomicityWriter |
Thread that does random full-row writes into a table.
|
TestAcidGuarantees.AtomicScanReader |
Thread that does full scans of the table looking for any partially completed
rows.
|
TestCellComparator | |
TestCellUtil | |
TestCheckTestClasses |
Checks tests are categorized.
|
TestChoreService | |
TestChoreService.ScheduledChoreSamples |
A few ScheduledChore samples that are useful for testing with ChoreService
|
TestChoreService.ScheduledChoreSamples.CountingChore | |
TestChoreService.ScheduledChoreSamples.DoNothingChore |
Lightweight ScheduledChore used primarily to fill the scheduling queue in tests
|
TestChoreService.ScheduledChoreSamples.FailInitialChore |
A Chore that will try to execute the initial chore a few times before succeeding.
|
TestChoreService.ScheduledChoreSamples.SampleStopper |
Straight forward stopper implementation that is used by default when one is not provided
|
TestChoreService.ScheduledChoreSamples.SleepingChore | |
TestChoreService.ScheduledChoreSamples.SlowChore |
Sleeps for longer than the scheduled period.
|
TestClassFinder | |
TestClusterBootOrder |
Tests the boot order indifference between regionserver and master
|
TestCompare |
Test comparing HBase objects.
|
TestCompatibilitySingletonFactory | |
TestCompoundConfiguration | |
TestDrainingServer |
Test the draining servers feature.
|
TestFSTableDescriptorForceCreation | |
TestFullLogReconstruction | |
TestGlobalMemStoreSize |
Test HBASE-3694 whether the GlobalMemStoreSize is the same as the summary
of all the online region's MemStoreSize
|
TestHBaseConfiguration | |
TestHBaseOnOtherDfsCluster |
Test that an HBase cluster can run on top of an existing MiniDfsCluster
|
TestHBaseTestingUtility |
Test our testing utility class
|
TestHColumnDescriptor |
Tests the HColumnDescriptor with appropriate arguments
|
TestHColumnDescriptorDefaultVersions |
Verify that the HColumnDescriptor version is set correctly by default, hbase-site.xml, and user
input
|
TestHDFSBlocksDistribution | |
TestHRegionLocation | |
TestHTableDescriptor |
Test setting values in the descriptor
|
TestInfoServers |
Testing, info servers are disabled.
|
TestInterfaceAudienceAnnotations |
Test cases for ensuring our client visible classes have annotations
for
InterfaceAudience . |
TestIOFencing |
Test for the case where a regionserver going down has enough cycles to do damage to regions
that have actually been assigned elsehwere.
|
TestIOFencing.BlockCompactionsInCompletionHStore | |
TestIOFencing.BlockCompactionsInCompletionRegion |
An override of HRegion that allows us park compactions in a holding pattern and
then when appropriate for the test, allow them proceed again.
|
TestIOFencing.BlockCompactionsInPrepRegion |
An override of HRegion that allows us park compactions in a holding pattern and
then when appropriate for the test, allow them proceed again.
|
TestIOFencing.CompactionBlockerRegion | |
TestIPv6NIOServerSocketChannel |
This tests whether ServerSocketChannel works over ipv6, which Zookeeper
depends on.
|
TestJMXListener | |
TestKeyValue | |
TestLocalHBaseCluster | |
TestLocalHBaseCluster.MyHMaster |
A private master class similar to that used by HMasterCommandLine when
running in local mode.
|
TestLocalHBaseCluster.MyHRegionServer |
A private regionserver class with a dummy method for testing casts
|
TestMetaMigrationConvertingToPB | Deprecated
Remove after 0.96
|
TestMetaTableAccessor |
Test
MetaTableAccessor . |
TestMetaTableAccessorNoCluster |
Test MetaTableAccessor but without spinning up a cluster.
|
TestMetaTableLocator |
Test
MetaTableLocator |
TestMovedRegionsCleaner |
Test whether background cleanup of MovedRegion entries is happening
|
TestMultiVersions |
Port of old TestScanMultipleVersions, TestTimestamp and TestGetRowVersions
from old testing framework to
HBaseTestingUtility . |
TestNamespace | |
TestNodeHealthCheckChore | |
TestPartialResultsFromClientSide |
These tests are focused on testing how partial results appear to a client.
|
TestPerformanceEvaluation | |
TestRegionLocations | |
TestRegionRebalancing |
Test whether region re-balancing works.
|
TestSerialization |
Test HBase Writables serializations
|
TestServerLoad | |
TestServerName | |
TestTagRewriteCell | |
TestZooKeeper | |
TimedOutTestsListener |
JUnit run listener which prints full thread dump into System.err
in case a test is failed due to timeout.
|
TimestampTestBase |
Tests user specifiable time stamps putting, getting and scanning.
|
Waiter |
A class that provides a standard waitFor pattern
See details at https://issues.apache.org/jira/browse/HBASE-7384
|
ZKNamespaceManager |
Class servers two purposes:
1.
|
ZNodeClearer |
Contains a set of methods for the collaboration between the start/stop scripts and the
servers.
|
Enum | Description |
---|---|
CompatibilitySingletonFactory.SingletonStorage | |
Coprocessor.State |
Lifecycle state of a given coprocessor instance.
|
HConstants.Modify |
modifyTable op for replacing the table descriptor
|
HConstants.OperationStatusCode |
Status codes used for return values of bulk operations.
|
KeepDeletedCells |
Ways to keep cells marked for delete around.
|
KeyValue.Type |
Key type.
|
PerformanceEvaluation.Counter |
Enum for map metrics.
|
ScanPerformanceEvaluation.ScanCounter |
Exception | Description |
---|---|
ClockOutOfSyncException |
This exception is thrown by the master when a region server clock skew is
too high.
|
CoordinatedStateException |
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
|
DoNotRetryIOException |
Subclass if exception is not meant to be retried: e.g.
|
DroppedSnapshotException |
Thrown during flush if the possibility snapshot content was not properly
persisted into store files.
|
HBaseIOException |
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
InvalidFamilyOperationException |
Thrown if a request is table schema modification is requested but
made for an invalid family name.
|
MasterNotRunningException |
Thrown if the master is not running
|
NamespaceExistException |
Thrown when a namespace exists but should not
|
NamespaceNotFoundException |
Thrown when a namespace can not be located
|
NotAllMetaRegionsOnlineException |
Thrown when an operation requires the root and all meta regions to be online
|
NotServingRegionException |
Thrown by a region server if it is sent a request for a region it is not
serving.
|
PleaseHoldException |
This exception is thrown by the master when a region server was shut down and
restarted so fast that the master still hasn't processed the server shutdown
of the first instance, or when master is initializing and client call admin
operations, or when an operation is performed on a region server that is still starting.
|
RegionException |
Thrown when something happens related to region handling.
|
RegionTooBusyException |
Thrown by a region server if it will block and wait to serve a request.
|
TableExistsException |
Thrown when a table exists but should not
|
TableInfoMissingException |
Failed to find .tableinfo file under table dir
|
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
|
UnknownRegionException |
Thrown when we are asked to operate on a region we know nothing about.
|
UnknownScannerException |
Thrown if a region server is passed an unknown scanner id.
|
YouAreDeadException |
This exception is thrown by the master when a region server reports and is
already being processed as dead.
|
ZooKeeperConnectionException |
Thrown if the client can't connect to zookeeper
|
Annotation Type | Description |
---|---|
MetaMutationAnnotation |
The field or the parameter to which this annotation can be applied only when it
holds mutations for hbase:meta table.
|
VersionAnnotation |
A package attribute that captures the version of hbase that was compiled.
|