Uses of Class
org.apache.hadoop.hbase.HBaseTestingUtility
Package
Description
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase
Modifier and TypeClassDescriptionclass
Facility for integration/system tests.Modifier and TypeFieldDescriptionprotected final HBaseTestingUtility
HBaseTestCase.testUtil
Deprecated.Modifier and TypeMethodDescriptionstatic HBaseTestingUtility
HBaseTestingUtility.createLocalHTU()
Deprecated.since 2.0.0 and will be removed in 3.0.0.static HBaseTestingUtility
HBaseTestingUtility.createLocalHTU
(org.apache.hadoop.conf.Configuration c) Deprecated.since 2.0.0 and will be removed in 3.0.0.MiniClusterRule.getTestingUtility()
Returns the underlying instance ofHBaseTestingUtility
Modifier and TypeMethodDescriptionstatic void
ProcedureTestUtil.waitUntilProcedureTimeoutIncrease
(HBaseTestingUtility util, Class<? extends org.apache.hadoop.hbase.procedure2.Procedure<?>> clazz, int times) static void
ProcedureTestUtil.waitUntilProcedureWaitingTimeout
(HBaseTestingUtility util, Class<? extends org.apache.hadoop.hbase.procedure2.Procedure<?>> clazz, long timeout) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.backup
Modifier and TypeFieldDescriptionprotected static HBaseTestingUtility
TestBackupBase.TEST_UTIL
protected static HBaseTestingUtility
TestBackupUtils.TEST_UTIL
protected static HBaseTestingUtility
TestBackupBase.TEST_UTIL2
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
AbstractTestAsyncTableRegionReplicasRead.TEST_UTIL
protected static final HBaseTestingUtility
AbstractTestCITimeout.TEST_UTIL
protected static final HBaseTestingUtility
AbstractTestScanCursor.TEST_UTIL
protected static final HBaseTestingUtility
AbstractTestShell.TEST_UTIL
protected static final HBaseTestingUtility
CloneSnapshotFromClientTestBase.TEST_UTIL
protected static final HBaseTestingUtility
MetaWithReplicasTestBase.TEST_UTIL
protected static final HBaseTestingUtility
RestoreSnapshotFromClientTestBase.TEST_UTIL
protected static HBaseTestingUtility
SnapshotWithAclTestBase.TEST_UTIL
protected static final HBaseTestingUtility
TestAdminBase.TEST_UTIL
protected static final HBaseTestingUtility
TestAppendFromClientSide.TEST_UTIL
protected static final HBaseTestingUtility
TestAsyncAdminBase.TEST_UTIL
protected static final HBaseTestingUtility
TestAvoidCellReferencesIntoShippedBlocks.TEST_UTIL
protected static final HBaseTestingUtility
TestBlockEvictionFromClient.TEST_UTIL
protected static final HBaseTestingUtility
TestFromClientSideNoCodec.TEST_UTIL
protected static final HBaseTestingUtility
TestFromClientSideScanExcpetion.TEST_UTIL
protected static final HBaseTestingUtility
TestIllegalTableDescriptor.TEST_UTIL
protected static final HBaseTestingUtility
TestIncrementsFromClientSide.TEST_UTIL
protected static final HBaseTestingUtility
TestSizeFailures.TEST_UTIL
protected static final HBaseTestingUtility
AbstractTestRegionLocator.UTIL
protected static final HBaseTestingUtility
ClientPushbackTestBase.UTIL
protected static final HBaseTestingUtility
TestSnapshotCloneIndependence.UTIL
protected static final HBaseTestingUtility
TestSnapshotFromClient.UTIL
protected static final HBaseTestingUtility
TestSnapshotTemporaryDirectory.UTIL
protected HBaseTestingUtility
TestServerLoadDurability.utility
Modifier and TypeMethodDescriptionprotected static void
AbstractTestUpdateConfiguration.addResourceToRegionServerConfiguration
(HBaseTestingUtility testUtil) static void
RegionReplicaTestHelper.assertReplicaDistributed
(HBaseTestingUtility util, Table t) static void
TestTableSnapshotScanner.blockUntilSplitFinished
(HBaseTestingUtility util, TableName tableName, int expectedRegionSize) static void
TestEnableTable.createTable
(HBaseTestingUtility testUtil, HTableDescriptor htd, byte[][] splitKeys) static void
TestTableSnapshotScanner.createTableAndSnapshot
(HBaseTestingUtility util, TableName tableName, String snapshotName, int numRegions) static void
TestEnableTable.deleteTable
(HBaseTestingUtility testUtil, TableName tableName) protected static void
AbstractTestUpdateConfiguration.setUpConfigurationFiles
(HBaseTestingUtility testUtil) static void
TestMetaWithReplicasShutdownHandling.shutdownMetaAndDoValidations
(HBaseTestingUtility util) protected void
CloneSnapshotFromClientTestBase.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
RestoreSnapshotFromClientTestBase.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestMobCloneSnapshotFromClientNormal.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientAfterSplittingRegions.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientAfterTruncate.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientClone.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientGetCompactionState.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientSchemaChange.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientSimple.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.coprocessor
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.io.compress
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
HFileTestBase.TEST_UTIL
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.io.hfile
ModifierConstructorDescriptionHFileTestRule
(HBaseTestingUtility testingUtility, org.junit.rules.TestName testName) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescriptionprotected static HBaseTestingUtility
TestNettyRpcServer.TEST_UTIL
protected static final HBaseTestingUtility
TestRpcSkipInitialSaslHandshake.TEST_UTIL
protected static final HBaseTestingUtility
TestSecurityRpcSentBytesMetrics.TEST_UTIL
protected static HBaseTestingUtility
TestSimpleRpcServer.TEST_UTIL
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.mapred
Modifier and TypeMethodDescriptionstatic void
TestTableSnapshotInputFormat.doTestWithMapReduce
(HBaseTestingUtility util, TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected void
TestTableSnapshotInputFormat.testWithMapReduceImpl
(HBaseTestingUtility util, TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected void
TestTableSnapshotInputFormat.testWithMockedMapReduce
(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescriptionstatic final HBaseTestingUtility
MultiTableInputFormatTestBase.TEST_UTIL
protected static final HBaseTestingUtility
TestSimpleTotalOrderPartitioner.TEST_UTIL
protected static HBaseTestingUtility
TestImportTsv.util
protected static HBaseTestingUtility
TestImportTSVWithOperationAttributes.util
protected static HBaseTestingUtility
TestImportTSVWithTTLs.util
protected static HBaseTestingUtility
TestImportTSVWithVisibilityLabels.util
protected final HBaseTestingUtility
TableSnapshotInputFormatTestBase.UTIL
protected static final HBaseTestingUtility
TestCellBasedImportExport2.UTIL
protected static final HBaseTestingUtility
TestImportExport.UTIL
protected static final HBaseTestingUtility
TestTableMapReduceBase.UTIL
Modifier and TypeMethodDescriptionprotected static void
TableSnapshotInputFormatTestBase.createTableAndSnapshot
(HBaseTestingUtility util, TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, int numRegions) protected static org.apache.hadoop.util.Tool
TestImportTsv.doMROnTableTest
(HBaseTestingUtility util, TableName table, String family, String data, Map<String, String> args) protected static org.apache.hadoop.util.Tool
TestImportTsv.doMROnTableTest
(HBaseTestingUtility util, TableName table, String family, String data, Map<String, String> args, int valueMultiplier, int expectedKVCount) Run an ImportTsv job and perform basic validation on the results.protected static org.apache.hadoop.util.Tool
TestImportTSVWithTTLs.doMROnTableTest
(HBaseTestingUtility util, String family, String data, String[] args, int valueMultiplier) protected static org.apache.hadoop.util.Tool
TestImportTSVWithVisibilityLabels.doMROnTableTest
(HBaseTestingUtility util, String family, String data, String[] args, int valueMultiplier) protected static org.apache.hadoop.util.Tool
TestImportTSVWithVisibilityLabels.doMROnTableTest
(HBaseTestingUtility util, String family, String data, String[] args, int valueMultiplier, int expectedKVCount) Run an ImportTsv job and perform basic validation on the results.static void
TestTableSnapshotInputFormat.doTestWithMapReduce
(HBaseTestingUtility util, TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected void
TableSnapshotInputFormatTestBase.testWithMapReduce
(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected abstract void
TableSnapshotInputFormatTestBase.testWithMapReduceImpl
(HBaseTestingUtility util, TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected void
TestTableSnapshotInputFormat.testWithMapReduceImpl
(HBaseTestingUtility util, TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected abstract void
TableSnapshotInputFormatTestBase.testWithMockedMapReduce
(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) void
TestTableSnapshotInputFormat.testWithMockedMapReduce
(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.master
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
TestWarmupRegion.TEST_UTIL
protected HBaseTestingUtility
AbstractTestRestartCluster.UTIL
protected static final HBaseTestingUtility
TestMergeTableRegionsWhileRSCrash.UTIL
protected static final HBaseTestingUtility
TestSplitRegionWhileRSCrash.UTIL
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.mob
Modifier and TypeFieldDescriptionprotected static HBaseTestingUtility
TestMobCompactionWithDefaults.HTU
Modifier and TypeMethodDescriptionstatic int
MobTestUtil.countMobRows
(HBaseTestingUtility util, Table table) Gets the number of rows in the given table. -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.namequeues
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
TestTooLargeLog.TEST_UTIL
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.namespace
Modifier and TypeMethodDescriptionstatic void
TestNamespaceAuditor.waitForQuotaInitialize
(HBaseTestingUtility util) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.quotas
ModifierConstructorDescriptionSpaceQuotaHelperForTests
(HBaseTestingUtility testUtil, org.junit.rules.TestName testName, AtomicLong counter) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
TestCompactionPolicy.TEST_UTIL
protected static HBaseTestingUtility
TestHRegion.TEST_UTIL
protected static HBaseTestingUtility
TestRecoveredEditsReplayAndAbort.TEST_UTIL
TestCompactionArchiveIOException.testUtil
protected static final HBaseTestingUtility
TestSecureBulkLoadManager.testUtil
protected static HBaseTestingUtility
TestHRegionServerBulkLoad.UTIL
protected static final HBaseTestingUtility
TestSplitWithBlockingFiles.UTIL
protected static final HBaseTestingUtility
TestBulkLoadReplication.UTIL3
Modifier and TypeMethodDescriptionprotected void
TestBulkLoadReplication.assertBulkLoadConditions
(TableName tableName, byte[] row, byte[] value, HBaseTestingUtility utility, Table... tables) protected void
TestBulkLoadReplication.bulkLoadOnCluster
(TableName tableName, byte[] row, byte[] value, HBaseTestingUtility cluster) static void
TestRegionServerNoMaster.checkRegionIsClosed
(HBaseTestingUtility HTU, HRegionServer rs, HRegionInfo hri) static void
TestRegionServerNoMaster.checkRegionIsOpened
(HBaseTestingUtility HTU, HRegionServer rs, HRegionInfo hri) static void
TestRegionServerNoMaster.closeRegion
(HBaseTestingUtility HTU, HRegionServer rs, HRegionInfo hri) static void
TestRegionServerNoMaster.flushRegion
(HBaseTestingUtility HTU, RegionInfo regionInfo) Flush the given region in the mini cluster.static void
TestRegionServerNoMaster.openRegion
(HBaseTestingUtility HTU, HRegionServer rs, HRegionInfo hri) static void
TestRegionServerNoMaster.stopMasterAndCacheMetaLocation
(HBaseTestingUtility HTU) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
AbstractTestFSWAL.TEST_UTIL
protected static final HBaseTestingUtility
AbstractTestLogRolling.TEST_UTIL
protected static final HBaseTestingUtility
AbstractTestLogRollPeriod.TEST_UTIL
protected static final HBaseTestingUtility
AbstractTestProtobufLog.TEST_UTIL
protected static final HBaseTestingUtility
TestLogRollAbort.TEST_UTIL
protected static final HBaseTestingUtility
TestWALOpenError.TEST_UTIL
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
SerialReplicationTestBase.UTIL
protected static final HBaseTestingUtility
TestNonHBaseReplicationEndpoint.UTIL
protected static final HBaseTestingUtility
TestReplicationBase.UTIL1
protected static final HBaseTestingUtility
TestReplicationSyncUpToolBase.UTIL1
protected static final HBaseTestingUtility
TestReplicationBase.UTIL2
protected static final HBaseTestingUtility
TestReplicationSyncUpToolBase.UTIL2
protected static HBaseTestingUtility
TestReplicationEditsDroppedWithDeletedTableCFs.utility1
protected static HBaseTestingUtility
TestReplicationEditsDroppedWithDroppedTable.utility1
protected static HBaseTestingUtility
TestReplicationStuckWithDeletedTableCFs.utility1
protected static HBaseTestingUtility
TestReplicationStuckWithDroppedTable.utility1
protected static HBaseTestingUtility
TestReplicationEditsDroppedWithDeletedTableCFs.utility2
protected static HBaseTestingUtility
TestReplicationEditsDroppedWithDroppedTable.utility2
protected static HBaseTestingUtility
TestReplicationStuckWithDeletedTableCFs.utility2
protected static HBaseTestingUtility
TestReplicationStuckWithDroppedTable.utility2
Modifier and TypeMethodDescriptionprotected void
TestReplicationKillRS.loadTableAndKillRS
(HBaseTestingUtility util) Load up 1 tables over 2 region servers and kill a source during the upload.protected static void
TestReplicationBase.setupConfig
(HBaseTestingUtility util, String znodeParent) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.rest
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
RowResourceBase.TEST_UTIL
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.rsgroup
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.security
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
AbstractTestSecureIPC.TEST_UTIL
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.snapshot
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
TestExportSnapshot.TEST_UTIL
protected static final HBaseTestingUtility
TestExportSnapshotAdjunct.TEST_UTIL
protected static final HBaseTestingUtility
TestRestoreSnapshotHelper.TEST_UTIL
protected static final HBaseTestingUtility
TestFlushSnapshotFromClient.UTIL
protected static final HBaseTestingUtility
TestRestoreFlushSnapshotFromClient.UTIL
Modifier and TypeMethodDescriptionstatic void
SnapshotTestingUtils.confirmSnapshotValid
(HBaseTestingUtility testUtil, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshotDescriptor, TableName tableName, byte[] family) static ArrayList
SnapshotTestingUtils.corruptSnapshot
(HBaseTestingUtility util, String snapshotName) Corrupt the specified snapshot by deleting some files.static Table
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtility util, TableName tableName, byte[]... families) Create a Mob table.static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtility util, TableName tableName, byte[][] splitKeys, int regionReplication, byte[]... families) static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtility util, TableName tableName, byte[][] splitKeys, int regionReplication, String storeFileTracker, byte[]... families) static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtility util, TableName tableName, byte[][] splitKeys, int regionReplication, String storeFileTracker, String cpClassName, byte[]... families) static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtility util, TableName tableName, int regionReplication, byte[]... families) Create the Mob Table.static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtility util, TableName tableName, int regionReplication, String storeFileTracker, byte[]... families) static void
MobSnapshotTestingUtils.createPreSplitMobTable
(HBaseTestingUtility util, TableName tableName, int nRegions, byte[]... families) static void
SnapshotTestingUtils.createPreSplitTable
(HBaseTestingUtility util, TableName tableName, int nRegions, byte[]... families) static void
SnapshotTestingUtils.createTable
(HBaseTestingUtility util, TableName tableName, byte[]... families) static void
SnapshotTestingUtils.createTable
(HBaseTestingUtility util, TableName tableName, int regionReplication, byte[]... families) static void
SnapshotTestingUtils.createTable
(HBaseTestingUtility util, TableName tableName, int regionReplication, int nRegions, byte[]... families) static void
SnapshotTestingUtils.deleteArchiveDirectory
(HBaseTestingUtility util) static void
SnapshotTestingUtils.loadData
(HBaseTestingUtility util, BufferedMutator mutator, int rows, byte[]... families) static void
SnapshotTestingUtils.loadData
(HBaseTestingUtility util, TableName tableName, int rows, byte[]... families) static void
MobSnapshotTestingUtils.verifyMobRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) static void
SnapshotTestingUtils.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestFlushSnapshotFromClient.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestMobFlushSnapshotFromClient.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestMobRestoreFlushSnapshotFromClient.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) protected void
TestRestoreFlushSnapshotFromClient.verifyRowCount
(HBaseTestingUtility util, TableName tableName, long expectedRows) static void
SnapshotTestingUtils.waitForTableToBeOnline
(HBaseTestingUtility util, TableName tableName) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.thrift
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
TestThriftHttpServer.TEST_UTIL
protected static final HBaseTestingUtility
TestThriftServerCmdLine.TEST_UTIL
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
BaseTestHBaseFsck.TEST_UTIL
protected static final HBaseTestingUtility
TestCoprocessorScanPolicy.TEST_UTIL
protected static final HBaseTestingUtility
TestMiniClusterLoadSequential.TEST_UTIL
static final HBaseTestingUtility
TestRegionSplitCalculator.TEST_UTIL
Modifier and TypeMethodDescriptionstatic void
BaseTestHBaseFsck.createTable
(HBaseTestingUtility testUtil, HTableDescriptor htd, byte[][] splitKeys) static void
BaseTestHBaseFsck.deleteTable
(HBaseTestingUtility testUtil, TableName tableName) static org.apache.hadoop.fs.Path
HFileArchiveTestingUtil.getStoreArchivePath
(HBaseTestingUtility util, String tableName, byte[] storeName) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.util.compaction
Modifier and TypeFieldDescriptionprotected HBaseTestingUtility
TestMajorCompactor.utility
protected static final HBaseTestingUtility
TestMajorCompactionRequest.UTILITY
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.wal
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtility
CompressedWALTestBase.TEST_UTIL
protected static final HBaseTestingUtility
TestWALFactory.TEST_UTIL
protected static final HBaseTestingUtility
TestWALSplit.TEST_UTIL
protected static final HBaseTestingUtility
WALCorruptionDueToDanglingByteBufferTestBase.UTIL
protected static final HBaseTestingUtility
WALCorruptionWithMultiPutDueToDanglingByteBufferTestBase.UTIL