public class TestFromClientSide5 extends FromClientSideBase
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.Modifier and Type | Field and Description |
---|---|
static HBaseClassTestRule |
CLASS_RULE |
private static org.slf4j.Logger |
LOG |
TableNameTestRule |
name |
FAMILY, INVALID_FAMILY, QUALIFIER, ROW, SLAVES, TEST_UTIL, VALUE
Constructor and Description |
---|
TestFromClientSide5() |
TestFromClientSide5(Class registry,
int numHedgedReqs) |
afterClass, 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
private static final org.slf4j.Logger LOG
public static final HBaseClassTestRule CLASS_RULE
public TableNameTestRule name
TestFromClientSide5()
public TestFromClientSide5(Class registry, int numHedgedReqs) throws Exception
Exception
public static Collection parameters()
public static void tearDownAfterClass() throws Exception
Exception
public void testGetClosestRowBefore() throws IOException, InterruptedException
IOException
InterruptedException
private org.apache.hadoop.hbase.client.Result getReverseScanResult(org.apache.hadoop.hbase.client.Table table, byte[] row) throws IOException
IOException
public void testScanVariableReuse()
public void testMultiRowMutation() throws Exception
Exception
public void testMultiRowMutationWithSingleConditionWhenConditionMatches() throws Exception
Exception
public void testMultiRowMutationWithSingleConditionWhenConditionNotMatch() throws Exception
Exception
public void testMultiRowMutationWithMultipleConditionsWhenConditionsMatch() throws Exception
Exception
public void testMultiRowMutationWithMultipleConditionsWhenConditionsNotMatch() throws Exception
Exception
public void testMultiRowMutationWithFilterConditionWhenConditionMatches() throws Exception
Exception
public void testMultiRowMutationWithFilterConditionWhenConditionNotMatch() throws Exception
Exception
public void testRowMutations() throws Exception
Exception
public void testBatchAppendWithReturnResultFalse() throws Exception
Exception
public void testAppend() throws Exception
Exception
private List<org.apache.hadoop.hbase.client.Result> doAppend(boolean walUsed) throws IOException
IOException
public void testAppendWithoutWAL() throws Exception
Exception
public void testClientPoolRoundRobin() throws IOException
IOException
public void testClientPoolThreadLocal() throws IOException
IOException
public void testCheckAndPut() throws IOException
IOException
public void testCheckAndMutateWithTimeRange() throws IOException
IOException
public void testCheckAndPutWithCompareOp() throws IOException
IOException
public void testCheckAndDelete() throws IOException
IOException
public void testCheckAndDeleteWithCompareOp() throws IOException
IOException
public void testScanMetrics() throws Exception
Exception
public void testCacheOnWriteEvictOnClose() throws Exception
Exception
private void waitForStoreFileCount(org.apache.hadoop.hbase.regionserver.HStore store, int count, int timeout) throws InterruptedException
InterruptedException
public void testNonCachedGetRegionLocation() throws Exception
Exception
public void testGetRegionsInRange() throws Exception
Exception
private List<org.apache.hadoop.hbase.HRegionLocation> getRegionsInRange(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey) throws IOException
IOException
public void testJira6912() throws Exception
Exception
public void testScan_NullQualifier() throws IOException
IOException
public void testNegativeTimestamp() throws IOException
IOException
public void testRawScanRespectsVersions() throws Exception
Exception
public void testEmptyFilterList() throws Exception
Exception
public void testSmallScan() throws Exception
Exception
public void testSuperSimpleWithReverseScan() throws Exception
Exception
public void testFiltersWithReverseScan() throws Exception
Exception
public void testKeyOnlyFilterWithReverseScan() throws Exception
Exception
public void testSimpleMissingWithReverseScan() throws Exception
Exception
public void testNullWithReverseScan() throws Exception
Exception
public void testDeletesWithReverseScan() throws Exception
Exception
public void testReversedScanUnderMultiRegions() throws Exception
Exception
public void testSmallReversedScanUnderMultiRegions() throws Exception
Exception
private void reverseScanTest(org.apache.hadoop.hbase.client.Table table, boolean small) throws IOException
IOException
public void testFilterAllRecords() throws IOException
IOException
public void testCellSizeLimit() throws IOException
IOException
public void testCellSizeNoLimit() throws IOException
IOException
public void testDeleteSpecifiedVersionOfSpecifiedColumn() throws Exception
Exception
public void testDeleteLatestVersionOfSpecifiedColumn() throws Exception
Exception
public void testReadWithFilter() throws Exception
Exception
public void testCellUtilTypeMethods() throws IOException
IOException
public void testCreateTableWithZeroRegionReplicas() throws Exception
Exception
public void testModifyTableWithZeroRegionReplicas() throws Exception
Exception
public void testModifyTableWithMemstoreData() throws Exception
Exception
public void testDeleteCFWithMemstoreData() throws Exception
Exception
private void createTableAndValidateTableSchemaModification(org.apache.hadoop.hbase.TableName tableName, boolean modifyTable) throws Exception
tableName
- Table namemodifyTable
- Modify table if true otherwise delete column familyIOException
- in case of failuresException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.