Package org.apache.hadoop.hbase.client
Class TestFromClientSide5
java.lang.Object
org.apache.hadoop.hbase.client.FromClientSideBase
org.apache.hadoop.hbase.client.TestFromClientSide5
- Direct Known Subclasses:
- TestFromClientSideWithCoprocessor5
Run tests that use the HBase clients; 
Table. Sets up the HBase mini cluster once at start
 and runs through all client tests. Each creates a table named for the method and does its stuff
 against that. Parameterized to run with different registry implementations.- 
Field SummaryFieldsModifier and TypeFieldDescriptionstatic final HBaseClassTestRuleprivate static final org.slf4j.LoggerFields inherited from class org.apache.hadoop.hbase.client.FromClientSideBaseFAMILY, INVALID_FAMILY, QUALIFIER, ROW, SLAVES, TEST_UTIL, VALUE
- 
Constructor SummaryConstructorsConstructorDescriptionTestFromClientSide5(Class<? extends org.apache.hadoop.hbase.client.ConnectionRegistry> registry, int numHedgedReqs) 
- 
Method SummaryModifier and TypeMethodDescriptionprivate voidcreateTableAndValidateTableSchemaModification(org.apache.hadoop.hbase.TableName tableName, boolean modifyTable) Create table and validate online schema modificationprivate List<org.apache.hadoop.hbase.client.Result>doAppend(boolean walUsed) private List<org.apache.hadoop.hbase.HRegionLocation>getRegionsInRange(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey) private org.apache.hadoop.hbase.client.ResultgetReverseScanResult(org.apache.hadoop.hbase.client.Table table, byte[] row) private voidreverseScanTest(org.apache.hadoop.hbase.client.Table table, org.apache.hadoop.hbase.client.Scan.ReadType readType) static voidvoidvoidvoidvoidTests that cache on write works all the way up from the client-side.voidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidTests getRegionsInRange by creating some regions over which a range of keys spans; then changing the key range.voidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidvoidTests the non cached version of getRegionLocator by moving a region.voidvoidvoidTest for HBASE-17125voidTests reversed scan under multi regionsvoidvoidvoidTest ScanMetricsvoidFor HBASE-2156voidTest simple table and non-existent row cases.voidTests reversed scan under multi regionsvoidvoidprivate voidwaitForStoreFileCount(org.apache.hadoop.hbase.regionserver.HStore store, int count, int timeout) Methods inherited from class org.apache.hadoop.hbase.client.FromClientSideBaseafterClass, assertDoubleResult, assertEmptyResult, assertIncrementKey, assertKey, assertNResult, assertNResult, assertNullResult, assertNumKeys, assertRowCount, assertSingleResult, assertSingleResult, assertSingleResult, buildScanner, createScanWithRowFilter, createScanWithRowFilter, deleteColumns, equals, getAllVersionsAndVerify, getNumberOfRows, getSingleScanResult, getTestNull, getTestNull, getVerifySingleColumn, getVerifySingleEmpty, getVersionAndVerify, getVersionAndVerifyMissing, getVersionRangeAndVerify, getVersionRangeAndVerifyGreaterThan, initialize, isSameParameterizedCluster, makeN, makeNAscii, makeNBig, makeStamps, putRows, scanAllVersionsAndVerify, scanTestNull, scanTestNull, scanVerifySingleColumn, scanVerifySingleEmpty, scanVersionAndVerify, scanVersionAndVerifyMissing, scanVersionRangeAndVerify, scanVersionRangeAndVerifyGreaterThan, singleRowGetTest, singleRowScanTest, splitTable
- 
Field Details- 
LOG
- 
CLASS_RULE
- 
name
 
- 
- 
Constructor Details- 
TestFromClientSide5
- 
TestFromClientSide5public TestFromClientSide5(Class<? extends org.apache.hadoop.hbase.client.ConnectionRegistry> registry, int numHedgedReqs) throws Exception - Throws:
- Exception
 
 
- 
- 
Method Details- 
parameters
- 
tearDownAfterClass- Throws:
- Exception
 
- 
testGetClosestRowBefore- Throws:
- IOException
- InterruptedException
 
- 
getReverseScanResultprivate org.apache.hadoop.hbase.client.Result getReverseScanResult(org.apache.hadoop.hbase.client.Table table, byte[] row) throws IOException - Throws:
- IOException
 
- 
testScanVariableReuseFor HBASE-2156
- 
testMultiRowMutation- Throws:
- Exception
 
- 
testMultiRowMutationWithSingleConditionWhenConditionMatches- Throws:
- Exception
 
- 
testMultiRowMutationWithSingleConditionWhenConditionNotMatch- Throws:
- Exception
 
