| Interface | Description | 
|---|---|
| ClassFinder.ClassFilter | |
| ClassFinder.FileNameFilter | |
| ClassFinder.ResourcePathFilter | |
| ClusterManager | 
 ClusterManager is an api to manage servers in a distributed environment. 
 | 
| HadoopShims | 
 A compatibility shim layer for interacting with different versions of Hadoop. 
 | 
| HBaseTestingUtility.PortAllocator.AvailablePortChecker | |
| PerformanceEvaluation.Status | 
 Implementations can have their status set. 
 | 
| RandomStringGenerator | |
| TimestampTestBase.FlushCache | |
| 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 | 
|---|---|
| AcidGuaranteesTestBase | 
 Test case that uses multiple threads to read and write multifamily rows into a table, verifying
 that reads never see partially-complete writes. 
 | 
| AcidGuaranteesTestTool | 
 A test tool that uses multiple threads to read and write multifamily rows into a table, verifying
 that reads never see partially-complete writes 
 | 
| AcidGuaranteesTestTool.AtomicGetReader | 
 Thread that does single-row reads in a table, looking for partially completed rows. 
 | 
| AcidGuaranteesTestTool.AtomicityWriter | 
 Thread that does random full-row writes into a table. 
 | 
| AcidGuaranteesTestTool.AtomicScanReader | 
 Thread that does full scans of the table looking for any partially completed rows. 
 | 
| 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.FileFilterWithName | |
| ClassFinder.Not | |
| ClassTestFinder | 
 ClassFinder that is pre-configured with filters that will only allow test classes. 
 | 
| ClassTestFinder.TestClassFilter | |
| ClassTestFinder.TestFileNameFilter | 
 Filters both test classes and anything in the hadoop-compat modules 
 | 
| DistributedHBaseCluster | 
 Manages the interactions with an already deployed distributed cluster (as opposed to
 a pseudo-distributed, or mini/local cluster). 
 | 
| DistributedHBaseCluster.ServerNameIgnoreStartCodeComparator | |
| 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.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. 
 | 
| HBaseClassTestRule | 
 The class level TestRule for all the tests. 
 | 
| HBaseClassTestRuleChecker | 
 A RunListener to confirm that we have a  
CategoryBasedTimeout class rule for every test. | 
| 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. 
 | 
| HBaseClusterManager.CommandProvider | 
 Provides command strings for services to be executed by Shell. 
 | 
| HBaseClusterManager.HadoopShellCommandProvider | 
 CommandProvider to manage the service using sbin/hadoop-* scripts. 
 | 
| HBaseClusterManager.HBaseShellCommandProvider | 
 CommandProvider to manage the service using bin/hbase-* scripts 
 | 
| HBaseClusterManager.ZookeeperShellCommandProvider | 
 CommandProvider to manage the service using bin/zk* scripts. 
 | 
| HBaseCommonTestingUtility | 
 Common helpers for testing HBase that do not depend on specific server/etc. 
 | 
| HBaseTestCase | Deprecated
 since 2.0.0 and will be removed in 3.0.0. 
 | 
| HBaseTestingUtility | 
 Facility for testing HBase. 
 | 
| HBaseTestingUtility.PortAllocator | |
| HBaseTestingUtility.SeenRowTracker | 
 A tracker for tracking and validating table rows
 generated with  
HBaseTestingUtility.loadTable(Table, byte[]) | 
| HBaseZKTestingUtility | 
 Helpers for testing HBase that do not depend on specific server/etc. 
 | 
| HFilePerformanceEvaluation | 
 This class runs performance benchmarks for  
HFile. | 
| HFilePerformanceEvaluation.GaussianRandomReadBenchmark | |
| HFilePerformanceEvaluation.ReadBenchmark | |
| HFilePerformanceEvaluation.RowOrientedBenchmark | |
| HFilePerformanceEvaluation.SequentialReadBenchmark | |
| HFilePerformanceEvaluation.SequentialWriteBenchmark | |
| HFilePerformanceEvaluation.UniformRandomReadBenchmark | |
| HFilePerformanceEvaluation.UniformRandomSmallScan | |
| 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 | |
| IntegrationTestIngestWithMOB | 
 Integration Test for MOB ingest. 
 | 
| 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. 
 | 
| IntegrationTestLazyCfLoading.DataGenerator | 
 Custom LoadTestDataGenerator. 
 | 
| 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. 
 | 
| IntegrationTestRegionReplicaPerf.PerfEvalCallable | 
 Wraps the invocation of  
PerformanceEvaluation in a Callable. | 
| IntegrationTestRegionReplicaPerf.TimingResult | 
 Record the results from a single  
PerformanceEvaluation job run. | 
| 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. 
 | 
| MetaMockingUtil | 
 Mocking utility for common hbase:meta functionality 
 | 
| MiniHBaseCluster | 
 This class creates a single process HBase cluster. 
 | 
| MiniHBaseCluster.MiniHBaseClusterRegionServer | 
 Subclass so can get at protected methods (none at moment). 
 | 
