All Classes and Interfaces
Class
Description
Based class for testing operation timeout logic for
ConnectionImplementation
.Based class for testing rpc timeout logic for
ConnectionImplementation
.Based class for testing timeout logic for
ConnectionImplementation
.This copro sleeps 20 second.
Base class for testing distributed log splitting.
Some basic ipc tests.
Test log deletion as logs are rolled.
Tests that verifies that the log is forced to be rolled every "hbase.regionserver.logroll.period"
WAL tests that can be reused across providers.
Base class to test Configuration Update logic.
Test replay of edits out of a WAL split.
Base class for parameterized unit tests that use X509TestContext for testing different X509
parameter combinations (CA key type, cert key type, with/without a password, with/without
hostname verification, etc).
Test case that uses multiple threads to read and write multifamily rows into a table, verifying
that reads never see partially-complete writes.
A test tool that uses multiple threads to read and write multifamily rows into a table, verifying
that reads never see partially-complete writes
Thread that does single-row reads in a table, looking for partially completed rows.
Thread that does random full-row writes into a table.
Thread that does full scans of the table looking for any partially completed rows.
org.apache.hadoop.hbase.chaos.actions.Action
A (possibly mischievous) action that the ChaosMonkey can perform.
org.apache.hadoop.hbase.chaos.actions.Action.ActionContext
Context for Action's
org.apache.hadoop.hbase.chaos.actions.AddColumnAction
Action the adds a column family to a table.
org.apache.hadoop.hbase.chaos.actions.AddCPULoadAction
Action that adds high cpu load to a random regionserver for a given duration
An implementation of HMaster that always runs as a stand by and never transitions to active.
org.apache.hadoop.hbase.client.trace.hamcrest.AttributesMatchers
Helper methods for matching against instances of
Attributes
.A bad Master Observer to prevent user to create/delete table once.
This is the base class for HBaseFsck's ability to detect reasons for inconsistent tables.
org.apache.hadoop.hbase.chaos.actions.BatchRestartRsAction
Restarts a ratio of the running regionservers at the same time
Utility to generate a bound socket.
Utility class to check whether a given class conforms to builder-style: Foo foo = new Foo()
.setBar(bar) .setBaz(baz)
org.apache.hadoop.hbase.util.bulkdatagenerator.BulkDataGeneratorInputFormat
org.apache.hadoop.hbase.util.bulkdatagenerator.BulkDataGeneratorInputSplit
Dummy input split to be used by
BulkDataGeneratorRecordReader
org.apache.hadoop.hbase.util.bulkdatagenerator.BulkDataGeneratorMapper
org.apache.hadoop.hbase.util.bulkdatagenerator.BulkDataGeneratorMapper.Counters
Counter enumeration to count number of rows generated.
org.apache.hadoop.hbase.util.bulkdatagenerator.BulkDataGeneratorRecordReader
org.apache.hadoop.hbase.util.bulkdatagenerator.BulkDataGeneratorTool
A command line utility to generate pre-splitted HBase Tables with large amount (TBs) of random
data, equally distributed among all regions.
org.apache.hadoop.hbase.client.hamcrest.BytesMatchers
Helper methods for matching against values passed through the helper methods of
Bytes
.org.apache.hadoop.hbase.chaos.monkies.CalmChaosMonkey
Chaos Monkey that does nothing.
org.apache.hadoop.hbase.chaos.factories.CalmMonkeyFactory
Factory to create a calm ChaosMonkey.
org.apache.hadoop.hbase.chaos.actions.ChangeBloomFilterAction
Action that tries to adjust the bloom filter setting on all the columns of a table
org.apache.hadoop.hbase.chaos.actions.ChangeCompressionAction
Action that changes the compression algorithm on a column family from a list of tables.
org.apache.hadoop.hbase.chaos.actions.ChangeEncodingAction
Action that changes the encoding on a column family from a list of tables.
org.apache.hadoop.hbase.chaos.actions.ChangeSplitPolicyAction
org.apache.hadoop.hbase.chaos.actions.ChangeVersionsAction
Action that changes the number of versions on a column family from a list of tables.
org.apache.hadoop.hbase.chaos.monkies.ChaosMonkey
A utility to injects faults in a running cluster.
org.apache.hadoop.hbase.chaos.util.ChaosMonkeyRunner
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.
Some utilities to help class loader testing
ClassFinder that is pre-configured with filters that will only allow test classes.
Filters both test classes and anything in the hadoop-compat modules
A
TestRule
that clears all user namespaces and tables before
the test executes.Test that we can actually send and use region metrics to slowdown client writes
org.apache.hadoop.hbase.testclassification.ClientTests
Tag a test as related to the client.
Base class for testing clone snapsot
Do basic codec performance eval.
org.apache.hadoop.hbase.chaos.actions.CompactMobAction
Action that queues a table compaction.
org.apache.hadoop.hbase.chaos.actions.CompactRandomRegionOfTableAction
Region that queues a compaction of a random region from the table.
org.apache.hadoop.hbase.chaos.actions.CompactTableAction
Action that queues a table compaction.
org.apache.hadoop.hbase.chaos.policies.CompositeSequentialPolicy
A policy that runs multiple other policies one after the other
org.apache.hadoop.hbase.chaos.factories.ConfigurableSlowDeterministicMonkeyFactory
org.apache.hadoop.hbase.chaos.factories.ConfigurableSlowDeterministicMonkeyFactory.SupportedTypes
A
Rule
that manages the lifecycle of an instance of AsyncConnection
.A blocking queue implementation for adding a constant delay.
Overrides commands to make use of coprocessor where possible.
org.apache.hadoop.hbase.testclassification.CoprocessorTests
Tag a test as related to coprocessors.
org.apache.hadoop.hbase.chaos.actions.CorruptDataFilesAction
Action corrupts HFiles with a certain chance.
org.apache.hadoop.hbase.chaos.actions.CorruptPacketsCommandAction
Corrupt network packets on a random regionserver.
org.apache.hadoop.hbase.test.util.CRC64
Creates an HFile with random key/value pairs.
Tests various algorithms for key compression on an existing HFile.
org.apache.hadoop.hbase.chaos.factories.DataIssuesMonkeyFactory
A chaos monkey to delete and corrupt regionserver data, requires a user with passwordless ssh
access to the cluster and sudo privileges.
org.apache.hadoop.hbase.chaos.actions.DecreaseMaxHFileSizeAction
org.apache.hadoop.hbase.chaos.actions.DelayPacketsCommandAction
Action adds latency to communication on a random regionserver.
org.apache.hadoop.hbase.chaos.actions.DeleteDataFilesAction
Action deletes HFiles with a certain chance.
Manages the interactions with an already deployed distributed cluster (as opposed to a
pseudo-distributed, or mini/local cluster).
org.apache.hadoop.hbase.chaos.factories.DistributedIssuesMonkeyFactory
A chaos monkey to create distributed cluster related issues, requires a user with passwordless
ssh access to the cluster and sudo privileges.
org.apache.hadoop.hbase.chaos.policies.DoActionsOncePolicy
A policy which performs a sequence of actions deterministically.
Registry that does nothing.
Can be overridden in UT if you only want to implement part of the methods in
AsyncTable
.Just a dummy exception for testing IPCUtil.isFatalConnectionException.
Just a dummy exception for testing IPCUtil.isFatalConnectionException.
A dummy replication endpoint that does nothing, for test use only.
org.apache.hadoop.hbase.chaos.actions.DumpClusterStatusAction
Action to dump the cluster status.
org.apache.hadoop.hbase.chaos.actions.DumpHdfsClusterStatusAction
org.apache.hadoop.hbase.chaos.actions.DuplicatePacketsCommandAction
Duplicate network packets on a random regionserver.
Test seek performance for encoded data blocks.
Used by tests to inject an edge into the manager.
Simple test coprocessor for injecting exceptions on Get requests.
org.apache.hadoop.hbase.client.trace.hamcrest.EventMatchers
Helper methods for matching against instances of
EventData
.This is a utility class, used by tests, which fails operation specified by FailureType enum
This class is used for testing only.
org.apache.log4j.FileAppender
Just a copy of the old log4j12 FileAppender.
Create a non-abstract "proxy" for FileSystem because FileSystem is an abstract class and not an
interface.
org.apache.hadoop.hbase.chaos.actions.FillDiskCommandAction
Fill the disk on a random regionserver.
By using this class as the super class of a set of tests you will have a HBase testing cluster
available that is very suitable for writing tests for scanning and filtering against.
org.apache.hadoop.hbase.testclassification.FilterTests
Tag a test as related to the
org.apache.hadoop.hbase.filter
package.org.apache.hadoop.hbase.testclassification.FlakeyTests
Tag a test as failing commonly on public build infrastructure.
org.apache.hadoop.hbase.chaos.actions.FlushRandomRegionOfTableAction
Action that tries to flush a random region of a table.
org.apache.hadoop.hbase.chaos.actions.FlushTableAction
Action that tries to flush a table.
org.apache.hadoop.hbase.chaos.actions.ForceBalancerAction
Action that tries to force a balancer run.
Test provides some very generic helpers which might be used across the tests
Mockito answer helper that triggers one latch as soon as the method is called, then waits on
another before continuing.
An Answer implementation that simply forwards all calls through to a delegate.
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.
org.apache.hadoop.hbase.chaos.actions.GracefulRollingRestartRsAction
Gracefully restarts every regionserver in a rolling fashion.
A
UserProvider
that always says hadoop security is enabled, regardless of the underlying
configuration.A compatibility shim layer for interacting with different versions of Hadoop.
Compatibility shim layer implementation for Hadoop-2.
The class level TestRule for all the tests.
A RunListener to confirm that we have a
HBaseClassTestRule
class rule for every test.This class defines methods that can help with managing HBase clusters from unit tests and system
tests.
A default cluster manager for HBase.
Common helpers for testing HBase that do not depend on specific server/etc.
Determines HBase home path from either class or jar directory
Log4j2 appender to be used when running UTs.
Deprecated.
since 2.0.0 and will be removed in 3.0.0.
Facility for testing HBase.
A tracker for tracking and validating table rows generated with
HBaseTestingUtility.loadTable(Table, byte[])
Helpers for testing HBase that do not depend on specific server/etc.
Connection
testing utility.This coproceesor sleep 2s at first increment/append rpc call.
org.apache.hadoop.hbase.chaos.actions.HdfsActionUtils
Configuration common across the HDFS Actions.
Test helper for testing archiving of HFiles
This class runs performance benchmarks for
HFile
.Utility class for HFile-related testing.
Similar to
HConstants
but for tests.This is a base class for functional tests of the
HttpServer
.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.
An integration test to detect regressions in HBASE-7912.
Base class for HBase integration tests that want to use the Chaos Monkey.
org.apache.hadoop.hbase.test.IntegrationTestBigLinkedList
This is an integration test borrowed from goraci, written by Keith Turner, which is in turn
inspired by the Accumulo test called continous ingest (ci).
org.apache.hadoop.hbase.test.IntegrationTestBigLinkedListWithVisibility
IT test used to verify the deletes with visibility labels.
Test Bulk Load and MR on a distributed cluster.
Comparator used to order linkKeys so that they are passed to a reducer in order.
Writable used as the value emitted from a pass over the hbase table.
Mapper to pass over the table.
Class that does the actual checking of the links.
Mapper that creates a linked list of KeyValues.
Writable class used as the key to group links in the linked list.
Comparator used to figure out if a linkKey should be grouped together.
Class to figure out what partition to send a link in the chain to.
Integration test that verifies Procedure V2.
Test Bulk Load and MR on a distributed cluster.
Validate ImportTsv + LoadIncrementalHFiles on a distributed cluster.
A base class for tests that do something with the cluster while running
LoadTestTool
to
write and verify some data.A test class that does the same things as IntegrationTestIngest but with stripe compactions.
/** An Integration class for tests that does something with the cluster while running
LoadTestTool
to write and verify some data.Integration Test for MOB ingest.
Facility for integration/system tests.
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.
org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify
A large test which loads a lot of data that has internal references, and verifies the data.
org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.LoadMapper
org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.VerifyMapper
org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.VerifyReducer
org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.WALSearcher
Tool to search missing rows in WALs and hfiles.
org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.WALSearcher.WALMapperSearcher
The actual searcher mapper.
org.apache.hadoop.hbase.test.IntegrationTestLoadCommonCrawl
This integration test loads successful resource retrieval records from the Common Crawl
(https://commoncrawl.org/) public dataset into an HBase table and writes records that can be used
to later verify the presence and integrity of those records.
org.apache.hadoop.hbase.test.IntegrationTestLoadCommonCrawl.Counts
org.apache.hadoop.hbase.test.IntegrationTestLoadCommonCrawl.HBaseKeyWritable
org.apache.hadoop.hbase.test.IntegrationTestLoadCommonCrawl.Loader
org.apache.hadoop.hbase.test.IntegrationTestLoadCommonCrawl.Loader.LoaderMapper
org.apache.hadoop.hbase.test.IntegrationTestLoadCommonCrawl.OneFilePerMapperSFIF<K,V>
org.apache.hadoop.hbase.test.IntegrationTestLoadCommonCrawl.Verify
org.apache.hadoop.hbase.test.IntegrationTestLoadCommonCrawl.Verify.VerifyMapper
An integration test to detect regressions in HBASE-7220.
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.
An integration test to detect regressions in HBASE-22749.
org.apache.hadoop.hbase.test.IntegrationTestMonkeys
This is an integration test for showing a simple usage of how to use
Monkeys
to control
ChaosMonkeyRunner
.org.apache.hadoop.hbase.mttr.IntegrationTestMTTR
Integration test that should benchmark how fast HBase can recover from failures.
org.apache.hadoop.hbase.mttr.IntegrationTestMTTR.LoadCallable
Callable used to make sure the cluster has some load on it.
Test for comparing the performance impact of region replicas.
Integration test for testing async wal replication to secondary region replicas.
This extends MultiThreadedWriter to add a configurable delay to the keys written by the writer
threads to become available to the MultiThradedReader threads.
This extends MultiThreadedWriter to add a configurable delay to the keys written by the writer
threads to become available to the MultiThradedReader threads.
org.apache.hadoop.hbase.test.IntegrationTestReplication
This is an integration test for replication.
org.apache.hadoop.hbase.test.IntegrationTestReplication.ClusterID
Wrapper around an HBase ClusterID allowing us to get admin connections and configurations for
it
org.apache.hadoop.hbase.testclassification.IntegrationTests
Tag a test as 'integration/system' test, meaning that the test class has the following
characteristics:
Possibly takes hours to complete
Can be run on a mini cluster or an actual cluster
Can make changes to the given cluster (starting stopping daemons, etc)
Should not be run in parallel of other integration tests
Integration / System tests should have a class name starting with "IntegrationTest", and should
be annotated with @Category(IntegrationTests.class).
This class drives the Integration test suite execution.
Test that we add tmpjars correctly including the named dependencies.
An integration test to test
TableSnapshotInputFormat
which enables reading directly from
snapshot files without going through hbase servers.org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedMultiGetRequestsWithRegionReplicas
Extends
IntegrationTestTimeBoundedRequestsWithRegionReplicas
for multi-gets Besides the
options already talked about in IntegrationTestTimeBoundedRequestsWithRegionReplicas the addition
options here are:org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas
An IntegrationTest for doing reads with a timeout, to a read-only table with region replicas.
org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader
org.apache.hadoop.hbase.test.IntegrationTestWithCellVisibilityLoadAndVerify
A large test which loads a lot of data with cell visibility, and verifies the data.
org.apache.hadoop.hbase.test.IntegrationTestWithCellVisibilityLoadAndVerify.LoadWithCellVisibilityMapper
org.apache.hadoop.hbase.test.IntegrationTestWithCellVisibilityLoadAndVerify.VerifyMapper
org.apache.hadoop.hbase.test.IntegrationTestZKAndFSPermissions
An integration test which checks that the znodes in zookeeper and data in the FileSystem are
protected for secure HBase deployments.
A WAL Provider that returns a single thread safe WAL that optionally can skip parts of our normal
interactions with HDFS.
org.apache.hadoop.hbase.testclassification.IOTests
Tag a test as related to the
org.apache.hadoop.hbase.io
package.org.apache.hadoop.hbase.http.resource.JerseyResource
A simple Jersey resource class TestHttpServer.
Return a fixed secret key for AES for testing.
org.apache.hadoop.hbase.http.ssl.KeyStoreTestUtil
A fixture that implements and presents a KeyValueScanner.
org.apache.hadoop.hbase.testclassification.LargeTests
Tagging a test as 'large', means that the test class has the following characteristics:
it can executed in an isolated JVM (Tests can however be executed in different JVM on the
same machine simultaneously so be careful two concurrent tests end up fighting over ports or
other singular resources).
ideally, the whole large test-suite/class, no matter how many or how few test methods it has,
will run in last less than three minutes
No large test can take longer than ten minutes; it will be killed.
class for masquerading System.exit(int).
A load test data generator for MOB
A generator of random keys and values for load testing.
A command-line utility that reads, writes, and verifies data.
org.apache.hadoop.hbase.chaos.actions.LosePacketsCommandAction
Lose network packets on a random regionserver.
This class provides shims for HBase to interact with the Hadoop 1.0.x and the Hadoop 0.23.x
series.
org.apache.hadoop.hbase.testclassification.MapReduceTests
Tag a test as related to mapred or mapreduce.
org.apache.hadoop.hbase.chaos.factories.MasterKillingMonkeyFactory
A chaos monkey to kill the active master periodically.
org.apache.hadoop.hbase.testclassification.MasterTests
Tag a test as related to the master.
An implementation of
Waiter.ExplainingPredicate
that uses Hamcrest Matcher
for
both predicate evaluation and explanation.org.apache.hadoop.hbase.testclassification.MediumTests
Tagging a test as 'medium' means that the test class has the following characteristics:
it can be executed in an isolated JVM (Tests can however be executed in different JVMs on the
same machine simultaneously so be careful two concurrent tests end up fighting over ports or
other singular resources).
ideally, the whole medium test-suite/class, no matter how many or how few test methods it
has, will complete in 50 seconds; otherwise make it a 'large' test.
Use it for tests that cannot be tagged as 'small'.
org.apache.hadoop.hbase.chaos.actions.MergeRandomAdjacentRegionsOfTableAction
Action to merge regions of a table.
Mocking utility for common hbase:meta functionality
Base class for testing the scenarios where replicas are enabled for the meta table.
org.apache.hadoop.hbase.test.MetricsAssertHelper
Interface of a class to make assertions about metrics values.
org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
A helper class that will allow tests to get into hadoop2's metrics2 values.
org.apache.hadoop.hbase.testclassification.MetricsTests
Tag a test that covers our metrics handling.
A
TestRule
that manages an instance of the MiniHBaseCluster
.A builder for fluent composition of a new
MiniClusterRule
.This class creates a single process HBase cluster.
Subclass so can get at protected methods (none at moment).
org.apache.hadoop.hbase.testclassification.MiscTests
Tag a test as not easily falling into any of the below categories.
org.apache.hadoop.hbase.chaos.factories.MobNoKillMonkeyFactory
This is a copy of NoKillMonkeyFactory that also does mob compactions.
org.apache.hadoop.hbase.chaos.factories.MobSlowDeterministicMonkeyFactory
This is a copy of SlowDeterministicMonkeyFactory that also does mob compactions.
Reproduction for MOB data loss 1.
A mock used so our tests don't deal with actual StoreFiles
A
Rule
that manages a simple http server.Basic mock region server services.
Basic mock Server for handler tests.
org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
org.apache.hadoop.hbase.chaos.factories.MonkeyFactory
Base class of the factory that will create a ChaosMonkey.
org.apache.hadoop.hbase.chaos.util.Monkeys
This class can be used to control chaos monkeys life cycle.
org.apache.hadoop.hbase.chaos.actions.MoveRandomRegionOfTableAction
Action that tries to move a random region of a table.
org.apache.hadoop.hbase.chaos.actions.MoveRegionsOfTableAction
Action that tries to move every region of a table.
Base set of tests and setup for input formats touching multiple tables.
Pass the key and value to reducer.
Checks the last and first keys seen against the scanner boundaries.
Common base class for reader and writer parts of multi-thread HBase load test (See LoadTestTool).
Default implementation of LoadTestDataGenerator that uses LoadTestKVGenerator, fixed set of
column families, and random number of columns in range.
Creates multiple threads that read and verify previously written data
A MultiThreadReader that helps to work with ACL
A test thread that performs a repeating operation.
A thread that can be added to a test context, and properly passes exceptions through.
Creates multiple threads that write key/values into the
A MultiThreadUpdater that helps to work with ACL
Creates multiple threads that write key/values into the
Creates multiple threads that write key/values into the
MultiThreadedWriter that helps in testing ACL
A nano-second timer.
Input format that creates a configurable number of map tasks each provided with a single row of
NullWritables.
A helper class for writing UTs, where we will eat the EOF and return null when reaching EOF, so
in UTs we do not need to deal with partial WAL files if this does not affect the correctness.
org.apache.hadoop.hbase.chaos.factories.NoKillMonkeyFactory
Monkey factory to create a ChaosMonkey that will not need access to ssh.
An clock which will never return the same clock twice.
RegionObserver that just reimplements the default behavior, in order to validate that all the
necessary APIs for this are public This observer is also used in
TestFromClientSideWithCoprocessor
and TestCompactionWithCoprocessor
to make sure
that a wide range of functionality still behaves as expected.A region server that will OOME.
Script used evaluating HBase performance and scalability.
Script used evaluating Stargate performance and scalability.
Enum for map metrics.
Enum for map metrics.
MapReduce job that runs a performance evaluation client in each map task.
MapReduce job that runs a performance evaluation client in each map task.
InputFormat of Performance Evaluation MapReduce job.
This class works as the InputSplit of Performance Evaluation MapReduce InputFormat, and the
Record Value of RecordReader.
Code shared by PE tests.
org.apache.hadoop.hbase.chaos.policies.PeriodicPolicy
A policy which does stuff every time interval.
org.apache.hadoop.hbase.chaos.policies.PeriodicRandomActionPolicy
A policy, which picks a random action according to the given weights, and performs it every
configurable period.
org.apache.hadoop.hbase.chaos.policies.Policy
A policy to introduce chaos to the cluster
org.apache.hadoop.hbase.chaos.policies.Policy.PolicyContext
A context for a Policy
org.apache.hadoop.hbase.chaos.monkies.PolicyBasedChaosMonkey
Chaos monkey that given multiple policies will run actions against the cluster.
A helper class for process-based mini-cluster tests.
A class that generates random numbers that follow some distribution.
Binomial distribution.
Interface for discrete (integer) random distributions.
P(i)=1/(max-min)
Zipf distribution.
These helper methods generate random byte[]'s data for KeyValues
Generate list of key values which are very useful to test data block encoding and compression.
An implementation of
Table
that sits directly on a Region; it decorates the passed in
Region instance with the Table API.org.apache.hadoop.hbase.testclassification.RegionServerTests
Tag a test as related to the regionserver.
HTable interface to remote tables accessed via REST gateway
org.apache.hadoop.hbase.chaos.actions.RemoveColumnAction
Action that removes a column family.
org.apache.hadoop.hbase.chaos.actions.ReorderPacketsCommandAction
Reorder network packets on a random regionserver.
Base class for testing replication for dropped tables.
A helper tool for generating random
ReplicationPeerConfig
and do assertion.Source that does nothing at all, helpful to test ReplicationSourceManager
org.apache.hadoop.hbase.testclassification.ReplicationTests
Tag a test as related to replication.
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
Listen to the test progress and check the usage of:
threads
open file descriptor
max open file descriptor
A ClusterManager implementation designed to control Cloudera Manager (http://www.cloudera.com)
clusters via REST API.
org.apache.hadoop.hbase.chaos.actions.RestartActionBaseAction
Base class for restarting HBaseServer's
org.apache.hadoop.hbase.chaos.actions.RestartActiveMasterAction
Action that tries to restart the active master.
org.apache.hadoop.hbase.chaos.actions.RestartActiveNameNodeAction
Action that tries to restart the active namenode.
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.
org.apache.hadoop.hbase.chaos.actions.RestartRandomDataNodeAction
Action that restarts a random datanode.
org.apache.hadoop.hbase.chaos.actions.RestartRandomJournalNodeAction
org.apache.hadoop.hbase.chaos.actions.RestartRandomRsAction
Action that restarts a random HRegionServer
org.apache.hadoop.hbase.chaos.actions.RestartRandomRsExceptMetaAction
org.apache.hadoop.hbase.chaos.actions.RestartRandomZKNodeAction
Action that restarts a random zookeeper node.
org.apache.hadoop.hbase.chaos.actions.RestartRsHoldingMetaAction
Action that tries to restart the HRegionServer holding Meta.
org.apache.hadoop.hbase.chaos.actions.RestartRsHoldingTableAction
Action that restarts an HRegionServer holding one of the regions of the table.
Base class for testing restore snapshot
org.apache.hadoop.hbase.testclassification.RestTests
Tag a test as related to the REST capability of HBase.
org.apache.hadoop.hbase.chaos.actions.RollingBatchRestartRsAction
Restarts a ratio of the regionservers in a rolling fashion.
org.apache.hadoop.hbase.chaos.actions.RollingBatchSuspendResumeRsAction
Suspend then resume a ratio of the regionservers in a rolling fashion.
org.apache.hadoop.hbase.testclassification.RPCTests
Tag a test as related to RPC.
Class for testing WALObserver coprocessor.
A simple performance evaluation tool for single client and MR scans and snapshot scans.
org.apache.hadoop.hbase.testclassification.SecurityTests
Tag a test as related to security.
Base class for testing serial replication.
org.apache.hadoop.hbase.chaos.factories.ServerAndDependenciesKillingMonkeyFactory
Creates ChaosMonkeys for doing server restart actions, but not flush / compact / snapshot kind of
actions.
org.apache.hadoop.hbase.chaos.factories.ServerKillingMonkeyFactory
Creates ChaosMonkeys for doing server restart actions, but not flush / compact / snapshot kind of
actions.
Receives shell commands from the client and executes them blindly.
org.apache.hadoop.hbase.client.procedure.ShellTestProcedure
A custom byte buf allocator for TestNettyRpcServer.
Utility for running
SimpleKdcServer
.A sample region observer that tests the RegionObserver interface.
A simplistic
ScanResultConsumer
for use in tests.org.apache.hadoop.hbase.chaos.factories.SlowDeterministicMonkeyFactory
org.apache.hadoop.hbase.testclassification.SmallTests
Tagging a test as 'small' means that the test class has the following characteristics:
it can be run simultaneously with other small tests all in the same JVM
ideally, the WHOLE implementing test-suite/class, no matter how many or how few test methods
it has, should take less than 15 seconds to complete
it does not use a cluster
org.apache.hadoop.hbase.chaos.actions.SnapshotTableAction
Action that tries to take a snapshot of a table.
Utilities class for snapshots
A SpaceQuotaSnapshotNotifier implementation for testing.
org.apache.hadoop.hbase.client.trace.hamcrest.SpanDataMatchers
Helper methods for matching against instances of
SpanData
.org.apache.hadoop.hbase.chaos.actions.SplitAllRegionOfTableAction
org.apache.hadoop.hbase.chaos.actions.SplitRandomRegionOfTableAction
Action that tries to split a random region of a table.
Options for starting up a mini cluster (including an hbase, dfs and zookeeper clusters) in test.
Builder pattern for creating an
StartMiniClusterOption
.This class is a helper that allows to create a partially-implemented, stateful mocks of Store.
A base implementation for a Stoppable service
org.apache.hadoop.hbase.chaos.factories.StressAssignmentManagerMonkeyFactory
A Rudimentary tool for visualizing a hierarchy of spans.
A perf test which does large data ingestion using stripe compactions and regular compactions.
org.apache.hadoop.hbase.chaos.actions.SudoCommandAction
Base class for performing Actions based on linux commands requiring sudo privileges
Returns a
TableName
based on currently running test method name.Used in testcases only.
org.apache.hadoop.hbase.chaos.actions.TCCommandAction
Base class for tc command actions
Test the
ActiveMasterManager
.Dummy Master Implementation.
Test class for
ActivePolicyEnforcement
.Testcase for HBASE-20147.
Class to test HBaseAdmin.
Class to test HBaseAdmin.
Testcase to make sure that we always set scanner id in ScanResponse.
Run Append tests that use the HBase clients;
Class to test AsyncAdmin.
Testcase for HBASE-22135.
Confirm that we will set the priority in
HBaseRpcController
for several admin operations.Only used to test stopMaster/stopRegionServer/shutdown methods.
See HBASE-24513.
Provides AsyncFSWAL test cases.
Testcase for HBASE-22539
Testcase for HBASE-25905
Test covers when client is configured with
RpcConnectionRegistry
.Test covers when client is configured with
ZKConnectionRegistry
.Class to test asynchronous namespace admin operations.
Class to test asynchronous procedure admin operations.
The purpose of this test is to make sure the region exception won't corrupt the results of batch.
Class to test asynchronous region admin operations.
Class to test asynchronous region admin operations.
Class to test asynchronous replication admin operations.
Class to test asynchronous replication admin operations when more than 1 cluster
Class to test asynchronous table admin operations.
Class to test asynchronous table admin operations
Class to test asynchronous table admin operations.
Will split the table, and move region randomly when testing.
Fix an infinite loop in
AsyncNonMetaRegionLocator
, see the comments on HBASE-21943 for
more details.Confirm that we will set the priority in
HBaseRpcController
for several table operations.Test the admin operations for Balancer, Normalizer, CleanerChore, and CatalogJanitor.
Testing of HRegion.incrementColumnValue, HRegion.increment, and HRegion.append
A thread that makes increment calls always on the same row, this.row against two column
families on this row.
This class is only a base for other integration-level backup tests.
This class is only a base for other integration-level backup tests.
Create multiple backups for two tables: table1, table2 then perform 1 delete
Test cases for backup system table API
Test balancer with disabled table
Test of default BaseSource for hadoop 2
This file has been copied from the Apache ZooKeeper project.
Tests for the bit comparator
A UT to make sure that everything is fine when we fail to load bloom filter.
Make sure that we can update the bootstrap server from master to region server, and region server
could also contact each other to update the bootstrap nodes.
My BufferedMutator.
This class attempts to unit test bulk HLog loading.
Integration test for bulk load replication.
Tests that
CacheConfig
does as expected.Tests
HFile
cache-on-write functionality for the following block types: data blocks,
non-root index blocks, and Bloom filter blocks.Tests
HFile
cache-on-write functionality for data blocks, non-root index blocks, and
Bloom filter blocks, as specified by the column family.Unit testing for CallQueue, a part of the org.apache.hadoop.hbase.thrift package.
Simple test for
HFileOutputFormat2
.Tests the table import and table export MR job functionality
Basic test for the WALPlayer M/R tool
org.apache.hadoop.hbase.chaos.actions.TestChangeSplitPolicyAction
Test changing store file tracker implementation by altering table.
Tests changing data block encoding settings of a column family.
An override of HRegion to allow sleep after get(), waiting for the release of DBB
Checks tests are categorized.
A Chore that will try to execute the initial chore a few times before succeeding.
In HBASE-26029, we reimplement the claim queue operation with proc-v2 and make it a step in SCP,
this is a UT to make sure the
ClaimReplicationQueuesProcedure
works correctly.Make sure we will honor the
HConstants.META_REPLICAS_NUM
.Test the ClusterStatus.
Test client behavior w/o setting up a cluster.
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.
This
RSRpcServices
class injects delay for Rpc calls and after executes super methods.Test the ClientScanner.
Rpc Channel implementation with RandomTimeoutBlockingRpcChannel
Tests the boot order indifference between regionserver and master
Test metrics incremented on region server operations.
Testcase for HBASE-21732.
Test for the ColumnPaginationFilter, used mainly to test the successful serialization of the
filter.
Test
CommonFSUtils
.compacted memstore test case
compacted memstore test case
Test compaction framework and common functions
Simple
CompactionLifeCycleTracker
on which you can wait until the requested compaction
finishes.Simple
CompactionLifeCycleTracker
on which you can wait until the requested compaction
finishes.Tests a race condition between archiving of compacted files in CompactedHFilesDischarger chore
and HRegion.close();
Tests that archiving compacted files behaves correctly when encountering exceptions.
This class tests the scenario where a store refresh happens due to a file not found during scan,
after a compaction but before the compacted files are archived.
This testcase is used to ensure that the compaction marker will fail a compaction if the RS is
already dead.
Confirm that the function of CompactionLifeCycleTracker is OK as we do not use it in our own
code.
Unit tests to test retrieving table/region compaction state
Make sure compaction tests still pass with the preFlush and preCompact overridden to implement
the default behavior
Tests writing Bloom filter blocks in the same part of the file as data blocks.
Test our compressor class.
Basic test case that the ConfServlet can write configuration to its output in XML and JSON
format.
This class is for testing HBaseConnectionManager features
Test TestCoprocessorClassLoader.
Tests for global coprocessor loading configuration
Testing of coprocessor metrics end-to-end.
MasterObserver that has a Timer metric for create table operation.
RegionEndpoint to test metrics from endpoint calls
RegionObserver that has a Counter for preGet()
RegionServerObserver that has a Counter for rollWAL requests.
WALObserver that has a Counter for walEdits written.
Ensure Coprocessors get ShortCircuit Connections when they get a Connection from their
CoprocessorEnvironment.
Tests for master and regionserver coprocessor stop method
Basic test for the CopyTable M/R tool
Test CoreCoprocessor Annotation works giving access to facility not usually available.
Annotate with CoreCoprocessor.
No annotation with CoreCoprocessor.
Test CoreCoprocessor Annotation works giving access to facility not usually available.
Annotate with CoreCoprocessor.
No annotation with CoreCoprocessor.
Test CoreCoprocessor Annotation works giving access to facility not usually available.
Annotate with CoreCoprocessor.
No annotation with CoreCoprocessor.
Test that we can create, load, setup our own custom codec
Test all of the data block encoding algorithms for correctness.
Test DataBlockEncodingTool.
Tests to make sure that the default environment edge conforms to appropriate behaviour.
memstore test case
Test class for
DisableTableViolationPolicyEnforcement
.Test a drop timeout request.
Coprocessor that sleeps a while the first time you do a Get
Tests for WAL write durability
Test TestDynamicClassLoader
Test enable RSGroup
Tests encoded seekers by loading and reading values.
Test Export Snapshot Tool
Tests that are adjunct to
TestExportSnapshot
.Test Export Snapshot Tool helpers
Test Export Snapshot Tool Tests V1 snapshots only.
Test Export Snapshot Tool; tests v2 snapshots.
Testing sync/append failures.
Testcase for HBASE-26679, here we introduce a separate test class and not put the testcase in
TestFanOutOneBlockAsyncDFSOutput
because we will send heartbeat to DN when there is no
out going packet, the timeout is controlled by
TestFanOutOneBlockAsyncDFSOutput.READ_TIMEOUT_MS
,which is 2 seconds, it will keep sending
package out and DN will respond immedately and then mess up the testing handler added by us.Test class for
FileArchiverNotifierImpl
.This file has been copied from the Apache ZooKeeper project.
This file has been copied from the Apache ZooKeeper project.
Test that FileLink switches between alternate locations when the current location moves or gets
deleted.
Test class for
FileSystemUtilizationChore
.Test filters at the HRegion doorstep.
Filter which makes sleeps for a second between each row of a scan.
To test behavior of filters at server from region side.
Tests filter Lists in ways that rely on a MiniCluster.
Test if Filter is incompatible with scan-limits
Test if the FilterWrapper retains the same semantics defined in the
Filter
Confirm that the function of FlushLifeCycleTracker is OK as we do not use it in our own code.
Test creating/using/deleting snapshots from the client
Make sure we always cache important block types, such as index blocks, as long as we have a block
cache, even though block caching might be disabled for the column family.
Test that we propagate errors through an dispatcher exactly once via different failure injection
mechanisms.
Test that we correctly serialize exceptions from a remote source
Run tests that use the HBase clients;
Table
.Run tests that use the HBase clients;
Table
.Run tests that use the HBase clients;
Table
.Do some ops and prove that client and server can work w/o codecs; that we can pb all the time.
Test all client operations with a coprocessor that just implements the default flush/compact/scan
policy.
Test all client operations with a coprocessor that just implements the default flush/compact/scan
policy.
Test all client operations with a coprocessor that just implements the default flush/compact/scan
policy.
Test all client operations with a coprocessor that just implements the default flush/compact/scan
policy.
Test cases that ensure that file system level errors are bubbled up appropriately to clients,
rather than swallowed.
Provides FSHLog test cases.
Testcase for HBASE-22539
Tests for
FSTableDescriptors
.Test
FSUtils
.Test
FSUtils
.TestGet is a medley of tests of get all done up as a single test.
Trivial test to confirm that we do not get 0 infoPort.
Trivial test to confirm that we can get last flushed sequence id by encodedRegionName.
Testcase for HBASE-19608.
Testcase for HBASE-21032, where use the wrong readType from a Scan instance which is actually a
get scan and cause returning only 1 cell per rpc call.
Testcase for HBASE-21032, where use the wrong readType from a Scan instance which is actually a
get scan and cause returning only 1 cell per rpc call.
A very simple filter that records accessed uri's
Configuration for RecordingFilter
Test HBASE-3694 whether the GlobalMemStoreSize is the same as the summary of all the online
region's MemStoreSize
Basic test for the HashTable M/R tool
Tests HBaseClassTestRule.
Test the comparator used by Hbck.
Test cases taken and adapted from Apache ZooKeeper Project
Test being able to edit hbase:meta.
Test that an HBase cluster can run on top of an existing MiniDfsCluster
Test our testing utility class
Make sure we can spin up a HBTU without a hbase-site.xml
Test cases taken and adapted from Apache ZooKeeper Project.
Class to test HBaseHbck.
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 together with
HColumnDescriptor
.Verify that the HColumnDescriptor version is set correctly by default, hbase-site.xml, and user
input
Testing the sizing that HeapSize offers and compares to the size given by ClassSize.
Unit testing for HelloHBase.
Unit testing for HelloHBase.
test hfile features.
Test that the utility works as expected
Test that the
HFileArchiver
correctly removes all the parts of a region when cleaning up
a regionThis test provides coverage for HFileHeader block fields that are read and interpreted before
HBase checksum validation can be applied.
Enables writing and rewriting portions of the file backing an
HFileBlock
.Reads blocks off of an
TestHFileBlockHeaderCorruption.HFileBlockChannelPositionIterator
, counting them as it does.Data class to enabled messing with the bytes behind an
HFileBlock
.A simplified wrapper over an
HFileBlock.BlockIterator
that looks a lot like an
Iterator
.Test a case when an inline index chunk is converted to a root one.
Test that FileLink switches between alternate locations when the current location moves or gets
deleted.
Simple test for
HFileOutputFormat2
.Test
test the performance for seek.
Testing writing a version 3
HFile
.Testing writing a version 3
HFile
for all encoded blocksTest for HQuorumPeer.
Basic stand-alone testing of HRegion.
The same as HRegion class, the only difference is that instantiateHStore will create a
different HStore - HStoreForTesting.
HStoreForTesting is merely the same as HStore, the difference is in the doCompaction method of
HStoreForTesting there is a checkpoint "hbase.hstore.compaction.complete" which doesn't let
hstore compaction complete.
Tests that need to spin up a cluster testing an
HRegion
.Tests of HRegion methods for replaying flush, compaction, region open, etc events for secondary
region replicas
Tests bulk loading of HFiles and shows the atomicity or lack of atomicity of the region server's
bullkLoad functionality.
Thread that does full scans of the table looking for any partially completed rows.
Thread that does full scans of the table looking for any partially completed rows.
Tests bulk loading of HFiles with old non-secure client for backward compatibility.
A test similar to TestHRegion, but with in-memory flush families.
Test class for the HStore
Test HStoreFile
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 together with
HTableDescriptor
.FilterInitializer that initialized the DummyFilter.
Dummy filter that mimics as an authentication filter.
Custom user->group mapping service.
Test webapp loading
Test ImmutableHRegionInfo
Small tests for ImmutableScan
Tests the table import and table export MR job functionality
Tests for
ImportTsv.TsvParser
.Tests the inclusive stop row filter
Make sure we will honor the
HConstants.META_REPLICAS_NUM
.And also test upgrading.1.
Test all
Increment
client operations with a coprocessor that just implements the default
flush/compact/scan policy.Tests that the incrementing environment edge increments time instead of using the default.
Run Increment tests that use the HBase clients;
TableBuilder
.This test runs batch mutation with Increments which have custom TimeRange.
Testing, info servers are disabled.
Testing info servers for admin acl.
Setup two clusters for replication.
Test scan/get offset and limit settings within one row through HRegion API.
Test the invocation logic of the filters.
Test for the case where a regionserver going down has enough cycles to do damage to regions that
have actually been assigned elsehwere.
An override of HRegion that allows us park compactions in a holding pattern and then when
appropriate for the test, allow them proceed again.
An override of HRegion that allows us park compactions in a holding pattern and then when
appropriate for the test, allow them proceed again.
This tests whether ServerSocketChannel works over ipv6, which ZooKeeper depends on.
Test failure in ScanDeleteTracker.isDeleted when ROWCOL bloom filter is used during a scan with a
filter.
This file was forked from hadoop/common/branches/branch-2@1350012.
This file has been copied from the Apache ZooKeeper project.
Test case for JMX Connector Server.
Test performance improvement of joined scanners optimization:
https://issues.apache.org/jira/browse/HBASE-5416
Test
JSONBean
.This should be in the hbase-logging module but the
HBaseClassTestRule
is in hbase-common
so we can only put the class in hbase-common module for now...This file has been copied from the Apache ZooKeeper project.
With filter we may stop at a middle of row and think that we still have more cells for the
current row but actually all the remaining cells will be filtered out by the filter.
Uses the load tester
Testcase for HBASE-21490.
A private master class similar to that used by HMasterCommandLine when running in local mode.
A private regionserver class with a dummy method for testing casts
This should be in the hbase-logging module but the
HBaseClassTestRule
is in hbase-common
so we can only put the class in hbase-common module for now...Test LogLevel.
Tests for conditions that should trigger RegionServer aborts when rolling the current WAL fails.
Test many concurrent appenders to an WAL while rolling the log.
ProtobufLogWriter that simulates higher latencies in sync() call
Tests the concurrent LruAdaptiveBlockCache.
Tests the concurrent LruBlockCache.
Tests LRUDictionary
Test major compactions
The purpose of this test is to ensure whether rs deals with the malformed cells correctly.
Tests to validate if HMaster default chores are scheduled
Tests unhandled exceptions thrown by coprocessors running on master.
Tests unhandled exceptions thrown by coprocessors running on master.
Tests that the MasterRpcServices is correctly searching for implementations of the Coprocessor
Service and not just the "default" implementations of those services.
Test the master filesystem in a local cluster
Test the master filesystem in a local cluster with Store File Tracking explicitly set in global
config
Test the master filesystem in a local cluster
Make open region very slow
Standup the master and fake it to test various aspects of master function.
Tests invocation of the
MasterObserver
interface
hooks at all appropriate times during normal HMaster operations.Test class for
MasterQuotasObserver
.Test class for MasterQuotasObserver that does not require a cluster.
Use a coprocessor to count puts and deletes.
Test transitions of state across the master.
Test the
ChunkCreator.MemStoreChunkPool
classTest the
MemStoreCompactorSegmentsIterator
and MemStoreMergerSegmentsIterator
class, Test for bug : HBASE-22324Throws CallQueueTooBigException for all gets.
Rotates through the possible cache clearing and non-cache clearing exceptions for requests.
Tests handling of meta-carrying region server failover.
Test
MetaTableAccessor
.Test MetaTableAccessor but without spinning up a cluster.
Test
MetaTableLocator
Test class for
MetricRegistriesLoader
.Unit test version of rs metrics tests.
Test for MetricsMasterProcSourceImpl
Test for the CompatibilitySingletonFactory and building MetricsMasterSource
Test for MetricsMasterSourceImpl
Unit test version of rs metrics tests.
Test for the CompatibilitySingletonFactory and building MetricsRegionServerSource
Test of Rest Metrics Source interface.
Test for hadoop 2's version of
MetricsRESTSource
.Test for MetricsTableSourceImpl
Test for the interface of MetricsThriftServerSourceFactory
Test for hadoop 2's version of MetricsThriftServerSourceFactory.
Testcase for HBASE-26193.
Runs a load test on a mini HBase cluster with data block encoding turned on.
A write/read/verify load test on a mini HBase cluster.
A write/read/verify load test on a mini HBase cluster.
Test minor compactions
Test Minimum Versions feature (HBASE-4071).
Tests that table state is mirrored out to zookeeper for hbase-1.x clients.
This coprocessor is used to delay the flush.
Mob file compaction chore in a generational non-batch mode test.
Mob file compaction chore in a generational batch mode test.
Mob file compaction chore in a regular batch mode test.
Mob file compaction base test.
Test Export Snapshot Tool
Mob file cleaner chore test.
Test creating/using/deleting snapshots from the client
Test clone/restore snapshots from the client TODO This is essentially a clone of
TestRestoreSnapshotFromClient.
Test the restore/clone operation from a file-system point of view.
Reruns TestMobExportSnapshot using MobExportSnapshot in secure mode.
Test to verify that the cloned table is independent of the table from which it was cloned
Test create/using/deleting snapshots from the client
Test mob store compaction
Test the MOB feature when enable RPC ByteBuffAllocator (HBASE-22122)
Test whether moved region cache is correct
Tests optimized scanning of multiple columns.
Test case for Compression.Algorithm.GZ and no use data block encoding.
Test case for Compression.Algorithm.GZ and use data block encoding.
Test case for Compression.Algorithm.NONE and no use data block encoding.
Test case for Compression.Algorithm.NONE and no use data block encoding.
Tests logging of large batch commands via Multi.
Test secure client connecting to a non secure server, where we have multiple server principal
candidates for a rpc service.
Tests for HBASE-28321, where we have multiple server principals candidates for a rpc service.
Run tests related to
TimestampsFilter
using HBase client
APIs.This test sets the multi size WAAAAAY low and then checks to make sure that gets will still make
progress.
Tests various scan start and stop row scenarios.
Tests of MultiTableInputFormatBase.
Connection to use above in Test.
Test Map/Reduce job over HBase tables.
Pass the given key and processed record reduce
This is a hammer test that verifies MultiVersionConcurrencyControl in a multiple writer single
reader scenario.
Very basic tests.
Port of old TestScanMultipleVersions, TestTimestamp and TestGetRowVersions from old testing
framework to
HBaseTestingUtility
.Comprehensively tests all permutations of certificate and host verification on the client side.
Comprehensively tests all permutations of ClientAuth modes and host verification
enabled/disabled.
Tests for Online SlowLog Provider Service
Test class for
NamespaceQuotaSnapshotStore
.Testcase for HBASE-23098
Test that verifies we do not have memstore size negative when a postPut/Delete hook is
slow/expensive and a flush is triggered at the same time the coprocessow is doing its work.
Confirm that we truly close the NettyRpcConnection when the netty channel is closed.
Test class for
NoInsertsViolationPolicyEnforcement
.Test class for
NoWritesCompactionsViolationPolicyEnforcement
;Test class for
NoWritesViolationPolicyEnforcement
.Test class for
HRegion.ObservedExceptionsInBatch
.Tests for OldWALsDirSizeChore Here we are using the
MockMasterServices
to mock the Hbase
Master.Testcase for HBASE-20242
Test that a coprocessor can open a connection and write to another table, inside a hook.
Coprocessor that creates an HTable with a pool to write to another table
Custom coprocessor that just copies the write to another table.
Run tests that use the functionality of the Operation superclass for Puts, Gets, Deletes, Scans,
and MultiPuts.
Used to confirm that it is OK to overwrite a file which is being written currently.
Tests for the page filter
Testing of multiPut in parallel.
A thread that makes a few put calls
This class tests ParseFilter.java It tests the entire work flow from when a string is given by
the user and how it is parsed to construct the corresponding Filter object
In this test, we write a small WAL file first, and then generate partial WAL file which length is
in range [0, fileLength)(we test all the possible length in the range), to see if we can
successfully get the completed entries, and also get an EOF at the end.
These tests are focused on testing how partial results appear to a client.
A very simple filter that records accessed uri's
Configuration for RecordingFilter
This file has been copied from the Apache ZooKeeper project.
This test verifies the correctness of the Per Column Family flushing strategy
This file has been copied from the Apache ZooKeeper project.
Implementation of the PluggableBlockingQueue abstract class.
Tests that verify certain RPCs get a higher QoS.
Test prometheus Sink.
Test for testing protocol buffer based RPC mechanism.
Test class for SPNEGO Proxyuser authentication on the HttpServer.
Test that I can Iterate Client Actions that hold Cells (Get does not have Cells).
Basic test that qos function is sort of working; i.e.
Test qualifierFilter with empty qualifier column
minicluster tests that validate that quota entries are properly set in the quota table
Non-HBase cluster unit tests for
QuotaObserverChore
.A test case to verify that region reports are expired when they are not sent.
Test class for
QuotaObserverChore
that uses a live HBase cluster.Test class for
QuotaSettingsFactory
.Test class for the quota status RPCs in the master and regionserver.
Test the quota table helpers (e.g.
Testcase for HBASE-21503.
Verify the behaviour of the Rate Limiter.
With filter we may stop at a middle of row and think that we still have more cells for the
current row but actually all the remaining cells will be filtered out by the filter.
Tests around replay of recovered.edits content.
HBASE-21031 If replay edits fails, we need to make sure memstore is rollbacked And if MSLAB is
used, all chunk is released too.
Test our recoverLease loop against mocked up filesystem.
Test reuse storefiles within data directory when cluster failover with a set of new region
servers with different hostnames with or without WALs and Zookeeper ZNodes, the master and
cluster should fail respectively if there is any situation considered as not supported.
Tests the ability to specify favored nodes for a region.
Increments with some concurrency against a region to ensure we get the right answer.
Test move fails when table disabled
Tests for Region Mover Load/Unload functionality with and without ack mode and also to test
exclude functionality useful for rack decommissioning
Tests for Region Mover Load/Unload functionality with and without ack mode and also to test
exclude functionality useful for rack decommissioning
Calls through to TestCoprocessor.
Calls through to TestCoprocessor.
Test that we fail if a Coprocessor tries to return a null scanner out
RegionObserver.preFlush(ObserverContext, Store, InternalScanner, FlushLifeCycleTracker)
or
RegionObserver.preCompact(ObserverContext, Store, InternalScanner, ScanType, CompactionLifeCycleTracker, CompactionRequest)
Coprocessor that returns null when preCompact or preFlush is called.
Do the default logic in
RegionObserver
interface.Don't allow any data to be written out in the compaction by creating a custom
StoreScanner
.Don't allow any data in a flush by creating a custom
StoreScanner
.Don't return any data from a scan by creating a custom
StoreScanner
.Test whether region re-balancing works.
Tests failover of secondary region replicas.
Tests for region replicas.
Tests around regionserver shutdown and abort
Throws an exception during store file refresh in order to trigger a regionserver abort.
Tests unhandled exceptions thrown by coprocessors running on a regionserver..
Tests unhandled exceptions thrown by coprocessors running on regionserver.
Testcase for HBASE-20742
Tests for the hostname specification by region server
Tests on the region server, without the master.
Verify that the Online config Changes on the HRegionServer side are actually happening.
Test class for isolated (non-cluster) tests surrounding the report of Region space use to the
Master by RegionServers.
This test HMaster class will always throw ServerNotRunningYetException if checked.
Test class for
RegionServerSpaceQuotaManager
.Test class which verifies that region sizes are reported to the master.
Testing the region snapshot task on a cluster.
Tests for
RegionSplitter
, which can create a pre-split table or do a rolling split of an
existing table.Test for RegionsRecoveryChore
Test for Regions Recovery Config Manager
Tests
RemoteAdmin
retries.Test RemoteHTable retries.
Testcase for HBASE-20296.
Tests for region replicas.
This copro is used to synchronize the tests.
Unit testing of ReplicationAdmin
Unit testing of ReplicationAdmin with clusters
This class is only a base for other integration-level replication tests.
Custom replication endpoint to keep track of replication status for tests.
Test handling of changes to the number of a peer's regionservers.
Tests ReplicationSource and ReplicationEndpoint interactions
Not used by unit tests, helpful for manual testing with replication.
Runs the TestReplicationKillRS test and selects the RS to kill in the master cluster Do not add
other tests in this class.
Run the same test as TestReplicationKillMasterRS but with WAL compression enabled Do not add
other tests in this class.
Runs the TestReplicationKillRS test and selects the RS to kill in the slave cluster Do not add
other tests in this class.
All the modification method will fail once in the test and should finally succeed.
White box testing for replication state interfaces.
Replication with dropped table will stuck as the default REPLICATION_DROP_ON_DELETED_TABLE_KEY is
false.
Replication with dropped table will stuck as the default REPLICATION_DROP_ON_DELETED_TABLE_KEY is
false.
This copro is used to slow down the primary meta region scan a bit
This copro is used to simulate region server down exception for Get and Scan
This copro is used to synchronize the tests.
Validate requestsPerSecond metric.
Simulate the scenario described in HBASE-26245, where we clean the WAL directory and try to start
the cluster.
Test clone/restore snapshots from the client TODO This is essentially a clone of
TestRestoreSnapshotFromClient.
Test the restore/clone operation from a file-system point of view.
Basic test for some old functionality we don't seem to have used but that looks nice.
Test cases against ReversibleKeyValueScanner
Tests the restarting of everything as done during rolling restarts.
Test requirement that root directory must be a URI
Basic test of
RoundRobinTableInputFormat
; i.e.Test the rowcounter map reduce job.
Test TestRowPrefixBloomFilter
Test case to check HRS throws
RowTooBigException
when row
size exceeds configured limits.A dummy RpcChannel implementation that intercepts the GetClusterId() RPC calls and injects
errors.
A silly test that does nothing but make sure an rpcscheduler factory makes what it says it is
going to make.
Tests to validate if HRegionServer default chores are scheduled
Performs authorization checks for rsgroup operations, according to different levels of authorized
users.
Tests that a regionserver that dies after reporting for duty gets removed from list of online
regions.
Mob file cleaner chore test.
Test parts of
RSRpcServices
Tests for the region server status page and its template.
Test of a long-lived scanner validating as we go.
Here we test to make sure that scans return the expected Results when the server is sending the
Client heartbeat messages.
Test the optimization that does not scan files where all key ranges are excluded.
Test the optimization that does not scan files where all timestamps are expired.
A client-side test, mostly testing scanners with various parameters.
Testcase for newly added feature in HBASE-17143, such as startRow and stopRow
inclusive/exclusive, limit for rows, etc.
Test various scanner timeout issues.
Tests a scanner on a corrupt hfile.
Test if Scan.setStartStopRowForPrefixScan works as intended.
Test a multi-column scanner when there is a Bloom filter false-positive.
Testcase to make sure that we do not close scanners if ScanRequest.numberOfRows is zero.
Tests for failedBulkLoad logic to make sure staged files are returned to their original location
if the bulkload have failed.
Reruns TestExportSnapshot using ExportSnapshot in secure mode.
Test class for SPNEGO authentication on the HttpServer.
Make sure that all rpc services for master and region server are properly configured in
SecurityInfo
and HBasePolicyProvider
.Test various seek optimizations for correctness and check if they are actually saving I/O
operations.
Test
HFileScanner.seekTo(Cell)
and its variants.Testcase for HBASE-20066
Test HBase Writables serializations
This class is for testing HBaseConnectionManager ServerBusyException.
Testcase for HBASE-20634
Test that sundry operations internal to the region server are traced as expected.
HBASE-19496 noticed that the RegionLoad/ServerLoad may be corrupted if rpc server reuses the
bytebuffer backed, so this test call the Admin#getLastMajorCompactionTimestamp() to invoke
HMaster to iterate all stored server/region loads.
Configuration for the filter
A very simple filter which record the uri filtered.
Configuration for the filter
org.apache.hbase.shaded.TestShadedHBaseTestingUtility
Test for the
ShellExecEndpointCoprocessor
.This test is there to dump the properties.
Test to confirm that we will not hang when stop a backup master which is trying to become the
active master.
See HBASE-19929 for more details.
Testcase to confirm that we will not hang when shutdown a cluster with no live region servers.
Test of simple partitioner.
Tests for
SingleColumnValueExcludeFilter
.Tests the value filter
Tests for SlowLog System Table
Test to verify that the cloned table is independent of the table from which it was cloned
Test that the
SnapshotProtos.SnapshotDescription
helper is helping correctly.This class tests that the use of a temporary snapshot directory supports snapshot functionality
while the temporary directory is on the same file system as the root directory
Test create/using/deleting snapshots from the client
Test class to verify that metadata is consistent before and after a snapshot attempt.
Test class for the
SnapshotQuotaObserverChore
.Validate if storefile length match both snapshop manifest and filesystem.
This class tests that the use of a temporary snapshot directory supports snapshot functionality
while the temporary directory is on a different file system than the root directory
Test Case for HBASE-21387
Test restore/clone snapshots with TTL from the client
Test class for
SpaceLimitSettings
.End-to-end test class for filesystem space quotas.
Test class to exercise the inclusion of snapshots in space quotas
Test class for
SpaceQuotaRefresherChore
.The below tests are testing split region against a running cluster
Testcase for https://issues.apache.org/jira/browse/HBASE-13811
Test class for SPNEGO authentication on the HttpServer.
This testcase issues SSL certificates configures the HttpServer to serve HTTPS using the created
certficates and calls an echo servlet using the corresponding HTTPS URL.
Test HStoreFile
This test tests whether parallel
StoreScanner.close()
and
StoreScanner.updateReaders(List, List)
works perfectly ensuring that there are no
references on the existing Storescanner readers.This class both tests and demonstrates how to construct compound rowkeys from a POJO.
Test class to verify that the HBase superuser can override quotas.
Basic test for the SyncTable M/R tool
Test setting values in the descriptor.
This tests the TableInputFormat and its recovery semantics
This tests the TableInputFormat and its recovery semantics
Tests various scan start and stop row scenarios.
Pass the key and value to reduce.
Checks the last and first key seen against the scanner boundaries.
Test Map/Reduce job over HBase tables.
Test Map/Reduce job over HBase tables.
A base class for a test Map/Reduce job over HBase tables.
Test different variants of initTableMapperJob method
Tests for various kinds of TableNames.
Spark creates many instances of TableOutputFormat within a single process.
Test class for
TableQuotaSnapshotStore
.Test that correct rpc priority is sent to server from blocking Table calls.
The Class ClientSideCellSetModel which mimics cell set model, and contains listener to perform
user defined operations on the row model.
This listener is invoked every time a new row model is unmarshalled.
Test case for
TableSpaceQuotaSnapshotNotifier
.Tests the default table lock manager
Non-HBase cluster unit tests for
QuotaObserverChore.TablesWithQuotas
.Class that test tags
Start the HBase Thrift HTTP server on a random port through the command-line interface and talk
to it from client side.
Unit testing for ThriftServerRunner.HBaseServiceHandler, a part of the
org.apache.hadoop.hbase.thrift package.
Start the HBase Thrift server on a random port through the command-line interface and talk to it
from client side.
Start the HBase Thrift HTTP server on a random port through the command-line interface and talk
to it from client side with SPNEGO security enabled.
Start the HBase Thrift HTTP server on a random port through the command-line interface and talk
to it from client side with SPNEGO security enabled.
Test the
TimeoutExceptionInjector
to ensure we fulfill contractsRun tests related to
TimestampsFilter
using HBase client APIs.Tests the concurrent TinyLfuBlockCache.
A simple UT to make sure that we do not leak the SslExceptions to netty's TailContext, where it
will generate a confusing WARN message.
Confirm that the empty replication endpoint can work.
We moved some of
TestVerifyReplication
's tests here because it could take too long to
complete.Test that the actions are called while playing with an WAL
Just counts when methods are called
This test verifies the correctness of the Per Column Family flushing strategy when part of the
memstores are compacted memstores
Ensure configuration changes are having an effect on WAL.
WAL tests that can be reused across providers.
Testing for lock up of FSHLog.
Simple testing of a few WAL methods.
Test for HBASE-17471.
Tests invocation of the
MasterObserver
interface
hooks at all appropriate times during normal HMaster operations.Test WAL Init ERROR
Basic test for the WALPlayer M/R tool
JUnit tests for the WALRecordReader
Enables compression and runs the TestWALReplay tests.
Enables compression and runs the TestWALReplay tests.
Testing
WAL
splitting code.Run tests that use the HBase clients;
TableBuilder
.Testcase for HBASE-21843.
This file has been copied from the Apache ZooKeeper project.
Test class for
RemoteAdmin
to verify XML is parsed in a certain manner.Test ZooKeeper multi-update functionality.
JUnit run listener which prints full thread dump into System.err in case a test is failed due to
timeout.
Tests user specifiable time stamps putting, getting and scanning.
A drop-in replacement for
BufferingScanResultConsumer
that adds tracing spans to its
implementation of the AdvancedScanResultConsumer
API.org.apache.hadoop.hbase.client.trace.hamcrest.TraceTestUtil
org.apache.hadoop.hbase.chaos.actions.TruncateTableAction
Action that tries to truncate of a table.
Dummy mapper used for unit tests to verify that the mapper can be injected.
Just shows a simple example of how the attributes can be extracted and added to the puts
org.apache.hadoop.hbase.chaos.policies.TwoConcurrentActionPolicy
Chaos Monkey policy that will run two different actions at the same time.
org.apache.hadoop.hbase.chaos.actions.UnbalanceKillAndRebalanceAction
This action is too specific to put in ChaosMonkey; put it here
org.apache.hadoop.hbase.chaos.factories.UnbalanceMonkeyFactory
org.apache.hadoop.hbase.chaos.actions.UnbalanceRegionsAction
Action that tries to unbalance the regions of a cluster.
org.apache.hadoop.hbase.util.bulkdatagenerator.Utility
org.apache.hadoop.hbase.util.bulkdatagenerator.Utility.TableColumnNames
Schema for HBase table to be generated by generated and populated by
BulkDataGeneratorTool
org.apache.hadoop.hbase.testclassification.VerySlowMapReduceTests
Tag a test as related to mapreduce and taking longer than 5 minutes to run on public build
infrastructure.
org.apache.hadoop.hbase.testclassification.VerySlowRegionServerTests
Tag a test as region tests which takes longer than 5 minutes to run on public build
infrastructure.
A class that provides a standard waitFor pattern See details at
https://issues.apache.org/jira/browse/HBASE-7384
A mixin interface, can be used with
Waiter
to explain failed state.A predicate 'closure' used by the
Waiter.waitFor(Configuration, long, Predicate)
and
Waiter.waitFor(Configuration, long, Predicate)
and
Waiter.waitFor(Configuration, long, long, boolean, Predicate)
methods.Testcase for HBASE-22539
Tests for WAL write durability - hflush vs hsync
This class runs performance benchmarks for
WAL
.org.apache.hadoop.hbase.test.util.warc.WARCFileReader
Reads
WARCRecord
s from a WARC file, using Hadoop's filesystem APIs.org.apache.hadoop.hbase.test.util.warc.WARCFileWriter
Writes
WARCRecord
s to a WARC file, using Hadoop's filesystem APIs.org.apache.hadoop.hbase.test.util.warc.WARCInputFormat
Hadoop InputFormat for mapreduce jobs ('new' API) that want to process data in WARC files.
org.apache.hadoop.hbase.test.util.warc.WARCOutputFormat
Hadoop OutputFormat for mapreduce jobs ('new' API) that want to write data to WARC files.
org.apache.hadoop.hbase.test.util.warc.WARCRecord
Immutable implementation of a record in a WARC file.
org.apache.hadoop.hbase.test.util.warc.WARCRecord.Header
Contains the parsed headers of a
WARCRecord
.org.apache.hadoop.hbase.test.util.warc.WARCWritable
A mutable wrapper around a
WARCRecord
implementing the Hadoop Writable interface.Represents a type of key pair used for X509 certs in tests.
This class simplifies the creation of certificates and private keys for SSL/TLS connections.
Builder class, used for creating new instances of X509TestContext.
Will cache X509TestContext to speed up tests.
org.apache.hadoop.hbase.testclassification.ZKTests
For tests which test the general logic of zookeeper related tools, such as
RecoverableZooKeeper
, not for tests which depend on ZooKeeper.