- 
testMultiRowMutationWithMultipleConditionsWhenConditionsMatch- Throws:
- Exception
 
- 
testMultiRowMutationWithMultipleConditionsWhenConditionsNotMatch- Throws:
- Exception
 
- 
testMultiRowMutationWithFilterConditionWhenConditionMatches- Throws:
- Exception
 
- 
testMultiRowMutationWithFilterConditionWhenConditionNotMatch- Throws:
- Exception
 
- 
testRowMutations- Throws:
- Exception
 
- 
testBatchAppendWithReturnResultFalse- Throws:
- Exception
 
- 
testAppend- Throws:
- Exception
 
- 
doAppend- Throws:
- IOException
 
- 
testAppendWithoutWAL- Throws:
- Exception
 
- 
testClientPoolRoundRobin- Throws:
- IOException
 
- 
testClientPoolThreadLocal- Throws:
- IOException
 
- 
testCheckAndPut- Throws:
- IOException
 
- 
testCheckAndMutateWithTimeRange- Throws:
- IOException
 
- 
testCheckAndPutWithCompareOp- Throws:
- IOException
 
- 
testCheckAndDelete- Throws:
- IOException
 
- 
testCheckAndDeleteWithCompareOp- Throws:
- IOException
 
- 
testScanMetricsTest ScanMetrics- Throws:
- Exception
 
- 
testCacheOnWriteEvictOnCloseTests that cache on write works all the way up from the client-side. Performs inserts, flushes, and compactions, verifying changes in the block cache along the way.- Throws:
- Exception
 
- 
waitForStoreFileCountprivate void waitForStoreFileCount(org.apache.hadoop.hbase.regionserver.HStore store, int count, int timeout) throws InterruptedException - Throws:
- InterruptedException
 
- 
testNonCachedGetRegionLocationTests the non cached version of getRegionLocator by moving a region.- Throws:
- Exception
 
- 
testGetRegionsInRangeTests getRegionsInRange by creating some regions over which a range of keys spans; then changing the key range.- Throws:
- Exception
 
- 
getRegionsInRangeprivate List<org.apache.hadoop.hbase.HRegionLocation> getRegionsInRange(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey) throws IOException - Throws:
- IOException
 
- 
testJira6912- Throws:
- Exception
 
- 
testScan_NullQualifier- Throws:
- IOException
 
- 
testNegativeTimestamp- Throws:
- IOException
 
- 
testRawScanRespectsVersions- Throws:
- Exception
 
- 
testEmptyFilterList- Throws:
- Exception
 
- 
testSmallScan- Throws:
- Exception
 
- 
testSuperSimpleWithReverseScan- Throws:
- Exception
 
- 
testFiltersWithReverseScan- Throws:
- Exception
 
- 
testKeyOnlyFilterWithReverseScan- Throws:
- Exception
 
- 
testSimpleMissingWithReverseScanTest simple table and non-existent row cases.- Throws:
- Exception
 
- 
testNullWithReverseScan- Throws:
- Exception
 
- 
testDeletesWithReverseScan- Throws:
- Exception
 
- 
testReversedScanUnderMultiRegionsTests reversed scan under multi regions- Throws:
- Exception
 
- 
testSmallReversedScanUnderMultiRegionsTests reversed scan under multi regions- Throws:
- Exception
 
- 
reverseScanTestprivate void reverseScanTest(org.apache.hadoop.hbase.client.Table table, org.apache.hadoop.hbase.client.Scan.ReadType readType) throws IOException - Throws:
- IOException
 
- 
testFilterAllRecords- Throws:
- IOException
 
- 
testCellSizeLimit- Throws:
- IOException
 
- 
testCellSizeNoLimit- Throws:
- IOException
 
- 
testDeleteSpecifiedVersionOfSpecifiedColumn- Throws:
- Exception
 
- 
testDeleteLatestVersionOfSpecifiedColumn- Throws:
- Exception
 
- 
testReadWithFilterTest for HBASE-17125- Throws:
- Exception
 
- 
testCellUtilTypeMethods- Throws:
- IOException
 
- 
testCreateTableWithZeroRegionReplicas- Throws:
- Exception
 
- 
testModifyTableWithZeroRegionReplicas- Throws:
- Exception
 
- 
testModifyTableWithMemstoreData- Throws:
- Exception
 
- 
testDeleteCFWithMemstoreData- Throws:
- Exception
 
- 
createTableAndValidateTableSchemaModificationprivate void createTableAndValidateTableSchemaModification(org.apache.hadoop.hbase.TableName tableName, boolean modifyTable) throws Exception Create table and validate online schema modification- Parameters:
- tableName- Table name
- modifyTable- Modify table if true otherwise delete column family
- Throws:
- IOException- in case of failures
- Exception
 
 
-