| MiniHBaseCluster.SingleFileSystemShutdownThread | 
 Alternate shutdown hook. 
 | 
| 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. 
 | 
| PerformanceEvaluation | 
 Script used evaluating HBase performance and scalability. 
 | 
| PerformanceEvaluation.AppendTest | |
| PerformanceEvaluation.AsyncRandomReadTest | |
| PerformanceEvaluation.AsyncRandomWriteTest | |
| PerformanceEvaluation.AsyncScanTest | |
| PerformanceEvaluation.AsyncSequentialReadTest | |
| PerformanceEvaluation.AsyncSequentialWriteTest | |
| PerformanceEvaluation.AsyncTableTest | |
| PerformanceEvaluation.AsyncTest | |
| PerformanceEvaluation.BufferedMutatorTest | |
| PerformanceEvaluation.CASTableTest | 
 Base class for operations that are CAS-like; that read a value and then set it based off what
 they read. 
 | 
| PerformanceEvaluation.CheckAndDeleteTest | |
| PerformanceEvaluation.CheckAndMutateTest | |
| PerformanceEvaluation.CheckAndPutTest | |
| PerformanceEvaluation.CmdDescriptor | 
 Describes a command. 
 | 
| PerformanceEvaluation.EvaluationMapTask | 
 MapReduce job that runs a performance evaluation client in each map task. 
 | 
| PerformanceEvaluation.FilteredScanTest | |
| PerformanceEvaluation.IncrementTest | |
| PerformanceEvaluation.RandomReadTest | |
| PerformanceEvaluation.RandomScanWithRange10000Test | |
| PerformanceEvaluation.RandomScanWithRange1000Test | |
| PerformanceEvaluation.RandomScanWithRange100Test | |
| PerformanceEvaluation.RandomScanWithRange10Test | |
| PerformanceEvaluation.RandomScanWithRangeTest | |
| PerformanceEvaluation.RandomSeekScanTest | |
| PerformanceEvaluation.RandomWriteTest | |
| PerformanceEvaluation.RunResult | |
| PerformanceEvaluation.ScanTest | |
| PerformanceEvaluation.SequentialReadTest | |
| PerformanceEvaluation.SequentialWriteTest | |
| PerformanceEvaluation.TableTest | |
| PerformanceEvaluation.Test | |
| PerformanceEvaluation.TestBase | |
| PerformanceEvaluation.TestOptions | 
 Wraps up options passed to  
PerformanceEvaluation. | 
| PerformanceEvaluationCommons | 
 Code shared by PE tests. 
 | 
| QosTestHelper | |
| RandomStringGeneratorImpl | |
| 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 
 | 
| ResourceChecker.ResourceAnalyzer | 
 Class to implement for each type of resource. 
 | 
| ResourceCheckerJUnitListener | 
 Listen to the test progress and check the usage of:
 
 threads
 open file descriptor
 max open file descriptor
  
 | 
| ResourceCheckerJUnitListener.AvailableMemoryMBResourceAnalyzer | |
| ResourceCheckerJUnitListener.MaxFileDescriptorResourceAnalyzer | |
| ResourceCheckerJUnitListener.OpenFileDescriptorResourceAnalyzer | |
| ResourceCheckerJUnitListener.ProcessCountResourceAnalyzer | |
| ResourceCheckerJUnitListener.SystemLoadAverageResourceAnalyzer | |
| ResourceCheckerJUnitListener.ThreadResourceAnalyzer | |
| 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> | |
| StripeCompactionsPerformanceEvaluation | 
 A perf test which does large data ingestion using stripe compactions and regular compactions. 
 | 
| StripeCompactionsPerformanceEvaluation.SeqShardedDataGenerator | |
| TestAcidGuaranteesWithAdaptivePolicy | |
| TestAcidGuaranteesWithBasicPolicy | |
| TestAcidGuaranteesWithEagerPolicy | |
| TestAcidGuaranteesWithNoInMemCompaction | |
| TestByteBufferKeyValue | |
| TestCellBuilder | |
| TestCellComparator | |
| TestCellUtil | |
| TestCellUtil.NonExtendedCell | |
| TestCellUtil.TestCell | 
 Cell used in test. 
 | 
| TestCellUtil.TestCellScannable | 
 CellScannable used in test. 
 | 
| TestCellUtil.TestCellScanner | 
 CellScanner used in test. 
 | 
| 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 | |
| TestClassFinder.FileAndPath | |
| TestClientClusterMetrics | |
| TestClientClusterMetrics.MyObserver | |
| TestClientClusterStatus | 
 Test the ClusterStatus. 
 | 
| TestClientClusterStatus.MyObserver | |
| TestClientOperationTimeout | 
 These tests verify that the RPC timeouts ('hbase.client.operation.timeout' and
 'hbase.client.scanner.timeout.period') work correctly using a modified Region Server which
 injects delays to get, scan and mutate operations. 
 | 
