Class TestHRegionWithInMemoryFlush
java.lang.Object
org.apache.hadoop.hbase.regionserver.TestHRegion
org.apache.hadoop.hbase.regionserver.TestHRegionWithInMemoryFlush
A test similar to TestHRegion, but with in-memory flush families. Also checks wal truncation
after in-memory compaction.
-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.hadoop.hbase.regionserver.TestHRegion
TestHRegion.FlushThread, TestHRegion.GetTillDoneOrException, TestHRegion.HRegionForTesting, TestHRegion.HRegionWithSeqId, TestHRegion.HStoreForTesting, TestHRegion.IsFlushWALMarker, TestHRegion.NoOpRegionCoprocessor, TestHRegion.PutThread
-
Field Summary
Modifier and TypeFieldDescriptionstatic final HBaseClassTestRule
private static final org.slf4j.Logger
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionprotected int
testWritesWhileScanning is flakey when called out of this class.protected int
So can be overridden in subclasses.protected org.apache.hadoop.hbase.regionserver.HRegion
initHRegion
(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] stopKey, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, org.apache.hadoop.hbase.client.Durability durability, org.apache.hadoop.hbase.wal.WAL wal, byte[]... families) void
A test case of HBASE-21041Methods inherited from class org.apache.hadoop.hbase.regionserver.TestHRegion
assertGet, assertScan, createWALFactory, doTestDelete_AndPostInsert, initHRegion, initSplit, putData, setup, tearDown, testaddFamily_PostInsert, testAllColumnsWithBloomFilter, testAppendTimestampsAreMonotonic, testAppendWithReadOnlyTable, testArchiveRecoveredEditsReplay, testAtomicBatchPut, testBatchMutateWithWrongRegionException, testBatchMutateWithZeroRowLockWait, testBatchPut_whileMultipleRowLocksHeld, testBatchPut_whileNoRowLocksHeld, testBatchPutWithTsSlop, testBloomFilterSize, testBulkLoadReplicationEnabled, testCellTTLs, testCheckAndAppend, testCheckAndDelete_ThatDeleteWasWritten, testCheckAndDeleteThatDeleteWasWritten, testCheckAndIncrement, testCheckAndIncrementAndAppend, testCheckAndMutate_WithCorrectValue, testCheckAndMutate_WithEmptyRowValue, testCheckAndMutate_WithFilters, testCheckAndMutate_WithFiltersAndTimeRange, testCheckAndMutate_WithNonEqualCompareOp, testCheckAndMutate_WithWrongValue, testCheckAndMutate_wrongMutationType, testCheckAndMutate_wrongRow, testCheckAndMutateTimestampsAreMonotonic, testCheckAndMutateWithCorrectValue, testCheckAndMutateWithEmptyRowValue, testCheckAndMutateWithFilters, testCheckAndMutateWithFiltersAndTimeRange, testCheckAndMutateWithNonEqualCompareOp, testCheckAndMutateWithWrongValue, testCheckAndPut_ThatPutWasWritten, testCheckAndPut_wrongRowInPut, testCheckAndPutThatPutWasWritten, testCheckAndRowMutateTimestampsAreMonotonic, testCheckAndRowMutations, testCloseAbort, testCloseAndArchiveCompactedFiles, testCloseCarryingSnapshot, testCloseInterrupt, testCloseNoInterrupt, testCloseRegionWrittenToWAL, testCloseWithFailingFlush, testCompactionAffectedByScanners, testCompactionFromPrimary, testDataInMemoryWithoutWAL, testDelete_CheckFamily, testDelete_CheckTimestampUpdated, testDelete_mixed, testDelete_multiDeleteColumn, testDeleteColumns_PostInsert, testDeleteRowWithBloomFilter, testDeleteRowWithFutureTs, testDurability, testFamilyWithAndWithoutColon, testFlushCacheWhileScanning, testFlushedFileWithNoTags, testFlushMarkers, testFlushMarkersWALFail, testFlushResult, testFlushSizeAccounting, testGet_Basic, testGet_Empty, testGet_FamilyChecker, testgetHDFSBlocksDistribution, testGetScanner_WithNoFamilies, testGetScanner_WithNotOkFamilies, testGetScanner_WithOkFamilies, testGetScanner_WithRegionClosed, testGetWhileRegionClose, testGetWithFilter, testHolesInMeta, testIncrementTimestampsAreMonotonic, testIncrWithReadOnlyTable, testIndexesScanWithOneDeletedRow, testInterruptProtection, testLongQualifier, testMemstoreSizeAccountingWithFailedPostBatchMutate, testMemstoreSnapshotSize, testMutateRow, testMutateRow_WriteRequestCount, testMutateRowInParallel, testOpenRegionWrittenToWAL, testParallelAppendWithMemStoreFlush, testParallelIncrementWithMemStoreFlush, testPutWithLatestTS, testPutWithMemStoreFlush, testPutWithTsSlop, testRecoveredEditsReplayCompaction, testRecoveredEditsReplayCompaction, testRegionInfoFileCreation, testRegionOnCoprocessorsChange, testRegionOnCoprocessorsWithoutChange, testRegionReplicaSecondary, testRegionReplicaSecondaryIsReadOnly, testRegionScanner_Next, testRegionTooBusy, testReverseScanner_FromMemStore_SingleCF_FullScan, testReverseScanner_FromMemStore_SingleCF_LargerKey, testReverseScanner_FromMemStore_SingleCF_Normal, testReverseScanner_FromMemStoreAndHFiles_MultiCFs1, testReverseScanner_FromMemStoreAndHFiles_MultiCFs2, testReverseScanner_moreRowsMayExistAfter, testReverseScanner_smaller_blocksize, testReverseScanner_StackOverflow, testReverseScanShouldNotScanMemstoreIfReadPtLesser, testReverseScanWhenPutCellsAfterOpenReverseScan, testScanner_DeleteOneFamilyNotAnother, testScanner_ExplicitColumns_FromFilesOnly_EnforceVersions, testScanner_ExplicitColumns_FromMemStore_EnforceVersions, testScanner_ExplicitColumns_FromMemStoreAndFiles_EnforceVersions, testScanner_JoinedScanners, testScanner_JoinedScannersWithLimits, testScanner_StopRow1542, testScanner_Wildcard_FromFilesOnly_EnforceVersions, testScanner_Wildcard_FromMemStore_EnforceVersions, testScanner_Wildcard_FromMemStoreAndFiles_EnforceVersions, testScannerOperationId, testSequenceId, testSkipRecoveredEditsReplay, testSkipRecoveredEditsReplayAllIgnored, testSkipRecoveredEditsReplaySomeIgnored, testSkipRecoveredEditsReplayTheLastFileIgnored, testStatusSettingToAbortIfAnyExceptionDuringRegionInitilization, testToShowNPEOnRegionScannerReseek, testTTLsUsingSmallHeartBeatCells, testWeirdCacheBehaviour, testWriteRequestsCounter, testWritesWhileGetting, testWritesWhileRollWriter, testWritesWhileScanning, verifyData
-
Field Details
-
CLASS_RULE
-
LOG
-
-
Constructor Details
-
TestHRegionWithInMemoryFlush
public TestHRegionWithInMemoryFlush()
-
-
Method Details
-
initHRegion
protected org.apache.hadoop.hbase.regionserver.HRegion initHRegion(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] stopKey, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, org.apache.hadoop.hbase.client.Durability durability, org.apache.hadoop.hbase.wal.WAL wal, byte[]... families) throws IOException - Overrides:
initHRegion
in classTestHRegion
- Returns:
- A region on which you must call
HBaseTestingUtility.closeRegionAndWAL(HRegion)
when done. - Throws:
IOException
-
getTestCountForTestWritesWhileScanning
Description copied from class:TestHRegion
So can be overridden in subclasses.- Overrides:
getTestCountForTestWritesWhileScanning
in classTestHRegion
-
getNumQualifiersForTestWritesWhileScanning
testWritesWhileScanning is flakey when called out of this class. Need to dig in. Meantime go easy on it. See if that helps.- Overrides:
getNumQualifiersForTestWritesWhileScanning
in classTestHRegion
-
testFlushAndMemstoreSizeCounting
A test case of HBASE-21041- Overrides:
testFlushAndMemstoreSizeCounting
in classTestHRegion
- Throws:
Exception
-