Interface | Description |
---|---|
RandomDistribution.DiscreteRNG |
Interface for discrete (integer) random distributions.
|
TestByteBufferArray.Call | |
TestCounter.Operation | |
TestFSUtils.HDFSBlockDistributionFunction |
Class | Description |
---|---|
AbstractHBaseToolTest | |
AbstractHBaseToolTest.Options | |
AbstractHBaseToolTest.TestTool |
Simple tool to test options parsing.
|
BaseTestHBaseFsck |
This is the base class for HBaseFsck's ability to detect reasons for inconsistent tables.
|
BaseTestHBaseFsck.MasterSyncCoprocessor | |
BaseTestHBaseFsck.MockErrorReporter | |
BuilderStyleTest |
Utility class to check whether a given class conforms to builder-style: Foo foo = new Foo()
.setBar(bar) .setBaz(baz)
|
ClassLoaderTestHelper |
Some utilities to help class loader testing
|
ConstantDelayQueue<E> |
A blocking queue implementation for adding a constant delay.
|
ConstantDelayQueue.DelayedElement<T> | |
EnvironmentEdgeManagerTestHelper |
Used by tests to inject an edge into the manager.
|
HBaseHomePath |
Determines HBase home path from either class or jar directory
|
HFileArchiveTestingUtil |
Test helper for testing archiving of HFiles
|
HFileTestUtil |
Utility class for HFile-related testing.
|
LauncherSecurityManager |
class for masquerading System.exit(int).
|
LoadTestDataGeneratorWithMOB |
A load test data generator for MOB
|
LoadTestDataGeneratorWithTags | |
LoadTestKVGenerator |
A generator of random keys and values for load testing.
|
LoadTestTool |
A command-line utility that reads, writes, and verifies data.
|
MockServer |
Basic mock Server for handler tests.
|
MultiThreadedAction |
Common base class for reader and writer parts of multi-thread HBase load test (See LoadTestTool).
|
MultiThreadedAction.DefaultDataGenerator |
Default implementation of LoadTestDataGenerator that uses LoadTestKVGenerator, fixed set of
column families, and random number of columns in range.
|
MultiThreadedReader |
Creates multiple threads that read and verify previously written data
|
MultiThreadedReaderWithACL |
A MultiThreadReader that helps to work with ACL
|
MultiThreadedUpdater |
Creates multiple threads that write key/values into the
|
MultiThreadedUpdaterWithACL |
A MultiThreadUpdater that helps to work with ACL
|
MultiThreadedWriter |
Creates multiple threads that write key/values into the
|
MultiThreadedWriterBase |
Creates multiple threads that write key/values into the
|
MultiThreadedWriterWithACL |
MultiThreadedWriter that helps in testing ACL
|
NonRepeatedEnvironmentEdge |
An clock which will never return the same clock twice.
|
PoolMapTestBase | |
ProcessBasedLocalHBaseCluster |
A helper class for process-based mini-cluster tests.
|
RandomDistribution |
A class that generates random numbers that follow some distribution.
|
RandomDistribution.Binomial |
Binomial distribution.
|
RandomDistribution.Flat |
P(i)=1/(max-min)
|
RandomDistribution.Zipf |
Zipf distribution.
|
RedundantKVGenerator |
Generate list of key values which are very useful to test data block encoding and compression.
|
RedundantKVGenerator.ExtendedOffheapKeyValue | |
RestartMetaTest |
A command-line tool that spins up a local process-based cluster, loads some data, restarts the
regionserver holding hbase:meta, and verifies that the cluster recovers.
|
SimpleKdcServerUtil |
Utility for running
SimpleKdcServer . |
StoppableImplementation |
A base implementation for a Stoppable service
|
TestAvlUtil | |
TestAvlUtil.TestAvlKeyComparator | |
TestAvlUtil.TestAvlNode | |
TestAvlUtil.TestLinkedAvlNode | |
TestBloomFilterChunk | |
TestBoundedPriorityBlockingQueue | |
TestBoundedPriorityBlockingQueue.TestObject | |
TestBoundedPriorityBlockingQueue.TestObjectComparator | |
TestByteBufferArray | |
TestByteBufferUtils | |
TestByteBuffUtils | |
TestByteRangeUtils | |
TestByteRangeWithKVSerialization | |
TestBytes | |
TestClasses | |
TestCommonFSUtils |
Test
CommonFSUtils . |
TestCompressionTest | |
TestConcatenatedLists | |
TestConfigurationUtil | |
TestConnectionCache | |
TestCoprocessorClassLoader |
Test TestCoprocessorClassLoader.
|
TestCoprocessorScanPolicy | |
TestCoprocessorScanPolicy.ScanObserver | |
TestCounter | |
TestDefaultEnvironmentEdge |
Tests to make sure that the default environment edge conforms to appropriate behaviour.
|
TestDynamicClassLoader |
Test TestDynamicClassLoader
|
TestEncryptionTest | |
TestEncryptionTest.FailingCipherProvider | |
TestEncryptionTest.FailingKeyProvider | |
TestEnvironmentEdgeManager | |
TestFromClientSide3WoUnsafe | |
TestFSTableDescriptors |
Tests for
FSTableDescriptors . |
TestFSTableDescriptors.FSTableDescriptorsTest | |
TestFSUtils |
Test
FSUtils . |
TestFSVisitor |
Test
FSUtils . |
TestFutureUtils | |
TestGsonUtil | |
TestHBaseFsckCleanReplicationBarriers | |
TestHBaseFsckComparator |
Test the comparator used by Hbck.
|
TestHBaseFsckEncryption | |
TestHBaseFsckMOB | |
TestHBaseFsckReplication | |
TestHFileArchiveUtil |
Test that the utility works as expected
|
TestIdLock | |
TestIdReadWriteLock | |
TestIncrementingEnvironmentEdge |
Tests that the incrementing environment edge increments time instead of using the default.
|
TestJRubyFormat | |
TestJSONBean |
Test
JSONBean . |
TestJSONMetricUtil | |
TestKeyLocker | |
TestLoadTestKVGenerator | |
TestLossyCounting | |
TestMiniClusterLoadEncoded |
Runs a load test on a mini HBase cluster with data block encoding turned on.
|
TestMiniClusterLoadParallel |
A write/read/verify load test on a mini HBase cluster.
|
TestMiniClusterLoadSequential |
A write/read/verify load test on a mini HBase cluster.
|
TestMovingAverage | |
TestOrder | |
TestOrderedBytes | |
TestRecoverLeaseFSUtils |
Test our recoverLease loop against mocked up filesystem.
|
TestRecoverLeaseFSUtils.IsFileClosedDistributedFileSystem |
Version of DFS that has HDFS-4525 in it.
|
TestRegionMover1 |
Tests for Region Mover Load/Unload functionality with and without ack mode and also to test
exclude functionality useful for rack decommissioning
|
TestRegionMover2 |
Tests for Region Mover Load/Unload functionality with and without ack mode and also to test
exclude functionality useful for rack decommissioning
|
TestRegionMover3 | |
TestRegionMover3.MockRackManager | |
TestRegionSplitCalculator | |
TestRegionSplitCalculator.SimpleRange |
This is range uses a user specified start and end keys.
|
TestRegionSplitter |
Tests for
RegionSplitter , which can create a pre-split table or do a rolling split of an
existing table. |
TestReservoirSample | |
TestRetryCounter |
Basic test for some old functionality we don't seem to have used but that looks nice.
|
TestRootPath |
Test requirement that root directory must be a URI
|
TestRoundRobinPoolMap | |
TestShowProperties |
This test is there to dump the properties.
|
TestSimpleKdcServerUtil | |
TestSimpleMutableByteRange | |
TestSimplePositionedMutableByteRange | |
TestSortedList | |
TestSortedList.StringComparator | |
TestStealJobQueue | |
TestThreadLocalPoolMap | |
TestThreads | |
TestVersionInfo | |
TestWeakObjectPool | |
TimeOffsetEnvironmentEdge |
Enum | Description |
---|---|
ProcessBasedLocalHBaseCluster.ServerType |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.