Package org.apache.hadoop.hbase.regionserver
package org.apache.hadoop.hbase.regionserver
-
ClassDescriptionCreates an HFile with random key/value pairs.Tests various algorithms for key compression on an existing HFile.Test seek performance for encoded data blocks.A fixture that implements and presents a KeyValueScanner.A mock used so our tests don't deal with actual StoreFilesRegionObserver 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
andTestCompactionWithCoprocessor
to make sure that a wide range of functionality still behaves as expected.A region server that will OOME.An implementation ofTable
that sits directly on a Region; it decorates the passed in Region instance with the Table API.This class is a helper that allows to create a partially-implemented, stateful mocks of Store.Testing of HRegion.incrementColumnValue, HRegion.increment, and HRegion.appendA thread that makes increment calls always on the same row, this.row against two column families on this row.A UT to make sure that everything is fine when we fail to load bloom filter.This class attempts to unit test bulk HLog loading.Integration test for bulk load replication.TestsHFile
cache-on-write functionality for data blocks, non-root index blocks, and Bloom filter blocks, as specified by the column family.Test metrics incremented on region server operations.compacted memstore test casecompacted memstore test caseTest compaction framework and common functionsSimpleCompactionLifeCycleTracker
on which you can wait until the requested compaction finishes.SimpleCompactionLifeCycleTracker
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 stateMake sure compaction tests still pass with the preFlush and preCompact overridden to implement the default behaviorTests writing Bloom filter blocks in the same part of the file as data blocks.Test DataBlockEncodingTool.memstore test caseTesting sync/append failures.Confirm that the function of FlushLifeCycleTracker is OK as we do not use it in our own code.Test cases that ensure that file system level errors are bubbled up appropriately to clients, rather than swallowed.TestGet is a medley of tests of get all done up as a single test.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 anHRegion
.Tests of HRegion methods for replaying flush, compaction, region open, etc events for secondary region replicasTests 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.A test similar to TestHRegion, but with in-memory flush families.Test class for the HStoreTest HStoreFileTest failure in ScanDeleteTracker.isDeleted when ROWCOL bloom filter is used during a scan with a filter.Test performance improvement of joined scanners optimization: https://issues.apache.org/jira/browse/HBASE-5416Test major compactionsTest theChunkCreator.MemStoreChunkPool
classTest theMemStoreCompactorSegmentsIterator
andMemStoreMergerSegmentsIterator
class, Test for bug : HBASE-22324Unit test version of rs metrics tests.Unit test version of rs metrics tests.Test for the CompatibilitySingletonFactory and building MetricsRegionServerSourceTest for MetricsTableSourceImplTest minor compactionsTest Minimum Versions feature (HBASE-4071).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.This is a hammer test that verifies MultiVersionConcurrencyControl in a multiple writer single reader scenario.Very basic tests.Test class forHRegion.ObservedExceptionsInBatch
.Testcase for HBASE-20242Testing of multiPut in parallel.A thread that makes a few put callsThis test verifies the correctness of the Per Column Family flushing strategyTests that verify certain RPCs get a higher QoS.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.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 disabledTests failover of secondary region replicas.Test region replication when error occur.Tests for region replicas.Tests around regionserver shutdown and abortThrows an exception during store file refresh in order to trigger a regionserver abort.Testcase for HBASE-20742Tests for the hostname specification by region serverTests 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.Validate requestsPerSecond metric.Test cases against ReversibleKeyValueScannerTest TestRowPrefixBloomFilterTest case to check HRS throwsRowTooBigException
when row size exceeds configured limits.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 scheduledTests that a regionserver that dies after reporting for duty gets removed from list of online regions.Basic test that qos function is sort of working; i.e.Test parts ofRSRpcServices
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.Tests a scanner on a corrupt hfile.Test a multi-column scanner when there is a Bloom filter false-positive.Tests for failedBulkLoad logic to make sure staged files are returned to their original location if the bulkload have failed.Test various seek optimizations for correctness and check if they are actually saving I/O operations.See HBASE-19929 for more details.The below tests are testing split region against a running clusterTestcase for https://issues.apache.org/jira/browse/HBASE-13811Test HStoreFileStore file writer does not do any compaction.This test tests whether parallelStoreScanner.close()
andStoreScanner.updateReaders(List, List)
works perfectly ensuring that there are no references on the existing Storescanner readers.Class that test tagsThis test verifies the correctness of the Per Column Family flushing strategy when part of the memstores are compacted memstoresTest for HBASE-17471.