Uses of Class
org.apache.hadoop.hbase.HBaseTestingUtility
Packages that use HBaseTestingUtility
Package
Description
-
Uses of HBaseTestingUtility in org.apache.hadoop.hbase
Subclasses of HBaseTestingUtility in org.apache.hadoop.hbaseModifier and TypeClassDescriptionclassFacility for integration/system tests.Fields in org.apache.hadoop.hbase declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected final HBaseTestingUtilityHBaseTestCase.testUtilDeprecated.Methods in org.apache.hadoop.hbase that return HBaseTestingUtilityModifier and TypeMethodDescriptionstatic HBaseTestingUtilityHBaseTestingUtility.createLocalHTU()Deprecated.since 2.0.0 and will be removed in 3.0.0.static HBaseTestingUtilityHBaseTestingUtility.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 ofHBaseTestingUtilityMethods in org.apache.hadoop.hbase with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionstatic voidProcedureTestUtil.waitUntilProcedureTimeoutIncrease(HBaseTestingUtility util, Class<? extends org.apache.hadoop.hbase.procedure2.Procedure<?>> clazz, int times) static voidProcedureTestUtil.waitUntilProcedureWaitingTimeout(HBaseTestingUtility util, Class<? extends org.apache.hadoop.hbase.procedure2.Procedure<?>> clazz, long timeout) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.backup
Fields in org.apache.hadoop.hbase.backup declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static HBaseTestingUtilityTestBackupBase.TEST_UTILprotected static HBaseTestingUtilityTestBackupUtils.TEST_UTILprotected static HBaseTestingUtilityTestBackupBase.TEST_UTIL2 -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityAbstractTestAsyncTableRegionReplicasRead.TEST_UTILprotected static final HBaseTestingUtilityAbstractTestCITimeout.TEST_UTILprotected static final HBaseTestingUtilityAbstractTestScanCursor.TEST_UTILprotected static final HBaseTestingUtilityAbstractTestShell.TEST_UTILprotected static final HBaseTestingUtilityCloneSnapshotFromClientTestBase.TEST_UTILprotected static final HBaseTestingUtilityMetaWithReplicasTestBase.TEST_UTILprotected static final HBaseTestingUtilityRestoreSnapshotFromClientTestBase.TEST_UTILprotected static HBaseTestingUtilitySnapshotWithAclTestBase.TEST_UTILprotected static final HBaseTestingUtilityTestAdminBase.TEST_UTILprotected static final HBaseTestingUtilityTestAppendFromClientSide.TEST_UTILprotected static final HBaseTestingUtilityTestAsyncAdminBase.TEST_UTILprotected static final HBaseTestingUtilityTestAvoidCellReferencesIntoShippedBlocks.TEST_UTILprotected static final HBaseTestingUtilityTestBlockEvictionFromClient.TEST_UTILprotected static final HBaseTestingUtilityTestFromClientSideNoCodec.TEST_UTILprotected static final HBaseTestingUtilityTestFromClientSideScanExcpetion.TEST_UTILprotected static final HBaseTestingUtilityTestIllegalTableDescriptor.TEST_UTILprotected static final HBaseTestingUtilityTestIncrementsFromClientSide.TEST_UTILprotected static final HBaseTestingUtilityTestSizeFailures.TEST_UTILprotected static final HBaseTestingUtilityAbstractTestRegionLocator.UTILprotected static final HBaseTestingUtilityClientPushbackTestBase.UTILprotected static final HBaseTestingUtilityTestSnapshotCloneIndependence.UTILprotected static final HBaseTestingUtilityTestSnapshotFromClient.UTILprotected static final HBaseTestingUtilityTestSnapshotTemporaryDirectory.UTILprotected HBaseTestingUtilityTestServerLoadDurability.utilityMethods in org.apache.hadoop.hbase.client with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionprotected static voidAbstractTestUpdateConfiguration.addResourceToRegionServerConfiguration(HBaseTestingUtility testUtil) static voidRegionReplicaTestHelper.assertReplicaDistributed(HBaseTestingUtility util, Table t) static voidTestTableSnapshotScanner.blockUntilSplitFinished(HBaseTestingUtility util, TableName tableName, int expectedRegionSize) static voidTestEnableTable.createTable(HBaseTestingUtility testUtil, HTableDescriptor htd, byte[][] splitKeys) static voidTestTableSnapshotScanner.createTableAndSnapshot(HBaseTestingUtility util, TableName tableName, String snapshotName, int numRegions) static voidTestEnableTable.deleteTable(HBaseTestingUtility testUtil, TableName tableName) protected static voidAbstractTestUpdateConfiguration.setUpConfigurationFiles(HBaseTestingUtility testUtil) static voidTestMetaWithReplicasShutdownHandling.shutdownMetaAndDoValidations(HBaseTestingUtility util) protected voidCloneSnapshotFromClientTestBase.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidRestoreSnapshotFromClientTestBase.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestMobCloneSnapshotFromClientNormal.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestMobRestoreSnapshotFromClientAfterSplittingRegions.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestMobRestoreSnapshotFromClientAfterTruncate.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestMobRestoreSnapshotFromClientClone.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestMobRestoreSnapshotFromClientGetCompactionState.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestMobRestoreSnapshotFromClientSchemaChange.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestMobRestoreSnapshotFromClientSimple.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.coprocessor
Constructors in org.apache.hadoop.hbase.coprocessor with parameters of type HBaseTestingUtility -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.io.compress
Fields in org.apache.hadoop.hbase.io.compress declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityHFileTestBase.TEST_UTIL -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.io.hfile
Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type HBaseTestingUtilityModifierConstructorDescriptionHFileTestRule(HBaseTestingUtility testingUtility, org.junit.rules.TestName testName) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static HBaseTestingUtilityTestNettyRpcServer.TEST_UTILprotected static final HBaseTestingUtilityTestRpcSkipInitialSaslHandshake.TEST_UTILprotected static final HBaseTestingUtilityTestSecurityRpcSentBytesMetrics.TEST_UTILprotected static HBaseTestingUtilityTestSimpleRpcServer.TEST_UTIL -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.mapred
Methods in org.apache.hadoop.hbase.mapred with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionstatic voidTestTableSnapshotInputFormat.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 voidTestTableSnapshotInputFormat.testWithMapReduceImpl(HBaseTestingUtility util, TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected voidTestTableSnapshotInputFormat.testWithMockedMapReduce(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.mapreduce
Fields in org.apache.hadoop.hbase.mapreduce declared as HBaseTestingUtilityModifier and TypeFieldDescriptionstatic final HBaseTestingUtilityMultiTableInputFormatTestBase.TEST_UTILprotected static final HBaseTestingUtilityTestSimpleTotalOrderPartitioner.TEST_UTILprotected static HBaseTestingUtilityTestImportTsv.utilprotected static HBaseTestingUtilityTestImportTSVWithOperationAttributes.utilprotected static HBaseTestingUtilityTestImportTSVWithTTLs.utilprotected static HBaseTestingUtilityTestImportTSVWithVisibilityLabels.utilprotected final HBaseTestingUtilityTableSnapshotInputFormatTestBase.UTILprotected static final HBaseTestingUtilityTestCellBasedImportExport2.UTILprotected static final HBaseTestingUtilityTestImportExport.UTILprotected static final HBaseTestingUtilityTestTableMapReduceBase.UTILMethods in org.apache.hadoop.hbase.mapreduce with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionprotected static voidTableSnapshotInputFormatTestBase.createTableAndSnapshot(HBaseTestingUtility util, TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, int numRegions) protected static org.apache.hadoop.util.ToolTestImportTsv.doMROnTableTest(HBaseTestingUtility util, TableName table, String family, String data, Map<String, String> args) protected static org.apache.hadoop.util.ToolTestImportTsv.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.ToolTestImportTSVWithTTLs.doMROnTableTest(HBaseTestingUtility util, String family, String data, String[] args, int valueMultiplier) protected static org.apache.hadoop.util.ToolTestImportTSVWithVisibilityLabels.doMROnTableTest(HBaseTestingUtility util, String family, String data, String[] args, int valueMultiplier) protected static org.apache.hadoop.util.ToolTestImportTSVWithVisibilityLabels.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 voidTestTableSnapshotInputFormat.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 voidTableSnapshotInputFormatTestBase.testWithMapReduce(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected abstract voidTableSnapshotInputFormatTestBase.testWithMapReduceImpl(HBaseTestingUtility util, TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected voidTestTableSnapshotInputFormat.testWithMapReduceImpl(HBaseTestingUtility util, TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected abstract voidTableSnapshotInputFormatTestBase.testWithMockedMapReduce(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) voidTestTableSnapshotInputFormat.testWithMockedMapReduce(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.master
Fields in org.apache.hadoop.hbase.master declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityTestWarmupRegion.TEST_UTILprotected HBaseTestingUtilityAbstractTestRestartCluster.UTILprotected static final HBaseTestingUtilityTestMergeTableRegionsWhileRSCrash.UTILprotected static final HBaseTestingUtilityTestSplitRegionWhileRSCrash.UTIL -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.mob
Fields in org.apache.hadoop.hbase.mob declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static HBaseTestingUtilityTestMobCompactionWithDefaults.HTUMethods in org.apache.hadoop.hbase.mob with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionstatic intMobTestUtil.countMobRows(HBaseTestingUtility util, Table table) Gets the number of rows in the given table. -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.namequeues
Fields in org.apache.hadoop.hbase.namequeues declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityTestTooLargeLog.TEST_UTIL -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.namespace
Methods in org.apache.hadoop.hbase.namespace with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionstatic voidTestNamespaceAuditor.waitForQuotaInitialize(HBaseTestingUtility util) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.quotas
Constructors in org.apache.hadoop.hbase.quotas with parameters of type HBaseTestingUtilityModifierConstructorDescriptionSpaceQuotaHelperForTests(HBaseTestingUtility testUtil, org.junit.rules.TestName testName, AtomicLong counter) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.regionserver
Fields in org.apache.hadoop.hbase.regionserver declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityTestCompactionPolicy.TEST_UTILprotected static HBaseTestingUtilityTestHRegion.TEST_UTILprotected static HBaseTestingUtilityTestRecoveredEditsReplayAndAbort.TEST_UTILTestCompactionArchiveIOException.testUtilprotected static final HBaseTestingUtilityTestSecureBulkLoadManager.testUtilprotected static HBaseTestingUtilityTestHRegionServerBulkLoad.UTILprotected static final HBaseTestingUtilityTestSplitWithBlockingFiles.UTILprotected static final HBaseTestingUtilityTestBulkLoadReplication.UTIL3Methods in org.apache.hadoop.hbase.regionserver with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionprotected voidTestBulkLoadReplication.assertBulkLoadConditions(TableName tableName, byte[] row, byte[] value, HBaseTestingUtility utility, Table... tables) protected voidTestBulkLoadReplication.bulkLoadOnCluster(TableName tableName, byte[] row, byte[] value, HBaseTestingUtility cluster) static voidTestRegionServerNoMaster.checkRegionIsClosed(HBaseTestingUtility HTU, HRegionServer rs, HRegionInfo hri) static voidTestRegionServerNoMaster.checkRegionIsOpened(HBaseTestingUtility HTU, HRegionServer rs, HRegionInfo hri) static voidTestRegionServerNoMaster.closeRegion(HBaseTestingUtility HTU, HRegionServer rs, HRegionInfo hri) static voidTestRegionServerNoMaster.flushRegion(HBaseTestingUtility HTU, RegionInfo regionInfo) Flush the given region in the mini cluster.static voidTestRegionServerNoMaster.openRegion(HBaseTestingUtility HTU, HRegionServer rs, HRegionInfo hri) static voidTestRegionServerNoMaster.stopMasterAndCacheMetaLocation(HBaseTestingUtility HTU) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.regionserver.wal
Fields in org.apache.hadoop.hbase.regionserver.wal declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityAbstractTestFSWAL.TEST_UTILprotected static final HBaseTestingUtilityAbstractTestLogRolling.TEST_UTILprotected static final HBaseTestingUtilityAbstractTestLogRollPeriod.TEST_UTILprotected static final HBaseTestingUtilityAbstractTestProtobufLog.TEST_UTILprotected static final HBaseTestingUtilityTestLogRollAbort.TEST_UTILprotected static final HBaseTestingUtilityTestWALOpenError.TEST_UTIL -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.replication
Fields in org.apache.hadoop.hbase.replication declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilitySerialReplicationTestBase.UTILprotected static final HBaseTestingUtilityTestNonHBaseReplicationEndpoint.UTILprotected static final HBaseTestingUtilityTestReplicationBase.UTIL1protected static final HBaseTestingUtilityTestReplicationSyncUpToolBase.UTIL1protected static final HBaseTestingUtilityTestReplicationBase.UTIL2protected static final HBaseTestingUtilityTestReplicationSyncUpToolBase.UTIL2protected static HBaseTestingUtilityTestReplicationEditsDroppedWithDeletedTableCFs.utility1protected static HBaseTestingUtilityTestReplicationEditsDroppedWithDroppedTable.utility1protected static HBaseTestingUtilityTestReplicationStuckWithDeletedTableCFs.utility1protected static HBaseTestingUtilityTestReplicationStuckWithDroppedTable.utility1protected static HBaseTestingUtilityTestReplicationEditsDroppedWithDeletedTableCFs.utility2protected static HBaseTestingUtilityTestReplicationEditsDroppedWithDroppedTable.utility2protected static HBaseTestingUtilityTestReplicationStuckWithDeletedTableCFs.utility2protected static HBaseTestingUtilityTestReplicationStuckWithDroppedTable.utility2Methods in org.apache.hadoop.hbase.replication with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionprotected voidTestReplicationKillRS.loadTableAndKillRS(HBaseTestingUtility util) Load up 1 tables over 2 region servers and kill a source during the upload.protected static voidTestReplicationBase.setupConfig(HBaseTestingUtility util, String znodeParent) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.rest
Fields in org.apache.hadoop.hbase.rest declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityRowResourceBase.TEST_UTIL -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.rsgroup
Fields in org.apache.hadoop.hbase.rsgroup declared as HBaseTestingUtility -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.security
Fields in org.apache.hadoop.hbase.security declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityAbstractTestSecureIPC.TEST_UTIL -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.snapshot
Fields in org.apache.hadoop.hbase.snapshot declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityTestExportSnapshot.TEST_UTILprotected static final HBaseTestingUtilityTestExportSnapshotAdjunct.TEST_UTILprotected static final HBaseTestingUtilityTestRestoreSnapshotHelper.TEST_UTILprotected static final HBaseTestingUtilityTestFlushSnapshotFromClient.UTILprotected static final HBaseTestingUtilityTestRestoreFlushSnapshotFromClient.UTILMethods in org.apache.hadoop.hbase.snapshot with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionstatic voidSnapshotTestingUtils.confirmSnapshotValid(HBaseTestingUtility testUtil, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshotDescriptor, TableName tableName, byte[] family) static ArrayListSnapshotTestingUtils.corruptSnapshot(HBaseTestingUtility util, String snapshotName) Corrupt the specified snapshot by deleting some files.static TableMobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util, TableName tableName, byte[]... families) Create a Mob table.static voidMobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util, TableName tableName, byte[][] splitKeys, int regionReplication, byte[]... families) static voidMobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util, TableName tableName, byte[][] splitKeys, int regionReplication, String storeFileTracker, byte[]... families) static voidMobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util, TableName tableName, byte[][] splitKeys, int regionReplication, String storeFileTracker, String cpClassName, byte[]... families) static voidMobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util, TableName tableName, int regionReplication, byte[]... families) Create the Mob Table.static voidMobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util, TableName tableName, int regionReplication, String storeFileTracker, byte[]... families) static voidMobSnapshotTestingUtils.createPreSplitMobTable(HBaseTestingUtility util, TableName tableName, int nRegions, byte[]... families) static voidSnapshotTestingUtils.createPreSplitTable(HBaseTestingUtility util, TableName tableName, int nRegions, byte[]... families) static voidSnapshotTestingUtils.createTable(HBaseTestingUtility util, TableName tableName, byte[]... families) static voidSnapshotTestingUtils.createTable(HBaseTestingUtility util, TableName tableName, int regionReplication, byte[]... families) static voidSnapshotTestingUtils.createTable(HBaseTestingUtility util, TableName tableName, int regionReplication, int nRegions, byte[]... families) static voidSnapshotTestingUtils.deleteArchiveDirectory(HBaseTestingUtility util) static voidSnapshotTestingUtils.loadData(HBaseTestingUtility util, BufferedMutator mutator, int rows, byte[]... families) static voidSnapshotTestingUtils.loadData(HBaseTestingUtility util, TableName tableName, int rows, byte[]... families) static voidMobSnapshotTestingUtils.verifyMobRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) static voidSnapshotTestingUtils.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestFlushSnapshotFromClient.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestMobFlushSnapshotFromClient.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestMobRestoreFlushSnapshotFromClient.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) protected voidTestRestoreFlushSnapshotFromClient.verifyRowCount(HBaseTestingUtility util, TableName tableName, long expectedRows) static voidSnapshotTestingUtils.waitForTableToBeOnline(HBaseTestingUtility util, TableName tableName) -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.thrift
Fields in org.apache.hadoop.hbase.thrift declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityTestThriftHttpServer.TEST_UTILprotected static final HBaseTestingUtilityTestThriftServerCmdLine.TEST_UTIL -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.util
Fields in org.apache.hadoop.hbase.util declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityBaseTestHBaseFsck.TEST_UTILprotected static final HBaseTestingUtilityTestCoprocessorScanPolicy.TEST_UTILprotected static final HBaseTestingUtilityTestMiniClusterLoadSequential.TEST_UTILstatic final HBaseTestingUtilityTestRegionSplitCalculator.TEST_UTILMethods in org.apache.hadoop.hbase.util with parameters of type HBaseTestingUtilityModifier and TypeMethodDescriptionstatic voidBaseTestHBaseFsck.createTable(HBaseTestingUtility testUtil, HTableDescriptor htd, byte[][] splitKeys) static voidBaseTestHBaseFsck.deleteTable(HBaseTestingUtility testUtil, TableName tableName) static org.apache.hadoop.fs.PathHFileArchiveTestingUtil.getStoreArchivePath(HBaseTestingUtility util, String tableName, byte[] storeName) Constructors in org.apache.hadoop.hbase.util with parameters of type HBaseTestingUtility -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.util.compaction
Fields in org.apache.hadoop.hbase.util.compaction declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected HBaseTestingUtilityTestMajorCompactor.utilityprotected static final HBaseTestingUtilityTestMajorCompactionRequest.UTILITY -
Uses of HBaseTestingUtility in org.apache.hadoop.hbase.wal
Fields in org.apache.hadoop.hbase.wal declared as HBaseTestingUtilityModifier and TypeFieldDescriptionprotected static final HBaseTestingUtilityCompressedWALTestBase.TEST_UTILprotected static final HBaseTestingUtilityTestWALFactory.TEST_UTILprotected static final HBaseTestingUtilityTestWALSplit.TEST_UTILprotected static final HBaseTestingUtilityWALCorruptionDueToDanglingByteBufferTestBase.UTILprotected static final HBaseTestingUtilityWALCorruptionWithMultiPutDueToDanglingByteBufferTestBase.UTIL