public class TestHRegionWithInMemoryFlush extends TestHRegion
TestHRegion.FlushThread, TestHRegion.GetTillDoneOrException, TestHRegion.HRegionForTesting, TestHRegion.HRegionWithSeqId, TestHRegion.HStoreForTesting, TestHRegion.IsFlushWALMarker, TestHRegion.NoOpRegionCoprocessor, TestHRegion.PutThread
Modifier and Type | Field and Description |
---|---|
static HBaseClassTestRule |
CLASS_RULE |
private static org.slf4j.Logger |
LOG |
Constructor and Description |
---|
TestHRegionWithInMemoryFlush() |
Modifier and Type | Method and Description |
---|---|
(package private) int |
getNumQualifiersForTestWritesWhileScanning()
testWritesWhileScanning is flakey when called out of this class.
|
(package private) int |
getTestCountForTestWritesWhileScanning()
So can be overridden in subclasses.
|
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 |
testFlushAndMemstoreSizeCounting()
A test case of HBASE-21041
|
assertGet, assertScan, createWALFactory, doTestDelete_AndPostInsert, initHRegion, initHRegion, initHRegion, 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, 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_WriteRequestCount, testMutateRow, 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, testWeirdCacheBehaviour, testWriteRequestsCounter, testWritesWhileGetting, testWritesWhileRollWriter, testWritesWhileScanning, verifyData
public static final HBaseClassTestRule CLASS_RULE
private static final org.slf4j.Logger LOG
public TestHRegionWithInMemoryFlush()
public 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
initHRegion
in class TestHRegion
HBaseTestingUtility.closeRegionAndWAL(HRegion)
when done.IOException
int getTestCountForTestWritesWhileScanning()
TestHRegion
getTestCountForTestWritesWhileScanning
in class TestHRegion
int getNumQualifiersForTestWritesWhileScanning()
getNumQualifiersForTestWritesWhileScanning
in class TestHRegion
public void testFlushAndMemstoreSizeCounting() throws Exception
testFlushAndMemstoreSizeCounting
in class TestHRegion
Exception
- ExceptionCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.