| TestClientOperationTimeout.DelayedRegionServer | |
| TestClientOperationTimeout.DelayedRSRpcServices | 
 This  
RSRpcServices class injects delay for Rpc calls and after executes super methods. | 
| TestClusterBootOrder | 
 Tests the boot order indifference between regionserver and master 
 | 
| TestClusterPortAssignment | |
| TestCompatibilitySingletonFactory | |
| TestCompoundConfiguration | |
| TestFSTableDescriptorForceCreation | |
| TestFullLogReconstruction | |
| TestGlobalMemStoreSize | 
 Test HBASE-3694 whether the GlobalMemStoreSize is the same as the summary
 of all the online region's MemStoreSize 
 | 
| TestHBaseConfiguration | |
| TestHBaseConfiguration.ReflectiveCredentialProviderClient | |
| TestHBaseOnOtherDfsCluster | 
 Test that an HBase cluster can run on top of an existing MiniDfsCluster 
 | 
| TestHBaseTestingUtility | 
 Test our testing utility class 
 | 
| TestHBaseTestingUtilSpinup | 
 Make sure we can spin up a HBTU without a hbase-site.xml 
 | 
| TestHColumnDescriptor | Deprecated
 As of release 2.0.0, this will be removed in HBase 3.0.0 together with
             
HColumnDescriptor. | 
| TestHColumnDescriptorDefaultVersions | 
 Verify that the HColumnDescriptor version is set correctly by default, hbase-site.xml, and user
 input 
 | 
| TestHDFSBlocksDistribution | |
| TestHRegionLocation | |
| TestHTableDescriptor | Deprecated
 As of release 2.0.0, this will be removed in HBase 3.0.0 together with
              
HTableDescriptor. | 
| TestIndividualBytesFieldCell | |
| TestInfoServers | 
 Testing, info servers are disabled. 
 | 
| TestIntegrationTestBase | |
| 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. 
 | 
| TestJMXConnectorServer | 
 Test case for JMX Connector Server. 
 | 
| TestJMXConnectorServer.MyAccessController | |
| TestJMXListener | |
| TestKeyValue | |
| TestKeyValue.FailureCase | |
| 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 
 | 
| TestMetaTableAccessor | 
 Test  
MetaTableAccessor. | 
| TestMetaTableAccessor.MetaTask | 
 Thread that runs a MetaTableAccessor task until asked stop. 
 | 
| TestMetaTableAccessor.SpyingRpcScheduler | |
| TestMetaTableAccessor.SpyingRpcSchedulerFactory | |
| TestMetaTableAccessorNoCluster | 
 Test MetaTableAccessor but without spinning up a cluster. 
 | 
| TestMetaTableLocator | 
 Test  
MetaTableLocator | 
| TestMovedRegionsCleaner | 
 Test whether background cleanup of MovedRegion entries is happening 
 | 
| TestMovedRegionsCleaner.TestMockRegionServer | |
| TestMultiVersions | 
 Port of old TestScanMultipleVersions, TestTimestamp and TestGetRowVersions
 from old testing framework to  
HBaseTestingUtility. | 
| TestNamespace | |
| TestNodeHealthCheckChore | |
| TestNodeHealthCheckChore.StoppableImplementation | 
 Simple helper class that just keeps track of whether or not its stopped. 
 | 
| TestPartialResultsFromClientSide | 
 These tests are focused on testing how partial results appear to a client. 
 | 
| TestPerformanceEvaluation | |
| TestRegionLoad | |
| TestRegionLocations | |
| TestRegionMetrics | |
| TestRegionRebalancing | 
 Test whether region re-balancing works. 
 | 
| TestSequenceIdMonotonicallyIncreasing | 
 Testcase for HBASE-20066 
 | 
| TestSerialization | 
 Test HBase Writables serializations 
 | 
| TestServerLoad | |
| TestServerMetrics | |
| TestServerName | |
| TestServerSideScanMetricsFromClientSide | |
| TestSize | |
| TestSplitMerge | |
| TestStochasticBalancerJmxMetrics | |
| TestTableName | 
 Returns a  
byte[] containing the name of the currently running test method. | 
| TestTableName.Names | |
| TestTagRewriteCell | |
| TestTagUtil | |
| TestTimeout | |
| TestZooKeeper | |
| TestZooKeeper.MockLoadBalancer | |
| 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 
 | 
| Enum | Description | 
|---|---|
| ClusterManager.ServiceType | 
 Type of the service daemon 
 | 
| HBaseClusterManager.CommandProvider.Operation | |
| IntegrationTestDDLMasterFailover.ACTION | |
| IntegrationTestRegionReplicaPerf.Stat | 
 Extract a descriptive statistic from a  
Histogram. | 
| PerformanceEvaluation.Counter | 
 Enum for map metrics. 
 | 
| ResourceChecker.Phase | |
| RESTApiClusterManager.RoleCommand | |
| RESTApiClusterManager.Service | |
| ScanPerformanceEvaluation.ScanCounter | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.