Modifier and Type | Class and Description |
---|---|
class |
IntegrationTestingUtility
Facility for integration/system tests.
|
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestPerformanceEvaluation.HTU |
private static HBaseTestingUtility |
TestFullLogReconstruction.TEST_UTIL |
private static HBaseTestingUtility |
TestServerSideScanMetricsFromClientSide.TEST_UTIL |
private static HBaseTestingUtility |
TestZooKeeper.TEST_UTIL |
private static HBaseTestingUtility |
TestLocalHBaseCluster.TEST_UTIL |
private static HBaseTestingUtility |
TestPartialResultsFromClientSide.TEST_UTIL |
private HBaseTestingUtility |
TestGlobalMemStoreSize.TEST_UTIL |
private static HBaseTestingUtility |
TestClusterPortAssignment.TEST_UTIL |
private static HBaseTestingUtility |
TestCachedClusterId.TEST_UTIL |
private static HBaseTestingUtility |
TestHColumnDescriptorDefaultVersions.TEST_UTIL |
private static HBaseTestingUtility |
TestIOFencing.TEST_UTIL |
private static HBaseTestingUtility |
TestNamespace.TEST_UTIL |
private HBaseTestingUtility |
MiniClusterRule.testingUtility |
private HBaseTestingUtility |
TestClusterBootOrder.testUtil |
protected HBaseTestingUtility |
HBaseTestCase.testUtil
Deprecated.
|
private static HBaseTestingUtility |
TestHBaseMetaEdit.UTIL |
private static HBaseTestingUtility |
TestMetaTableAccessorNoCluster.UTIL |
private static HBaseTestingUtility |
TestSplitMerge.UTIL |
private static HBaseTestingUtility |
AcidGuaranteesTestBase.UTIL |
private static HBaseTestingUtility |
TestRegionMetrics.UTIL |
private static HBaseTestingUtility |
TestInfoServers.UTIL |
private static HBaseTestingUtility |
TestJMXConnectorServer.UTIL |
private static HBaseTestingUtility |
TestClientOperationTimeout.UTIL |
private static HBaseTestingUtility |
TestClientClusterMetrics.UTIL |
private static HBaseTestingUtility |
TestMetaTableLocator.UTIL |
private HBaseTestingUtility |
TestMovedRegionCache.UTIL |
private static HBaseTestingUtility |
TestMultiVersions.UTIL |
private static HBaseTestingUtility |
TestFSTableDescriptorForceCreation.UTIL |
private HBaseTestingUtility |
TestRegionRebalancing.UTIL |
private static HBaseTestingUtility |
TestJMXListener.UTIL |
private static HBaseTestingUtility |
TestRegionLoad.UTIL |
private static HBaseTestingUtility |
TestClientClusterStatus.UTIL |
private static HBaseTestingUtility |
TestMetaTableAccessor.UTIL |
private static HBaseTestingUtility |
TestSequenceIdMonotonicallyIncreasing.UTIL |
private static HBaseTestingUtility |
TestNodeHealthCheckChore.UTIL |
private static HBaseTestingUtility |
TestHBaseTestingUtilSpinup.UTIL |
Modifier and Type | Field and Description |
---|---|
private Supplier<HBaseTestingUtility> |
TestServerInternalsTracing.Setup.testingUtilSupplier |
Modifier and Type | Method and Description |
---|---|
static HBaseTestingUtility |
HBaseTestingUtility.createLocalHTU()
Deprecated.
since 2.0.0 and will be removed in 3.0.0. Use
HBaseTestingUtility()
instead. |
static HBaseTestingUtility |
HBaseTestingUtility.createLocalHTU(org.apache.hadoop.conf.Configuration c)
Deprecated.
since 2.0.0 and will be removed in 3.0.0. Use
HBaseTestingUtility(Configuration) instead. |
HBaseTestingUtility |
MiniClusterRule.getTestingUtility()
Returns the underlying instance of
HBaseTestingUtility |
Modifier and Type | Method and Description |
---|---|
private static File |
TestShellExecEndpointCoprocessor.ensureTestDataDirExists(HBaseTestingUtility testingUtility) |
private static Optional<org.apache.hbase.thirdparty.com.google.gson.JsonObject> |
ProcedureTestUtil.getProcedure(HBaseTestingUtility util,
Class<? extends org.apache.hadoop.hbase.procedure2.Procedure<?>> clazz,
org.apache.hbase.thirdparty.com.google.gson.JsonParser parser) |
static 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) |
Constructor and Description |
---|
Setup(Supplier<HBaseTestingUtility> testingUtilSupplier) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestHFileArchiving.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestZooKeeperTableArchiveClient.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestReplicaWithCluster.HTU |
private static HBaseTestingUtility |
TestReplicasClient.HTU |
private static HBaseTestingUtility |
TestReplicaWithCluster.HTU2 |
private static HBaseTestingUtility |
TestAsyncTable.TEST_UTIL |
private static HBaseTestingUtility |
TestClientSideRegionScanner.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncTableScannerCloseWhileSuspending.TEST_UTIL |
protected static HBaseTestingUtility |
TestAppendFromClientSide.TEST_UTIL |
private static HBaseTestingUtility |
TestFastFail.TEST_UTIL |
private static HBaseTestingUtility |
TestSeparateClientZKCluster.TEST_UTIL |
private static HBaseTestingUtility |
TestCheckAndMutate.TEST_UTIL |
private static HBaseTestingUtility |
TestEnableTable.TEST_UTIL |
private static HBaseTestingUtility |
TestTimestampsFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestFlushFromClient.TEST_UTIL |
protected static HBaseTestingUtility |
TestIllegalTableDescriptor.TEST_UTIL |
private static HBaseTestingUtility |
TestHTableNoncedRetry.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncBufferMutator.TEST_UTIL |
private static HBaseTestingUtility |
TestGetScanPartialResult.TEST_UTIL |
protected static HBaseTestingUtility |
AbstractTestScanCursor.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncTableLocateRegionForDeletedTable.TEST_UTIL |
private static HBaseTestingUtility |
TestScannerTimeout.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncTableBatch.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionLocationCaching.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncTableNoncedRetry.TEST_UTIL |
private static HBaseTestingUtility |
TestSmallReversedScanner.TEST_UTIL |
protected static HBaseTestingUtility |
TestIncrementsFromClientSide.TEST_UTIL |
private static HBaseTestingUtility |
TestSplitOrMergeStatus.TEST_UTIL |
protected static HBaseTestingUtility |
TestFromClientSideNoCodec.TEST_UTIL |
private static HBaseTestingUtility |
TestSplitOrMergeAtTableLevel.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncNonMetaRegionLocator.TEST_UTIL |
private static HBaseTestingUtility |
TestTableFavoredNodes.TEST_UTIL |
private static HBaseTestingUtility |
TestHTableMultiplexerFlushCache.TEST_UTIL |
private static HBaseTestingUtility |
TestServerBusyException.TEST_UTIL |
private static HBaseTestingUtility |
TestHbck.TEST_UTIL |
private static HBaseTestingUtility |
TestMultiRespectsLimits.TEST_UTIL |
protected static HBaseTestingUtility |
RestoreSnapshotFromClientTestBase.TEST_UTIL |
private static HBaseTestingUtility |
TestMalformedCellFromClient.TEST_UTIL |
private static HBaseTestingUtility |
TestRawAsyncTablePartialScan.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncTableScanRenewLease.TEST_UTIL |
private static HBaseTestingUtility |
TestCatalogReplicaLoadBalanceSimpleSelector.TEST_UTIL |
protected static HBaseTestingUtility |
TestAvoidCellReferencesIntoShippedBlocks.TEST_UTIL |
protected static HBaseTestingUtility |
TestAsyncAdminBase.TEST_UTIL |
protected static HBaseTestingUtility |
TestSizeFailures.TEST_UTIL |
private static HBaseTestingUtility |
TestFromClientSide3.TEST_UTIL |
private static HBaseTestingUtility |
TestFailedMetaReplicaAssigment.TEST_UTIL |
private static HBaseTestingUtility |
TestConnectionImplementation.TEST_UTIL |
private static HBaseTestingUtility |
TestScannersFromClientSide.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncAdminBuilder.TEST_UTIL |
private static HBaseTestingUtility |
TestClientTimeouts.TEST_UTIL |
protected static HBaseTestingUtility |
TestAdminBase.TEST_UTIL |
protected static HBaseTestingUtility |
CloneSnapshotFromClientTestBase.TEST_UTIL |
private static HBaseTestingUtility |
TestResultFromCoprocessor.TEST_UTIL |
private static HBaseTestingUtility |
TestMetaRegionLocationCache.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncNonMetaRegionLocatorConcurrenyLimit.TEST_UTIL |
private static HBaseTestingUtility |
TestRequestTooBigException.TEST_UTIL |
private static HBaseTestingUtility |
TestMultipleTimestamps.TEST_UTIL |
private static HBaseTestingUtility |
TestUpdateConfiguration.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncSingleRequestRpcRetryingCaller.TEST_UTIL |
private static HBaseTestingUtility |
TestIntraRowPagination.TEST_UTIL |
(package private) static HBaseTestingUtility |
FromClientSideBase.TEST_UTIL |
private static HBaseTestingUtility |
TestCheckAndMutateWithByteBuff.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterRegistry.TEST_UTIL |
private static HBaseTestingUtility |
TestDropTimeoutRequest.TEST_UTIL |
protected static HBaseTestingUtility |
TestFromClientSideScanExcpetion.TEST_UTIL |
private static HBaseTestingUtility |
TestGetScanColumnsWithNewVersionBehavior.TEST_UTIL |
protected static HBaseTestingUtility |
AbstractTestCITimeout.TEST_UTIL |
protected static HBaseTestingUtility |
AbstractTestAsyncTableRegionReplicasRead.TEST_UTIL |
protected static HBaseTestingUtility |
MetaWithReplicasTestBase.TEST_UTIL |
private static HBaseTestingUtility |
TestClientScannerTimeouts.TEST_UTIL |
protected static HBaseTestingUtility |
TestBlockEvictionFromClient.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncTableLocatePrefetch.TEST_UTIL |
private static HBaseTestingUtility |
TestScannersFromClientSide2.TEST_UTIL |
protected static HBaseTestingUtility |
SnapshotWithAclTestBase.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncTableGetMultiThreaded.TEST_UTIL |
private static HBaseTestingUtility |
TestHTableMultiplexer.TEST_UTIL |
private static HBaseTestingUtility |
TestMetaCache.TEST_UTIL |
(package private) static HBaseTestingUtility |
TestZKConnectionRegistry.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncRegionLocator.TEST_UTIL |
private static HBaseTestingUtility |
TestMultiActionMetricsFromClient.TEST_UTIL |
(package private) static HBaseTestingUtility |
TestResultSizeEstimation.TEST_UTIL |
private static HBaseTestingUtility |
TestLeaseRenewal.TEST_UTIL |
private static HBaseTestingUtility |
TestPutWithDelete.TEST_UTIL |
protected static HBaseTestingUtility |
AbstractTestShell.TEST_UTIL |
private static HBaseTestingUtility |
TestAsyncReplicationAdminApiWithClusters.TEST_UTIL2 |
private HBaseTestingUtility |
TestAsyncMetaRegionLocator.Setup.testUtil |
private static HBaseTestingUtility |
TestClientOperationInterrupt.util |
private static HBaseTestingUtility |
TestRawAsyncTableLimitedScanWithFilter.UTIL |
private static HBaseTestingUtility |
TestAlwaysSetScannerId.UTIL |
protected static HBaseTestingUtility |
TestSnapshotCloneIndependence.UTIL |
private static HBaseTestingUtility |
TestGetProcedureResult.UTIL |
private static HBaseTestingUtility |
TestAsyncClientPauseForServerOverloaded.UTIL |
protected static HBaseTestingUtility |
AbstractTestRegionLocator.UTIL |
private static HBaseTestingUtility |
TestAsyncTableScanMetrics.UTIL |
private static HBaseTestingUtility |
TestTableOperationException.UTIL |
private static HBaseTestingUtility |
TestMultiParallel.UTIL |
private HBaseTestingUtility |
TestTableSnapshotScanner.UTIL |
private static HBaseTestingUtility |
TestAsyncTableBatchRetryImmediately.UTIL |
private static HBaseTestingUtility |
TestMvccConsistentScanner.UTIL |
private static HBaseTestingUtility |
TestShortCircuitConnection.UTIL |
protected static HBaseTestingUtility |
TestSnapshotFromClient.UTIL |
private static HBaseTestingUtility |
TestSnapshotMetadata.UTIL |
protected static HBaseTestingUtility |
ClientPushbackTestBase.UTIL |
protected static HBaseTestingUtility |
TestSnapshotTemporaryDirectory.UTIL |
private static HBaseTestingUtility |
TestAsyncTableRSCrashPublish.UTIL |
private static HBaseTestingUtility |
TestAsyncTableScanException.UTIL |
private static HBaseTestingUtility |
TestAsyncTableUseMetaReplicas.UTIL |
private static HBaseTestingUtility |
TestLimitedScanWithFilter.UTIL |
private static HBaseTestingUtility |
TestScanWithoutFetchingData.UTIL |
private static HBaseTestingUtility |
TestRpcConnectionRegistry.UTIL |
protected HBaseTestingUtility |
TestServerLoadDurability.utility |
Modifier and Type | Method and Description |
---|---|
HBaseTestingUtility |
TestAsyncMetaRegionLocator.Setup.getTestingUtility() |
Modifier and Type | Method and Description |
---|---|
protected static void |
AbstractTestUpdateConfiguration.addResourceToRegionServerConfiguration(HBaseTestingUtility testUtil) |
static void |
RegionReplicaTestHelper.assertReplicaDistributed(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.Table t) |
static void |
TestTableSnapshotScanner.blockUntilSplitFinished(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
int expectedRegionSize) |
static void |
TestEnableTable.createTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.HTableDescriptor htd,
byte[][] splitKeys) |
static void |
TestTableSnapshotScanner.createTableAndSnapshot(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
int numRegions) |
static void |
TestEnableTable.deleteTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.TableName tableName) |
(package private) static Optional<org.apache.hadoop.hbase.ServerName> |
RegionReplicaTestHelper.getRSCarryingReplica(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
int replicaId) |
(package private) static org.apache.hadoop.hbase.ServerName |
RegionReplicaTestHelper.moveRegion(HBaseTestingUtility util,
org.apache.hadoop.hbase.HRegionLocation currentLoc)
Return the new location.
|
protected static void |
AbstractTestUpdateConfiguration.setUpConfigurationFiles(HBaseTestingUtility testUtil) |
static void |
TestMetaWithReplicasShutdownHandling.shutdownMetaAndDoValidations(HBaseTestingUtility util) |
(package private) static void |
RegionReplicaTestHelper.testLocator(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
RegionReplicaTestHelper.Locator locator) |
private void |
TestTableSnapshotScanner.testScanner(HBaseTestingUtility util,
String snapshotName,
int numRegions,
boolean shutdownCluster) |
protected void |
TestMobRestoreSnapshotFromClientAfterSplittingRegions.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestMobRestoreSnapshotFromClientClone.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
RestoreSnapshotFromClientTestBase.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestMobRestoreSnapshotFromClientAfterTruncate.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
CloneSnapshotFromClientTestBase.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestMobCloneSnapshotFromClientNormal.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestMobRestoreSnapshotFromClientSchemaChange.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestMobRestoreSnapshotFromClientGetCompactionState.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestMobRestoreSnapshotFromClientSimple.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
(package private) static void |
RegionReplicaTestHelper.waitUntilAllMetaReplicasAreReady(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.ConnectionRegistry registry) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestHttpProxyExample.UTIL |
private static HBaseTestingUtility |
TestAsyncClientExample.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestReplicationAdmin.TEST_UTIL |
private static HBaseTestingUtility |
TestBadReplicationPeer.TEST_UTIL |
private static HBaseTestingUtility |
TestReplicationAdminWithTwoDifferentZKClusters.utility1 |
private static HBaseTestingUtility |
TestReplicationAdminWithTwoDifferentZKClusters.utility2 |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestConstraint.util |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestCoprocessorShortCircuitRPC.HTU |
(package private) HBaseTestingUtility |
TestCoreRegionCoprocessor.HTU |
private static HBaseTestingUtility |
TestCoreMasterCoprocessor.HTU |
private static HBaseTestingUtility |
TestCoreRegionServerCoprocessor.HTU |
private static HBaseTestingUtility |
TestRegionServerCoprocessorExceptionWithAbort.TEST_UTIL |
private static HBaseTestingUtility |
TestCoprocessorInterface.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionObserverStacking.TEST_UTIL |
private static HBaseTestingUtility |
TestWALObserver.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionServerCoprocessorExceptionWithRemove.TEST_UTIL |
private static HBaseTestingUtility |
TestNegativeMemStoreSizeWithSlowCoprocessor.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionObserverInterface.util |
private static HBaseTestingUtility |
TestIncrementAndAppendWithNullResult.util |
private static HBaseTestingUtility |
TestRegionObserverForAddingMutationsFromCoprocessors.util |
private static HBaseTestingUtility |
TestAppendTimeRange.util |
private static HBaseTestingUtility |
TestRegionObserverBypass.util |
private static HBaseTestingUtility |
TestIncrementTimeRange.util |
private static HBaseTestingUtility |
TestPassCustomCellViaRegionObserver.UTIL |
private static HBaseTestingUtility |
TestCoprocessorMetrics.UTIL |
private static HBaseTestingUtility |
TestMasterCoprocessorExceptionWithAbort.UTIL |
(package private) HBaseTestingUtility |
TestMasterCoprocessorExceptionWithAbort.CreateTableThread.UTIL |
private static HBaseTestingUtility |
TestMasterObserverToModifyTableSchema.UTIL |
private static HBaseTestingUtility |
TestMetaTableMetrics.UTIL |
private static HBaseTestingUtility |
TestOpenTableInCoprocessor.UTIL |
private static HBaseTestingUtility |
TestMasterObserver.UTIL |
private static HBaseTestingUtility |
TestRegionObserverScannerOpenHook.UTIL |
private static HBaseTestingUtility |
TestPostIncrementAndAppendBeforeWAL.UTIL |
private static HBaseTestingUtility |
TestCoprocessorStop.UTIL |
private static HBaseTestingUtility |
TestMasterCoprocessorExceptionWithRemove.UTIL |
Constructor and Description |
---|
CreateTableThread(HBaseTestingUtility UTIL) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestRefreshHFilesBase.HTU |
private static HBaseTestingUtility |
TestZooKeeperScanPolicyObserver.UTIL |
protected static HBaseTestingUtility |
WriteHeavyIncrementObserverTestBase.UTIL |
private static HBaseTestingUtility |
TestValueReplacingCompaction.UTIL |
private static HBaseTestingUtility |
TestScanModifyingObserver.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestFilterListOrOperatorWithBlkCnt.TEST_UTIL |
private static HBaseTestingUtility |
TestColumnPrefixFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestFilterListOnMini.TEST_UTIL |
private static HBaseTestingUtility |
TestMultipleColumnPrefixFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestFiltersWithBinaryComponentComparator.TEST_UTIL |
private static HBaseTestingUtility |
FilterTestingCluster.TEST_UTIL |
private static HBaseTestingUtility |
TestQualifierFilterWithEmptyQualifier.TEST_UTIL |
private static HBaseTestingUtility |
TestFuzzyRowFilterEndToEnd.TEST_UTIL |
private static HBaseTestingUtility |
TestFilterWrapper.TEST_UTIL |
private static HBaseTestingUtility |
TestInvocationRecordFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestDependentColumnFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestFuzzyRowAndColumnRangeFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestSeekHints.TEST_UTIL |
private static HBaseTestingUtility |
TestColumnRangeFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestFilterFromRegionSide.TEST_UTIL |
private static HBaseTestingUtility |
TestMultiRowRangeFilter.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
private HBaseTestingUtility |
TestBlockReorderMultiBlocks.htu |
private HBaseTestingUtility |
TestBlockReorderBlockLocation.htu |
private HBaseTestingUtility |
TestBlockReorder.htu |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestInfoServersACL.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestHalfStoreFileReader.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
HFileTestBase.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestZstdDictionarySplitMerge.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestChangingEncoding.TEST_UTIL |
private HBaseTestingUtility |
TestSeekBeforeWithReverseScan.testUtil |
private HBaseTestingUtility |
TestEncodedSeekers.testUtil |
Modifier and Type | Field and Description |
---|---|
private HBaseTestingUtility |
TestScannerFromBucketCache.test_util |
private static HBaseTestingUtility |
TestScannerSelectionUsingTTL.TEST_UTIL |
private static HBaseTestingUtility |
TestLazyDataBlockDecompression.TEST_UTIL |
private static HBaseTestingUtility |
TestPrefetch.TEST_UTIL |
private static HBaseTestingUtility |
TestHFileEncryption.TEST_UTIL |
private static HBaseTestingUtility |
TestHFileWriterV3.TEST_UTIL |
private static HBaseTestingUtility |
TestHFileWriterV3WithDataEncoders.TEST_UTIL |
private static HBaseTestingUtility |
TestChecksum.TEST_UTIL |
private static HBaseTestingUtility |
TestSeekTo.TEST_UTIL |
private static HBaseTestingUtility |
TestSeekBeforeWithInlineBlocks.TEST_UTIL |
private HBaseTestingUtility |
TestHFileSeek.MyOptions.TEST_UTIL |
private static HBaseTestingUtility |
TestCacheOnWrite.TEST_UTIL |
private static HBaseTestingUtility |
TestBlockIOUtils.TEST_UTIL |
private static HBaseTestingUtility |
TestReseekTo.TEST_UTIL |
private static HBaseTestingUtility |
TestHFileBlockUnpack.TEST_UTIL |
private static HBaseTestingUtility |
TestHFileBlockIndex.TEST_UTIL |
private static HBaseTestingUtility |
TestHFileBlock.TEST_UTIL |
private static HBaseTestingUtility |
TestRowIndexV1DataEncoder.TEST_UTIL |
private static HBaseTestingUtility |
TestHFileReaderImpl.TEST_UTIL |
private static HBaseTestingUtility |
TestHFile.TEST_UTIL |
private HBaseTestingUtility |
TestForceCacheImportantBlocks.TEST_UTIL |
private static HBaseTestingUtility |
TestScannerSelectionUsingKeyRange.TEST_UTIL |
private HBaseTestingUtility |
TestHFileInlineToRootChunkConversion.testUtil |
private HBaseTestingUtility |
TestFixedFileTrailer.util |
private static HBaseTestingUtility |
TestHFileScannerImplReferenceCount.UTIL |
private static HBaseTestingUtility |
TestCombinedBlockCache.UTIL |
private static HBaseTestingUtility |
TestHFilePrettyPrinter.UTIL |
Modifier and Type | Method and Description |
---|---|
private static org.apache.hadoop.hbase.regionserver.HRegion |
TestScannerFromBucketCache.initHRegion(org.apache.hadoop.hbase.TableName tableName,
byte[] startKey,
byte[] stopKey,
String callingMethod,
org.apache.hadoop.conf.Configuration conf,
HBaseTestingUtility testUtil,
boolean isReadOnly,
byte[]... families) |
private static org.apache.hadoop.hbase.regionserver.HRegion |
TestScannerFromBucketCache.initHRegion(org.apache.hadoop.hbase.TableName tableName,
String callingMethod,
org.apache.hadoop.conf.Configuration conf,
HBaseTestingUtility test_util,
byte[]... families) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestBucketCache.HBASE_TESTING_UTILITY |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestNettyRpcServer.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterFifoRpcScheduler.TEST_UTIL |
protected static HBaseTestingUtility |
TestSimpleRpcServer.TEST_UTIL |
private static HBaseTestingUtility |
TestRpcClientLeaks.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestTableOutputFormatConnectionExhaust.UTIL |
private static HBaseTestingUtility |
TestTableMapReduceUtil.UTIL |
private static HBaseTestingUtility |
TestTableInputFormat.UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
TestTableSnapshotInputFormat.doTestWithMapReduce(HBaseTestingUtility util,
org.apache.hadoop.hbase.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,
org.apache.hadoop.hbase.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) |
Modifier and Type | Field and Description |
---|---|
static HBaseTestingUtility |
MultiTableInputFormatTestBase.TEST_UTIL |
private static HBaseTestingUtility |
TestWALRecordReader.TEST_UTIL |
(package private) static HBaseTestingUtility |
TestTableInputFormatScanBase.TEST_UTIL |
private static HBaseTestingUtility |
TestRowCounter.TEST_UTIL |
private static HBaseTestingUtility |
TestHashTable.TEST_UTIL |
private static HBaseTestingUtility |
TestCellBasedWALPlayer2.TEST_UTIL |
protected static HBaseTestingUtility |
TestSimpleTotalOrderPartitioner.TEST_UTIL |
private static HBaseTestingUtility |
TestWALPlayer.TEST_UTIL |
private static HBaseTestingUtility |
TestCopyTable.TEST_UTIL |
private static HBaseTestingUtility |
TestSyncTable.TEST_UTIL |
private static HBaseTestingUtility |
TestTableRecordReader.TEST_UTIL |
protected static HBaseTestingUtility |
TestImportTSVWithTTLs.util |
private HBaseTestingUtility |
TestCellBasedHFileOutputFormat2.util |
private HBaseTestingUtility |
TestHFileOutputFormat2.util |
protected static HBaseTestingUtility |
TestImportTSVWithOperationAttributes.util |
protected static HBaseTestingUtility |
TestImportTSVWithVisibilityLabels.util |
protected static HBaseTestingUtility |
TestImportTsv.util |
private static HBaseTestingUtility |
TestMapReduceExamples.util |
private static HBaseTestingUtility |
TestHRegionPartitioner.UTIL |
private static HBaseTestingUtility |
TestMultithreadedTableMapper.UTIL |
private static HBaseTestingUtility |
TestTimeRangeMapRed.UTIL |
protected static HBaseTestingUtility |
TestCellBasedImportExport2.UTIL |
protected HBaseTestingUtility |
TableSnapshotInputFormatTestBase.UTIL |
protected static HBaseTestingUtility |
TestImportExport.UTIL |
private static HBaseTestingUtility |
TestCellCounter.UTIL |
private static HBaseTestingUtility |
TestTableInputFormat.UTIL |
protected static HBaseTestingUtility |
TestTableMapReduceBase.UTIL |
Modifier and Type | Method and Description |
---|---|
protected static void |
TableSnapshotInputFormatTestBase.createTableAndSnapshot(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
int numRegions) |
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) |
private org.apache.hadoop.util.Tool |
TestImportTSVWithOperationAttributes.doMROnTableTest(HBaseTestingUtility util,
String family,
String data,
String[] args,
int valueMultiplier,
boolean dataAvailable)
Run an ImportTsv job and perform basic validation on the results.
|
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.
|
protected static org.apache.hadoop.util.Tool |
TestImportTsv.doMROnTableTest(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName table,
String family,
String data,
Map<String,String> args) |
protected static org.apache.hadoop.util.Tool |
TestImportTsv.doMROnTableTest(HBaseTestingUtility util,
org.apache.hadoop.hbase.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.
|
static void |
TestTableSnapshotInputFormat.doTestWithMapReduce(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
org.apache.hadoop.fs.Path tableDir,
int numRegions,
int numSplitsPerRegion,
int expectedNumSplits,
boolean shutdownCluster) |
private static Closeable |
TestTableMapReduceUtil.startSecureMiniCluster(HBaseTestingUtility util,
org.apache.hadoop.minikdc.MiniKdc kdc,
String principal) |
protected void |
TableSnapshotInputFormatTestBase.testWithMapReduce(HBaseTestingUtility util,
String snapshotName,
int numRegions,
int numSplitsPerRegion,
int expectedNumSplits,
boolean shutdownCluster) |
protected abstract void |
TableSnapshotInputFormatTestBase.testWithMapReduceImpl(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
org.apache.hadoop.fs.Path tableDir,
int numRegions,
int numSplitsPerRegion,
int expectedNumSplits,
boolean shutdownCluster) |
protected void |
TestTableSnapshotInputFormat.testWithMapReduceImpl(HBaseTestingUtility util,
org.apache.hadoop.hbase.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) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestRegionsRecoveryChore.HBASE_TESTING_UTILITY |
private static HBaseTestingUtility |
TestRegionsRecoveryConfigManager.HBASE_TESTING_UTILITY |
private HBaseTestingUtility |
TestMasterShutdown.htu |
private static HBaseTestingUtility |
TestSplitWALManager.TEST_UTIL |
private static HBaseTestingUtility |
TestSplitLogManager.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterBalancerNPE.TEST_UTIL |
private static HBaseTestingUtility |
TestMaster.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionPlacement2.TEST_UTIL |
private static HBaseTestingUtility |
TestAssignmentManagerMetrics.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterDryRunBalancer.TEST_UTIL |
private static HBaseTestingUtility |
TestDeadServer.TEST_UTIL |
private static HBaseTestingUtility |
TestGetReplicationLoad.TEST_UTIL |
private static HBaseTestingUtility |
AbstractTestDLS.TEST_UTIL |
private HBaseTestingUtility |
TestBalancer.TEST_UTIL |
private static HBaseTestingUtility |
TestActiveMasterManager.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterRepairMode.TEST_UTIL |
private static HBaseTestingUtility |
TestRollingRestart.TEST_UTIL |
private HBaseTestingUtility |
TestMirroringTableStateManager.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterTransitions.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionPlacement.TEST_UTIL |
private static HBaseTestingUtility |
TestMetaShutdownHandler.TEST_UTIL |
private static HBaseTestingUtility |
TestRecreateCluster.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterMetricsWrapper.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterBalanceThrottling.TEST_UTIL |
private static HBaseTestingUtility |
TestClientMetaServiceRPCs.TEST_UTIL |
protected static HBaseTestingUtility |
TestWarmupRegion.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterMetrics.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterOperationsForRegionReplicas.TEST_UTIL |
private HBaseTestingUtility |
TestTableStateManager.TEST_UTIL |
private static HBaseTestingUtility |
TestHMasterCommandLine.TESTING_UTIL |
private HBaseTestingUtility |
TestHMasterRPCException.testUtil |
private HBaseTestingUtility |
TestGetLastFlushedSequenceId.testUtil |
private HBaseTestingUtility |
TestGetInfoPort.testUtil |
private static HBaseTestingUtility |
TestMasterNoCluster.TESTUTIL |
private static HBaseTestingUtility |
TestRestartWithEmptyWALDirectory.UTIL |
private static HBaseTestingUtility |
TestUnknownServers.UTIL |
protected static HBaseTestingUtility |
TestMergeTableRegionsWhileRSCrash.UTIL |
private static HBaseTestingUtility |
TestMasterFileSystemWithStoreFileTracking.UTIL |
private static HBaseTestingUtility |
TestMasterChoreScheduled.UTIL |
private static HBaseTestingUtility |
TestServerCrashProcedureStuck.UTIL |
private static HBaseTestingUtility |
TestMetaAssignmentWithStopMaster.UTIL |
private static HBaseTestingUtility |
TestNewStartedRegionServerVersion.UTIL |
private static HBaseTestingUtility |
TestMasterHandlerFullWhenTransitRegion.UTIL |
protected static HBaseTestingUtility |
TestSplitRegionWhileRSCrash.UTIL |
protected HBaseTestingUtility |
AbstractTestRestartCluster.UTIL |
private static HBaseTestingUtility |
TestLoadProcedureError.UTIL |
private static HBaseTestingUtility |
TestShutdownBackupMaster.UTIL |
private static HBaseTestingUtility |
TestShutdownWithNoRegionServer.UTIL |
private static HBaseTestingUtility |
TestMasterAbortAndRSGotKilled.UTIL |
private static HBaseTestingUtility |
TestMasterFileSystem.UTIL |
private static HBaseTestingUtility |
TestRegionPlansWithThrottle.UTIL |
private static HBaseTestingUtility |
TestMasterFileSystemWithWALDir.UTIL |
private static HBaseTestingUtility |
TestServerCrashProcedureCarryingMetaStuck.UTIL |
private static HBaseTestingUtility |
TestMasterNotCarryTable.UTIL |
private static HBaseTestingUtility |
TestMigrateAndMirrorMetaLocations.UTIL |
private static HBaseTestingUtility |
TestCloseAnOpeningRegion.UTIL |
Modifier and Type | Method and Description |
---|---|
private void |
TestRecreateCluster.prepareDataBeforeRecreate(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.TableName tableName) |
private void |
TestSplitWALManager.splitLogsTestHelper(HBaseTestingUtility testUtil) |
private void |
TestRecreateCluster.validateDataAfterRecreate(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.TableName tableName) |
private void |
TestMasterOperationsForRegionReplicas.validateFromSnapshotFromMeta(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName table,
int numRegions,
int numReplica,
org.apache.hadoop.hbase.client.Connection connection) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestRegionReplicaSplit.HTU |
private static HBaseTestingUtility |
TestRegionBypass.TEST_UTIL |
protected HBaseTestingUtility |
TestAssignmentManagerBase.util |
protected HBaseTestingUtility |
TestDeadServerMetricRegionChore.util |
private static HBaseTestingUtility |
TestRaceBetweenSCPAndDTP.UTIL |
private static HBaseTestingUtility |
TestReportOnlineRegionsRace.UTIL |
private static HBaseTestingUtility |
TestMergeTableRegionsProcedure.UTIL |
private static HBaseTestingUtility |
TestAssignmentManagerUtil.UTIL |
private static HBaseTestingUtility |
TestReportRegionStateTransitionRetry.UTIL |
private static HBaseTestingUtility |
TestOpenRegionProcedureHang.UTIL |
private static HBaseTestingUtility |
TestExceptionInAssignRegion.UTIL |
private static HBaseTestingUtility |
TestCloseRegionWhileRSCrash.UTIL |
private static HBaseTestingUtility |
TestReportRegionStateTransitionFromDeadServer.UTIL |
private static HBaseTestingUtility |
TestRaceBetweenSCPAndTRSP.UTIL |
private static HBaseTestingUtility |
TestExceptionInUnassignedRegion.UTIL |
protected static HBaseTestingUtility |
TestModifyTableWhileMerging.UTIL |
protected static HBaseTestingUtility |
TestRegionStates.UTIL |
private static HBaseTestingUtility |
TestTransitRegionStateProcedure.UTIL |
private static HBaseTestingUtility |
TestAssignRegionToUninitializedRegionServer.UTIL |
protected static HBaseTestingUtility |
TestSplitTableRegionProcedure.UTIL |
protected static HBaseTestingUtility |
TestRegionSplit.UTIL |
private static HBaseTestingUtility |
TestWakeUpUnexpectedProcedure.UTIL |
private static HBaseTestingUtility |
TestSCPGetRegionsRace.UTIL |
private HBaseTestingUtility |
TestRegionMoveAndAbandon.UTIL |
private static HBaseTestingUtility |
TestRegionAssignedToMultipleRegionServers.UTIL |
protected static HBaseTestingUtility |
TestMasterAbortWhileMergingTable.UTIL |
private static HBaseTestingUtility |
TestRogueRSAssignment.UTIL |
protected static HBaseTestingUtility |
TestRegionSplitAndSeparateChildren.UTIL |
private static HBaseTestingUtility |
TestOpenRegionProcedureBackoff.UTIL |
private HBaseTestingUtility |
TestAssignmentOnRSCrash.UTIL |
private static HBaseTestingUtility |
TestAssignmentManagerLoadMetaRegionState.UTIL |
private static HBaseTestingUtility |
TestRegionStateStore.UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
AssignmentTestingUtil.crashRs(HBaseTestingUtility util,
org.apache.hadoop.hbase.ServerName serverName,
boolean kill) |
static org.apache.hadoop.hbase.ServerName |
AssignmentTestingUtil.crashRsWithRegion(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.RegionInfo hri,
boolean kill) |
private static org.apache.hadoop.hbase.master.HMaster |
AssignmentTestingUtil.getMaster(HBaseTestingUtility util) |
static Set<org.apache.hadoop.hbase.client.RegionInfo> |
AssignmentTestingUtil.getMetaRegions(HBaseTestingUtility util) |
static org.apache.hadoop.hbase.ServerName |
AssignmentTestingUtil.getServerHoldingRegion(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.RegionInfo hri) |
static void |
AssignmentTestingUtil.insertData(HBaseTestingUtility UTIL,
org.apache.hadoop.hbase.TableName tableName,
int rowCount,
int startRowNum,
boolean flushOnce,
String... cfs) |
static void |
AssignmentTestingUtil.insertData(HBaseTestingUtility UTIL,
org.apache.hadoop.hbase.TableName tableName,
int rowCount,
int startRowNum,
String... cfs) |
static boolean |
AssignmentTestingUtil.isServerHoldingMeta(HBaseTestingUtility util,
org.apache.hadoop.hbase.ServerName serverName) |
static void |
AssignmentTestingUtil.killRs(HBaseTestingUtility util,
org.apache.hadoop.hbase.ServerName serverName) |
static void |
AssignmentTestingUtil.stopRs(HBaseTestingUtility util,
org.apache.hadoop.hbase.ServerName serverName) |
static void |
AssignmentTestingUtil.waitForRegionToBeInTransition(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.RegionInfo hri) |
static void |
AssignmentTestingUtil.waitForRsToBeDead(HBaseTestingUtility util,
org.apache.hadoop.hbase.ServerName serverName) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestStochasticLoadBalancerHeterogeneousCost.HTU |
private static HBaseTestingUtility |
TestStochasticLoadBalancerHeterogeneousCostRules.HTU |
private static HBaseTestingUtility |
TestRegionLocationFinder.TEST_UTIL |
private static HBaseTestingUtility |
TestFavoredStochasticLoadBalancer.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionsOnMasterOptions.TEST_UTIL |
private static HBaseTestingUtility |
TestFavoredStochasticBalancerPickers.TEST_UTIL |
private static HBaseTestingUtility |
TestFavoredNodeTableImport.UTIL |
private static HBaseTestingUtility |
TestBalancerStatusTagInJMXMetrics.UTIL |
private static HBaseTestingUtility |
TestStochasticBalancerJmxMetrics.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestSnapshotCleanerChore.HBASE_TESTING_UTILITY |
private static HBaseTestingUtility |
TestCleanerClearHFiles.TEST_UTIL |
private static HBaseTestingUtility |
TestLogsCleaner.TEST_UTIL |
private static HBaseTestingUtility |
TestReplicationHFileCleaner.TEST_UTIL |
private static HBaseTestingUtility |
TestHFileLinkCleaner.TEST_UTIL |
private static HBaseTestingUtility |
TestReplicationBarrierCleaner.UTIL |
private static HBaseTestingUtility |
TestHFileCleaner.UTIL |
private static HBaseTestingUtility |
TestSnapshotFromMaster.UTIL |
private static HBaseTestingUtility |
TestCleanerChore.UTIL |
Modifier and Type | Method and Description |
---|---|
private org.apache.hadoop.hbase.client.Table |
TestCleanerClearHFiles.createTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestCatalogJanitor.HTU |
private static HBaseTestingUtility |
TestMetaFixer.TEST_UTIL |
private static HBaseTestingUtility |
TestCatalogJanitorInMemoryStates.TEST_UTIL |
private static HBaseTestingUtility |
TestCatalogJanitorCluster.TEST_UTIL |
Modifier and Type | Method and Description |
---|---|
private String |
TestCatalogJanitor.setRootDirAndCleanIt(HBaseTestingUtility htu,
String subdir) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestLockManager.UTIL |
protected static HBaseTestingUtility |
TestLockProcedure.UTIL |
Modifier and Type | Field and Description |
---|---|
private HBaseTestingUtility |
TestInitializeStoreFileTracker.HTU |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestSimpleRegionNormalizerOnCluster.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionNormalizerManagerConfigurationObserver.testUtil |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestSplitWALProcedure.TEST_UTIL |
private static HBaseTestingUtility |
TestTableDescriptorModificationFromClient.TEST_UTIL |
private static HBaseTestingUtility |
TestDeleteColumnFamilyProcedureFromClient.TEST_UTIL |
protected HBaseTestingUtility |
TestServerRemoteProcedure.util |
protected HBaseTestingUtility |
TestSCPBase.util |
protected static HBaseTestingUtility |
TestProcedureAdmin.UTIL |
protected static HBaseTestingUtility |
TestMasterProcedureEvents.UTIL |
protected static HBaseTestingUtility |
MasterProcedureSchedulerPerformanceEvaluation.UTIL |
private static HBaseTestingUtility |
TestSchedulerQueueDeadLock.UTIL |
protected static HBaseTestingUtility |
TestMasterObserverPostCalls.UTIL |
protected static HBaseTestingUtility |
TestSafemodeBringsDownMaster.UTIL |
private static HBaseTestingUtility |
TestIgnoreUnknownFamily.UTIL |
private static HBaseTestingUtility |
TestCreateTableProcedureMuitipleRegions.UTIL |
protected static HBaseTestingUtility |
TestCreateNamespaceProcedure.UTIL |
private static HBaseTestingUtility |
TestProcedurePriority.UTIL |
protected static HBaseTestingUtility |
MasterFailoverWithProceduresTestBase.UTIL |
private static HBaseTestingUtility |
TestReopenTableRegionsProcedureInfiniteLoop.UTIL |
protected static HBaseTestingUtility |
TestTableDDLProcedureBase.UTIL |
private static HBaseTestingUtility |
TestCreateTableNoRegionServer.UTIL |
protected static HBaseTestingUtility |
TestDeleteNamespaceProcedure.UTIL |
protected static HBaseTestingUtility |
TestModifyNamespaceProcedure.UTIL |
private static HBaseTestingUtility |
TestReopenTableRegionsProcedureBackoff.UTIL |
protected static HBaseTestingUtility |
TestWALProcedureStoreOnHDFS.UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
MasterProcedureTestingUtility.masterFailover(HBaseTestingUtility testUtil) |
protected static void |
MasterFailoverWithProceduresTestBase.testRecoveryAndDoubleExecution(HBaseTestingUtility testUtil,
long procId,
int lastStepBeforeFailover) |
static void |
MasterProcedureTestingUtility.waitBackupMaster(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.master.HMaster oldMaster) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestChangeSFTForMasterRegion.UTIL |
private static HBaseTestingUtility |
TestMasterRegionOnTwoFileSystems.WAL_UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestModifyPeerProcedureRetryBackoff.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestSnapshotHFileCleaner.TEST_UTIL |
private static HBaseTestingUtility |
TestSnapshotManager.UTIL |
protected static HBaseTestingUtility |
TestSnapshotFileCache.UTIL |
private static HBaseTestingUtility |
TestTakeSnapshotHandler.UTIL |
private static HBaseTestingUtility |
TestSnapshotWhileRSCrashes.UTIL |
Modifier and Type | Field and Description |
---|---|
private HBaseTestingUtility |
MobStressToolRunner.HTU |
protected static HBaseTestingUtility |
TestMobCompactionWithDefaults.HTU |
private HBaseTestingUtility |
TestMobFileCleanerChore.HTU |
private HBaseTestingUtility |
TestRSMobFileCleanerChore.HTU |
private static HBaseTestingUtility |
TestExpiredMobFileCleaner.TEST_UTIL |
private static HBaseTestingUtility |
TestMobFile.TEST_UTIL |
private static HBaseTestingUtility |
TestDefaultMobStoreFlusher.TEST_UTIL |
private static HBaseTestingUtility |
TestMobDataBlockEncoding.TEST_UTIL |
private static HBaseTestingUtility |
TestCachedMobFile.TEST_UTIL |
private static HBaseTestingUtility |
TestMobStoreScanner.TEST_UTIL |
private HBaseTestingUtility |
TestMobFileCache.UTIL |
private static HBaseTestingUtility |
TestMobWithByteBuffAllocator.UTIL |
private static HBaseTestingUtility |
TestMobStoreCompaction.UTIL |
Modifier and Type | Method and Description |
---|---|
static int |
MobTestUtil.countMobRows(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.Table table)
Gets the number of rows in the given table.
|
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestNamedQueueRecorder.HBASE_TESTING_UTILITY |
private static HBaseTestingUtility |
TestSlowLogAccessor.HBASE_TESTING_UTILITY |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestNamespaceAuditor.UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
TestNamespaceAuditor.waitForQuotaInitialize(HBaseTestingUtility util) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestFailedProcCleanup.TEST_UTIL |
private static HBaseTestingUtility |
TestProcedureManager.util |
private static HBaseTestingUtility |
TestZKProcedure.UTIL |
private static HBaseTestingUtility |
TestZKProcedureControllers.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestQuotaObserverChoreWithMiniCluster.TEST_UTIL |
private static HBaseTestingUtility |
TestQuotaTableUtil.TEST_UTIL |
private static HBaseTestingUtility |
TestQuotaThrottle.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotasWithSnapshots.TEST_UTIL |
private static HBaseTestingUtility |
TestSnapshotQuotaObserverChore.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotaIncrease.TEST_UTIL |
private static HBaseTestingUtility |
TestSuperUserQuotaPermissions.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotaOnNonExistingTables.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotaRemoval.TEST_UTIL |
private static HBaseTestingUtility |
TestQuotaObserverChoreRegionReports.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotas.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotaDropTable.TEST_UTIL |
private static HBaseTestingUtility |
TestFileArchiverNotifierImpl.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotasWithRegionReplicas.TEST_UTIL |
private static HBaseTestingUtility |
TestClusterScopeQuotaThrottle.TEST_UTIL |
private static HBaseTestingUtility |
TestQuotaStatusRPCs.TEST_UTIL |
private static HBaseTestingUtility |
TestQuotaAdmin.TEST_UTIL |
private static HBaseTestingUtility |
TestMasterQuotasObserver.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotaBasicFunctioning.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionSizeUse.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotaOnBulkLoad.TEST_UTIL |
private static HBaseTestingUtility |
TestSpaceQuotaSwitchPolicies.TEST_UTIL |
private static HBaseTestingUtility |
TestLowLatencySpaceQuotas.TEST_UTIL |
private HBaseTestingUtility |
SpaceQuotaHelperForTests.testUtil |
Modifier and Type | Method and Description |
---|---|
(package private) static void |
ThrottleQuotaTestUtil.clearQuotaCache(HBaseTestingUtility testUtil) |
private static void |
ThrottleQuotaTestUtil.triggerCacheRefresh(HBaseTestingUtility testUtil,
boolean bypass,
boolean userLimiter,
boolean tableLimiter,
boolean nsLimiter,
boolean rsLimiter,
boolean exceedThrottleQuota,
org.apache.hadoop.hbase.TableName... tables) |
(package private) static void |
ThrottleQuotaTestUtil.triggerExceedThrottleQuotaCacheRefresh(HBaseTestingUtility testUtil,
boolean exceedEnabled) |
(package private) static void |
ThrottleQuotaTestUtil.triggerNamespaceCacheRefresh(HBaseTestingUtility testUtil,
boolean bypass,
org.apache.hadoop.hbase.TableName... tables) |
(package private) static void |
ThrottleQuotaTestUtil.triggerRegionServerCacheRefresh(HBaseTestingUtility testUtil,
boolean bypass) |
(package private) static void |
ThrottleQuotaTestUtil.triggerTableCacheRefresh(HBaseTestingUtility testUtil,
boolean bypass,
org.apache.hadoop.hbase.TableName... tables) |
(package private) static void |
ThrottleQuotaTestUtil.triggerUserCacheRefresh(HBaseTestingUtility testUtil,
boolean bypass,
org.apache.hadoop.hbase.TableName... tables) |
Constructor and Description |
---|
SpaceQuotaHelperForTests(HBaseTestingUtility testUtil,
org.junit.rules.TestName testName,
AtomicLong counter) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestRegionServerOnlineConfigChange.hbaseTestingUtility |
private static HBaseTestingUtility |
TestParallelPut.HBTU |
(package private) HBaseTestingUtility |
TestKeepDeletes.hbu |
(package private) HBaseTestingUtility |
TestMinVersions.hbu |
private HBaseTestingUtility |
TestSecureBulkloadListener.htu |
private static HBaseTestingUtility |
TestRegionReplicasWithRestartScenarios.HTU |
private static HBaseTestingUtility |
TestRegionReplicaWaitForPrimaryFlushConf.HTU |
private static HBaseTestingUtility |
TestRegionOpen.HTU |
private static HBaseTestingUtility |
TestRegionServerNoMaster.HTU |
private static HBaseTestingUtility |
TestRegionReplicaFailover.HTU |
private static HBaseTestingUtility |
TestRegionReplicas.HTU |
private static HBaseTestingUtility |
TestRowTooBig.HTU |
private HBaseTestingUtility |
TestClearRegionBlockCache.HTU |
private static HBaseTestingUtility |
TestRegionReplicasAreDistributed.HTU |
private static HBaseTestingUtility |
TestRegionReplicasWithModifyTable.HTU |
private static HBaseTestingUtility |
TestSettingTimeoutOnBlockingPoint.TEST_UTIL |
private static HBaseTestingUtility |
TestWALLockup.TEST_UTIL |
private static HBaseTestingUtility |
TestCacheOnWriteInSchema.TEST_UTIL |
private static HBaseTestingUtility |
TestScannerWithBulkload.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionServerReadRequestMetrics.TEST_UTIL |
private static HBaseTestingUtility |
TestRemoveRegionMetrics.TEST_UTIL |
private static HBaseTestingUtility |
TestHRegionReplayEvents.TEST_UTIL |
private static HBaseTestingUtility |
TestMergesSplitsAddToTracker.TEST_UTIL |
private static HBaseTestingUtility |
TestHdfsSnapshotHRegion.TEST_UTIL |
private static HBaseTestingUtility |
TestEncryptionRandomKeying.TEST_UTIL |
private static HBaseTestingUtility |
TestHRegionFileSystem.TEST_UTIL |
private static HBaseTestingUtility |
TestBlocksScanned.TEST_UTIL |
(package private) static HBaseTestingUtility |
TestRegionMergeTransactionOnCluster.TEST_UTIL |
private static HBaseTestingUtility |
TestStoreScanner.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionServerScan.TEST_UTIL |
private static HBaseTestingUtility |
TestCompactionState.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionMove.TEST_UTIL |
private static HBaseTestingUtility |
TestStoreFileInfo.TEST_UTIL |
private static HBaseTestingUtility |
TestOpenRegionFailedMemoryLeak.TEST_UTIL |
private static HBaseTestingUtility |
TestBlocksRead.TEST_UTIL |
private static HBaseTestingUtility |
TestJoinedScanners.TEST_UTIL |
private static HBaseTestingUtility |
TestScanner.TEST_UTIL |
private HBaseTestingUtility |
TestClusterId.TEST_UTIL |
private static HBaseTestingUtility |
TestNewVersionBehaviorFromClientSide.TEST_UTIL |
private static HBaseTestingUtility |
TestCleanupMetaWAL.TEST_UTIL |
private static HBaseTestingUtility |
TestScanWithBloomError.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionInterrupt.TEST_UTIL |
private static HBaseTestingUtility |
TestCompactSplitThread.TEST_UTIL |
private static HBaseTestingUtility |
TestScannerHeartbeatMessages.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionServerMetrics.TEST_UTIL |
private static HBaseTestingUtility |
TestWalAndCompactingMemStoreFlush.TEST_UTIL |
private HBaseTestingUtility |
TestAtomicOperation.TEST_UTIL |
private static HBaseTestingUtility |
TestWALMonotonicallyIncreasingSeqId.TEST_UTIL |
private static HBaseTestingUtility |
TestSeekOptimizations.TEST_UTIL |
private static HBaseTestingUtility |
TestHStoreFile.TEST_UTIL |
private static HBaseTestingUtility |
TestCompoundBloomFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestEncryptionKeyRotation.TEST_UTIL |
private HBaseTestingUtility |
TestStoreFileRefresherChore.TEST_UTIL |
private static HBaseTestingUtility |
TestShortCircuitGet.TEST_UTIL |
private static HBaseTestingUtility |
TestRowPrefixBloomFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestEncryptionDisabled.TEST_UTIL |
private static HBaseTestingUtility |
TestScannerRPCScanMetrics.TEST_UTIL |
private static HBaseTestingUtility |
TestDataBlockEncodingTool.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionIncrement.TEST_UTIL |
private static HBaseTestingUtility |
TestMultiColumnScanner.TEST_UTIL |
private static HBaseTestingUtility |
TestEndToEndSplitTransaction.TEST_UTIL |
private static HBaseTestingUtility |
TestRecoveredEdits.TEST_UTIL |
private static HBaseTestingUtility |
TestNotCleanupCompactedFileWhenRegionWarmup.TEST_UTIL |
private static HBaseTestingUtility |
TestSplitLogWorker.TEST_UTIL |
private static HBaseTestingUtility |
TestScannerTimeoutHandling.TEST_UTIL |
protected static HBaseTestingUtility |
TestCompactionPolicy.TEST_UTIL |
private HBaseTestingUtility |
TestRegionServerHostname.TEST_UTIL |
protected static HBaseTestingUtility |
TestRecoveredEditsReplayAndAbort.TEST_UTIL |
private static HBaseTestingUtility |
TestFailedAppendAndSync.TEST_UTIL |
private static HBaseTestingUtility |
TestHStore.TEST_UTIL |
protected static HBaseTestingUtility |
TestHRegion.TEST_UTIL |
(package private) HBaseTestingUtility |
TestReversibleScanners.TEST_UTIL |
private static HBaseTestingUtility |
TestHRegionOnCluster.TEST_UTIL |
private static HBaseTestingUtility |
TestBulkloadBase.TEST_UTIL |
private static HBaseTestingUtility |
TestScannerWithCorruptHFile.TEST_UTIL |
private static HBaseTestingUtility |
TestCompactionWithByteBuff.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionFavoredNodes.TEST_UTIL |
private static HBaseTestingUtility |
TestTags.TEST_UTIL |
private static HBaseTestingUtility |
TestDirectStoreSplitsMerges.TEST_UTIL |
private static HBaseTestingUtility |
TestCleanupCompactedFileAfterFailover.TEST_UTIL |
private static HBaseTestingUtility |
TestStripeStoreFileManager.TEST_UTIL |
private static HBaseTestingUtility |
TestTimestampFilterSeekHint.TEST_UTIL |
private static HBaseTestingUtility |
TestPerColumnFamilyFlush.TEST_UTIL |
private static HBaseTestingUtility |
TestColumnSeeking.TEST_UTIL |
private static HBaseTestingUtility |
TestIsDeleteFailure.TEST_UTIL |
private static HBaseTestingUtility |
TestHMobStore.TEST_UTIL |
private static HBaseTestingUtility |
TestDeleteMobTable.TEST_UTIL |
private static HBaseTestingUtility |
TestStoreFileScannerWithTagCompression.TEST_UTIL |
private static HBaseTestingUtility |
TestStoreScannerClosure.TEST_UTIL |
private static HBaseTestingUtility |
TestLogRoller.TEST_UTIL |
(package private) static HBaseTestingUtility |
TestMutateRowsRecovery.TESTING_UTIL |
(package private) static HBaseTestingUtility |
TestSplitTransactionOnCluster.TESTING_UTIL |
private HBaseTestingUtility |
EncodedSeekPerformanceTest.testingUtility |
private HBaseTestingUtility |
TestCompactionTool.testUtil |
private HBaseTestingUtility |
TestSplitWalDataLoss.testUtil |
protected static HBaseTestingUtility |
TestSecureBulkLoadManager.testUtil |
private HBaseTestingUtility |
TestRegionServerAbort.testUtil |
private HBaseTestingUtility |
TestCompactionArchiveConcurrentClose.testUtil |
private HBaseTestingUtility |
TestBrokenStoreFileCleaner.testUtil |
private HBaseTestingUtility |
TestRegionServerReportForDuty.testUtil |
HBaseTestingUtility |
TestCompactionArchiveIOException.testUtil |
private static HBaseTestingUtility |
TestCompactionFileNotFound.util |
private HBaseTestingUtility |
TestMultiLogThreshold.util |
(package private) HBaseTestingUtility |
TestFSErrorsExposed.util |
private static HBaseTestingUtility |
TestCleanupCompactedFileOnRegionClose.util |
private static HBaseTestingUtility |
TestGetClosestAtOrBefore.UTIL |
private static HBaseTestingUtility |
TestSwitchToStreamRead.UTIL |
private static HBaseTestingUtility |
TestMinorCompaction.UTIL |
private static HBaseTestingUtility |
TestCompaction.UTIL |
private static HBaseTestingUtility |
TestShutdownWhileWALBroken.UTIL |
private static HBaseTestingUtility |
TestFlushLifeCycleTracker.UTIL |
private static HBaseTestingUtility |
TestPriorityRpc.UTIL |
private static HBaseTestingUtility |
TestCompactionInDeadRegionServer.UTIL |
private static HBaseTestingUtility |
TestScannerRetriableFailure.UTIL |
private static HBaseTestingUtility |
TestCompactorMemLeak.UTIL |
private static HBaseTestingUtility |
TestRegionServerCrashDisableWAL.UTIL |
private static HBaseTestingUtility |
TestRSChoresScheduled.UTIL |
private static HBaseTestingUtility |
TestWideScanner.UTIL |
protected static HBaseTestingUtility |
TestHRegionServerBulkLoad.UTIL |
private static HBaseTestingUtility |
TestMaxResultsPerColumnFamily.UTIL |
private static HBaseTestingUtility |
TestOpenSeqNumUnexpectedIncrease.UTIL |
private static HBaseTestingUtility |
TestCompactionLifeCycleTracker.UTIL |
private static HBaseTestingUtility |
TestRegionServerAbortTimeout.UTIL |
private static HBaseTestingUtility |
TestMajorCompaction.UTIL |
private static HBaseTestingUtility |
TestHRegionTracing.UTIL |
private static HBaseTestingUtility |
TestHeapMemoryManager.UTIL |
private static HBaseTestingUtility |
TestRequestsPerSecondMetric.UTIL |
protected static HBaseTestingUtility |
TestSplitWithBlockingFiles.UTIL |
protected static HBaseTestingUtility |
TestBulkLoadReplication.UTIL3 |
Modifier and Type | Method and Description |
---|---|
protected void |
TestBulkLoadReplication.assertBulkLoadConditions(org.apache.hadoop.hbase.TableName tableName,
byte[] row,
byte[] value,
HBaseTestingUtility utility,
org.apache.hadoop.hbase.client.Table... tables) |
protected void |
TestBulkLoadReplication.bulkLoadOnCluster(org.apache.hadoop.hbase.TableName tableName,
byte[] row,
byte[] value,
HBaseTestingUtility cluster) |
static void |
TestRegionServerNoMaster.checkRegionIsClosed(HBaseTestingUtility HTU,
org.apache.hadoop.hbase.regionserver.HRegionServer rs,
org.apache.hadoop.hbase.HRegionInfo hri) |
static void |
TestRegionServerNoMaster.checkRegionIsOpened(HBaseTestingUtility HTU,
org.apache.hadoop.hbase.regionserver.HRegionServer rs,
org.apache.hadoop.hbase.HRegionInfo hri) |
static void |
TestRegionServerNoMaster.closeRegion(HBaseTestingUtility HTU,
org.apache.hadoop.hbase.regionserver.HRegionServer rs,
org.apache.hadoop.hbase.HRegionInfo hri) |
private org.apache.hadoop.hbase.client.Table |
TestCompactionWithByteBuff.createTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName) |
static void |
TestRegionServerNoMaster.flushRegion(HBaseTestingUtility HTU,
org.apache.hadoop.hbase.client.RegionInfo regionInfo)
Flush the given region in the mini cluster.
|
private org.apache.hadoop.hbase.replication.ReplicationPeerConfig |
TestBulkLoadReplication.getPeerConfigForCluster(HBaseTestingUtility util) |
static void |
TestRegionServerNoMaster.openRegion(HBaseTestingUtility HTU,
org.apache.hadoop.hbase.regionserver.HRegionServer rs,
org.apache.hadoop.hbase.HRegionInfo hri) |
private void |
TestBulkLoadReplication.setupCoprocessor(HBaseTestingUtility cluster) |
static void |
TestRegionServerNoMaster.stopMasterAndCacheMetaLocation(HBaseTestingUtility HTU) |
Constructor and Description |
---|
MockHStoreFile(HBaseTestingUtility testUtil,
org.apache.hadoop.fs.Path testPath,
long length,
long ageInDisk,
boolean isRef,
long sequenceid) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestFIFOCompactionPolicy.TEST_UTIL |
private HBaseTestingUtility |
TestCompactedHFilesDischarger.testUtil |
private static HBaseTestingUtility |
TestOffPeakHours.testUtil |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestChangeStoreFileTracker.UTIL |
private static HBaseTestingUtility |
TestRegionWithFileBasedStoreFileTracker.UTIL |
private static HBaseTestingUtility |
TestMigrationStoreFileTracker.UTIL |
Modifier and Type | Field and Description |
---|---|
private HBaseTestingUtility |
TestFlushWithThroughputController.hbtu |
private static HBaseTestingUtility |
TestCompactionWithThroughputController.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
AbstractTestLogRolling.TEST_UTIL |
protected static HBaseTestingUtility |
TestLogRollAbort.TEST_UTIL |
private static HBaseTestingUtility |
TestWALActionsListener.TEST_UTIL |
private static HBaseTestingUtility |
TestDurability.TEST_UTIL |
protected static HBaseTestingUtility |
AbstractTestProtobufLog.TEST_UTIL |
private static HBaseTestingUtility |
WALDurabilityTestBase.TEST_UTIL |
(package private) static HBaseTestingUtility |
TestWALConfiguration.TEST_UTIL |
protected static HBaseTestingUtility |
AbstractTestLogRollPeriod.TEST_UTIL |
protected static HBaseTestingUtility |
TestWALOpenError.TEST_UTIL |
private static HBaseTestingUtility |
TestLogRollingNoCluster.TEST_UTIL |
(package private) static HBaseTestingUtility |
AbstractTestWALReplay.TEST_UTIL |
protected static HBaseTestingUtility |
AbstractTestFSWAL.TEST_UTIL |
private static HBaseTestingUtility |
TestHBaseWalOnEC.UTIL |
private static HBaseTestingUtility |
TestAsyncFSWALRollStuck.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestVerifyReplicationCrossDiffHdfs.mapReduceUtil |
protected static HBaseTestingUtility |
SerialReplicationTestBase.UTIL |
protected static HBaseTestingUtility |
TestNonHBaseReplicationEndpoint.UTIL |
private static HBaseTestingUtility |
TestReplicationProcedureRetry.UTIL |
private static HBaseTestingUtility |
TestVerifyCellsReplicationEndpoint.UTIL |
private static HBaseTestingUtility |
TestVerifyReplicationCrossDiffHdfs.util1 |
private static HBaseTestingUtility |
TestVerifyReplicationSecureClusterCredentials.UTIL1 |
protected static HBaseTestingUtility |
TestReplicationBase.UTIL1 |
protected static HBaseTestingUtility |
TestReplicationSyncUpToolBase.UTIL1 |
private static HBaseTestingUtility |
TestVerifyReplicationCrossDiffHdfs.util2 |
private static HBaseTestingUtility |
TestVerifyReplicationSecureClusterCredentials.UTIL2 |
protected static HBaseTestingUtility |
TestReplicationBase.UTIL2 |
protected static HBaseTestingUtility |
TestReplicationSyncUpToolBase.UTIL2 |
private static HBaseTestingUtility |
TestNamespaceReplicationWithBulkLoadedData.UTIL4 |
private HBaseTestingUtility[] |
TestMasterReplication.utilities |
protected static HBaseTestingUtility |
TestReplicationEditsDroppedWithDeletedTableCFs.utility1 |
protected static HBaseTestingUtility |
TestReplicationStuckWithDeletedTableCFs.utility1 |
private static HBaseTestingUtility |
TestReplicationWithTags.utility1 |
private static HBaseTestingUtility |
TestMultiSlaveReplication.utility1 |
protected static HBaseTestingUtility |
TestReplicationStuckWithDroppedTable.utility1 |
private static HBaseTestingUtility |
TestPerTableCFReplication.utility1 |
protected static HBaseTestingUtility |
TestReplicationEditsDroppedWithDroppedTable.utility1 |
protected static HBaseTestingUtility |
TestReplicationEditsDroppedWithDeletedTableCFs.utility2 |
protected static HBaseTestingUtility |
TestReplicationStuckWithDeletedTableCFs.utility2 |
private static HBaseTestingUtility |
TestReplicationWithTags.utility2 |
private static HBaseTestingUtility |
TestMultiSlaveReplication.utility2 |
protected static HBaseTestingUtility |
TestReplicationStuckWithDroppedTable.utility2 |
private static HBaseTestingUtility |
TestPerTableCFReplication.utility2 |
protected static HBaseTestingUtility |
TestReplicationEditsDroppedWithDroppedTable.utility2 |
private static HBaseTestingUtility |
TestMultiSlaveReplication.utility3 |
private static HBaseTestingUtility |
TestPerTableCFReplication.utility3 |
Modifier and Type | Method and Description |
---|---|
(package private) static void |
TestReplicationBase.configureClusters(HBaseTestingUtility util1,
HBaseTestingUtility util2) |
private static Thread |
TestReplicationKillRS.killARegionServer(HBaseTestingUtility utility,
long timeout,
int rs) |
protected void |
TestReplicationKillRS.loadTableAndKillRS(HBaseTestingUtility util)
Load up 1 tables over 2 region servers and kill a source during the upload.
|
private void |
TestMultiSlaveReplication.rollWALAndWait(HBaseTestingUtility utility,
org.apache.hadoop.hbase.TableName table,
byte[] row) |
private void |
TestMasterReplication.rollWALAndWait(HBaseTestingUtility utility,
org.apache.hadoop.hbase.TableName table,
byte[] row) |
private static void |
TestVerifyReplicationSecureClusterCredentials.setupCluster(HBaseTestingUtility util) |
protected static void |
TestReplicationBase.setupConfig(HBaseTestingUtility util,
String znodeParent) |
(package private) void |
TestReplicationSyncUpToolBase.syncUp(HBaseTestingUtility util) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestTableCFsUpdater.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
private HBaseTestingUtility |
TestMetaRegionReplicaReplicationEndpoint.HTU |
private static HBaseTestingUtility |
TestRegionReplicaReplicationEndpoint.HTU |
private static HBaseTestingUtility |
TestRegionReplicaReplicationEndpointNoMaster.HTU |
protected static HBaseTestingUtility |
WALEntryStreamTestBase.TEST_UTIL |
protected static HBaseTestingUtility |
TestReplicationSink.TEST_UTIL |
private static HBaseTestingUtility |
TestReplicationSource.TEST_UTIL |
private static HBaseTestingUtility |
TestReplicationSource.TEST_UTIL_PEER |
private static HBaseTestingUtility |
TestHBaseInterClusterReplicationEndpointFilterEdits.UTIL |
private static HBaseTestingUtility |
TestSerialReplicationChecker.UTIL |
private static HBaseTestingUtility |
TestSerialReplicationEndpoint.UTIL |
private static HBaseTestingUtility |
TestRaceWhenCreatingReplicationSource.UTIL |
protected static HBaseTestingUtility |
TestReplicationSourceManager.utility |
private static HBaseTestingUtility |
TestGlobalReplicationThrottler.utility1 |
private static HBaseTestingUtility |
TestGlobalReplicationThrottler.utility2 |
Modifier and Type | Method and Description |
---|---|
private void |
TestReplicator.truncateTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tablename) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestScannersWithFilters.TEST_UTIL |
private static HBaseTestingUtility |
TestMultiRowResource.TEST_UTIL |
private static HBaseTestingUtility |
TestVersionResource.TEST_UTIL |
private static HBaseTestingUtility |
TestSecurityHeadersFilter.TEST_UTIL |
protected static HBaseTestingUtility |
RowResourceBase.TEST_UTIL |
private static HBaseTestingUtility |
TestScannerResource.TEST_UTIL |
private static HBaseTestingUtility |
TestTableResource.TEST_UTIL |
private static HBaseTestingUtility |
TestTableScan.TEST_UTIL |
private static HBaseTestingUtility |
TestNamespacesResource.TEST_UTIL |
private static HBaseTestingUtility |
TestSchemaResource.TEST_UTIL |
private static HBaseTestingUtility |
TestNamespacesInstanceResource.TEST_UTIL |
private static HBaseTestingUtility |
TestStatusResource.TEST_UTIL |
private static HBaseTestingUtility |
TestSecureRESTServer.TEST_UTIL |
private static HBaseTestingUtility |
TestResourceFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestRESTServerSSL.TEST_UTIL |
private static HBaseTestingUtility |
TestGzipFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestScannersWithLabels.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestRemoteAdminRetries.TEST_UTIL |
private static HBaseTestingUtility |
TestRemoteHTableRetries.TEST_UTIL |
private static HBaseTestingUtility |
TestRemoteTable.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestRSGroupsBase.TEST_UTIL |
private static HBaseTestingUtility |
TestRSGroupsOfflineMode.TEST_UTIL |
private static HBaseTestingUtility |
TestEnableRSGroups.TEST_UTIL |
private static HBaseTestingUtility |
TestRSGroupsWithACL.TEST_UTIL |
private static HBaseTestingUtility |
TestDetermineRSGroupInfoForTable.UTIL |
private static HBaseTestingUtility |
TestRSGroupUtil.UTIL |
private static HBaseTestingUtility |
TestRSGroupMappingScript.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestSecureIPC.TEST_UTIL |
private static HBaseTestingUtility |
TestUsersOperationsWithSecureHadoop.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestCellACLs.TEST_UTIL |
private static HBaseTestingUtility |
TestCellACLWithMultipleVersions.TEST_UTIL |
private static HBaseTestingUtility |
TestSnapshotScannerHDFSAclController2.TEST_UTIL |
private static HBaseTestingUtility |
TestAccessControlFilter.TEST_UTIL |
private static HBaseTestingUtility |
TestWithDisabledAuthorization.TEST_UTIL |
private static HBaseTestingUtility |
TestUnloadAccessController.TEST_UTIL |
private static HBaseTestingUtility |
TestAccessController2.TEST_UTIL |
private static HBaseTestingUtility |
TestAccessController.TEST_UTIL |
private static HBaseTestingUtility |
TestSnapshotScannerHDFSAclController.TEST_UTIL |
private static HBaseTestingUtility |
TestScanEarlyTermination.TEST_UTIL |
private static HBaseTestingUtility |
TestRpcAccessChecks.TEST_UTIL |
private static HBaseTestingUtility |
TestAccessController3.TEST_UTIL |
private static HBaseTestingUtility |
TestNamespaceCommands.UTIL |
private static HBaseTestingUtility |
TestZKPermissionWatcher.UTIL |
private static HBaseTestingUtility |
TestTablePermissions.UTIL |
private static HBaseTestingUtility |
TestCoprocessorWhitelistMasterObserver.UTIL |
Modifier and Type | Method and Description |
---|---|
(package private) static void |
TestHDFSAclHelper.canUserScanSnapshot(HBaseTestingUtility util,
org.apache.hadoop.hbase.security.User user,
String snapshot,
int expectedRowCount)
Check if user is able to read expected rows from the specific snapshot
|
static void |
SecureTestUtil.checkGlobalPerms(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.security.access.Permission.Action... actions) |
static void |
SecureTestUtil.checkTablePerms(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.security.access.Permission... perms) |
static void |
SecureTestUtil.checkTablePerms(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.TableName table,
byte[] family,
byte[] column,
org.apache.hadoop.hbase.security.access.Permission.Action... actions) |
(package private) static org.apache.hadoop.hbase.client.Table |
TestHDFSAclHelper.createMobTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName) |
static void |
SecureTestUtil.createNamespace(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.NamespaceDescriptor nsDesc) |
(package private) static void |
TestHDFSAclHelper.createNamespace(HBaseTestingUtility util,
String namespace) |
static void |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.client.Admin admin,
org.apache.hadoop.hbase.client.TableDescriptor htd) |
static void |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.client.Admin admin,
org.apache.hadoop.hbase.client.TableDescriptor htd,
byte[][] splitKeys) |
static void |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.client.TableDescriptor htd) |
static void |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.client.TableDescriptor htd,
byte[][] splitKeys) |
(package private) static org.apache.hadoop.hbase.client.Table |
TestHDFSAclHelper.createTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName) |
static org.apache.hadoop.hbase.client.Table |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.TableName tableName,
byte[][] families) |
(package private) static void |
TestHDFSAclHelper.createTableAndPut(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableNam) |
(package private) static org.apache.hadoop.hbase.client.TableDescriptor |
TestHDFSAclHelper.createUserScanSnapshotDisabledTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName) |
static void |
SecureTestUtil.deleteNamespace(HBaseTestingUtility testUtil,
String namespace) |
static void |
SecureTestUtil.deleteTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.client.Admin admin,
org.apache.hadoop.hbase.TableName tableName) |
static void |
SecureTestUtil.deleteTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.TableName tableName) |
(package private) static org.apache.hadoop.hbase.client.TableDescriptorBuilder |
TestHDFSAclHelper.getTableDescriptorBuilder(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName) |
static void |
SecureTestUtil.grantGlobal(HBaseTestingUtility util,
String user,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Grant permissions globally to the given user.
|
static void |
SecureTestUtil.grantGlobal(org.apache.hadoop.hbase.security.User caller,
HBaseTestingUtility util,
String user,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Grant permissions globally to the given user.
|
static void |
SecureTestUtil.grantGlobalUsingAccessControlClient(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.Connection connection,
String user,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Grant global permissions to the given user using AccessControlClient.
|
static void |
SecureTestUtil.grantOnNamespace(HBaseTestingUtility util,
String user,
String namespace,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Grant permissions on a namespace to the given user.
|
static void |
SecureTestUtil.grantOnNamespace(org.apache.hadoop.hbase.security.User caller,
HBaseTestingUtility util,
String user,
String namespace,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Grant permissions on a namespace to the given user.
|
static void |
SecureTestUtil.grantOnNamespaceUsingAccessControlClient(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.Connection connection,
String user,
String namespace,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Grant permissions on a namespace to the given user using AccessControl Client.
|
static void |
SecureTestUtil.grantOnTable(HBaseTestingUtility util,
String user,
org.apache.hadoop.hbase.TableName table,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Grant permissions on a table to the given user.
|
(package private) static void |
TestHDFSAclHelper.grantOnTable(HBaseTestingUtility util,
String user,
org.apache.hadoop.hbase.TableName tableName,
org.apache.hadoop.hbase.security.access.Permission.Action... actions) |
static void |
SecureTestUtil.grantOnTable(org.apache.hadoop.hbase.security.User caller,
HBaseTestingUtility util,
String user,
org.apache.hadoop.hbase.TableName table,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Grant permissions on a table to the given user.
|
static void |
SecureTestUtil.grantOnTableUsingAccessControlClient(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.Connection connection,
String user,
org.apache.hadoop.hbase.TableName table,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Grant permissions on a table to the given user using AccessControlClient.
|
static void |
SecureTestUtil.revokeFromNamespace(HBaseTestingUtility util,
String user,
String namespace,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Revoke permissions on a namespace from the given user.
|
static void |
SecureTestUtil.revokeFromNamespace(org.apache.hadoop.hbase.security.User caller,
HBaseTestingUtility util,
String user,
String namespace,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Revoke permissions on a namespace from the given user.
|
static void |
SecureTestUtil.revokeFromNamespaceUsingAccessControlClient(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.Connection connection,
String user,
String namespace,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Revoke permissions on a namespace from the given user using AccessControl Client.
|
static void |
SecureTestUtil.revokeFromTable(HBaseTestingUtility util,
String user,
org.apache.hadoop.hbase.TableName table,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Revoke permissions on a table from the given user.
|
static void |
SecureTestUtil.revokeFromTable(org.apache.hadoop.hbase.security.User caller,
HBaseTestingUtility util,
String user,
org.apache.hadoop.hbase.TableName table,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Revoke permissions on a table from the given user.
|
static void |
SecureTestUtil.revokeFromTableUsingAccessControlClient(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.Connection connection,
String user,
org.apache.hadoop.hbase.TableName table,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Revoke permissions on a table from the given user using AccessControlClient.
|
static void |
SecureTestUtil.revokeGlobal(HBaseTestingUtility util,
String user,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Revoke permissions globally from the given user.
|
static void |
SecureTestUtil.revokeGlobal(org.apache.hadoop.hbase.security.User caller,
HBaseTestingUtility util,
String user,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Revoke permissions globally from the given user.
|
static void |
SecureTestUtil.revokeGlobalUsingAccessControlClient(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.Connection connection,
String user,
org.apache.hadoop.hbase.security.access.Permission.Action... actions)
Revoke global permissions from the given user using AccessControlClient.
|
private static void |
SecureTestUtil.updateACLs(HBaseTestingUtility util,
Callable c) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
CustomSaslAuthenticationProviderTestBase.UTIL |
Modifier and Type | Method and Description |
---|---|
private static void |
CustomSaslAuthenticationProviderTestBase.createBaseCluster(HBaseTestingUtility util,
File keytabFile,
org.apache.hadoop.minikdc.MiniKdc kdc) |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestShadeSaslAuthenticationProvider.UTIL |
Modifier and Type | Method and Description |
---|---|
(package private) static org.apache.hadoop.hbase.LocalHBaseCluster |
TestShadeSaslAuthenticationProvider.createCluster(HBaseTestingUtility util,
File keytabFile,
org.apache.hadoop.minikdc.MiniKdc kdc,
Map<String,char[]> userDatabase) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
SecureTestCluster.TEST_UTIL |
private HBaseTestingUtility |
TestTokenAuthentication.TEST_UTIL |
private HBaseTestingUtility |
TestTokenAuthentication.TokenServer.TEST_UTIL |
private static HBaseTestingUtility |
TestZKSecretWatcher.TEST_UTIL |
private static HBaseTestingUtility |
TestZKSecretWatcherRefreshKeys.TEST_UTIL |
Constructor and Description |
---|
TokenServer(org.apache.hadoop.conf.Configuration conf,
HBaseTestingUtility TEST_UTIL) |
Modifier and Type | Field and Description |
---|---|
static HBaseTestingUtility |
TestVisibilityWithCheckAuths.TEST_UTIL |
private static HBaseTestingUtility |
TestVisibilityLabelsOpWithDifferentUsersNoACL.TEST_UTIL |
static HBaseTestingUtility |
TestEnforcingScanLabelGenerator.TEST_UTIL |
protected static HBaseTestingUtility |
VisibilityLabelsWithDeletesTestBase.TEST_UTIL |
private static HBaseTestingUtility |
TestVisibilityLabelsWithACL.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLabelsReplication.TEST_UTIL |
static HBaseTestingUtility |
TestDefaultScanLabelGeneratorStack.TEST_UTIL |
private static HBaseTestingUtility |
TestWithDisabledAuthorization.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLablesWithGroups.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLabelsWithSLGStack.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLabels.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLabelsReplication.TEST_UTIL1 |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestExportSnapshot.TEST_UTIL |
protected static HBaseTestingUtility |
TestExportSnapshotAdjunct.TEST_UTIL |
private static HBaseTestingUtility |
TestSnapshotClientRetries.TEST_UTIL |
private static HBaseTestingUtility |
TestSnapshotManifest.TEST_UTIL |
protected static HBaseTestingUtility |
TestRestoreSnapshotHelper.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionSnapshotTask.TEST_UTIL |
private static HBaseTestingUtility |
TestSnapshotWhenChoreCleaning.TEST_UTIL |
protected static HBaseTestingUtility |
TestFlushSnapshotFromClient.UTIL |
private static HBaseTestingUtility |
TestSnapshotDescriptionUtils.UTIL |
protected static HBaseTestingUtility |
TestRestoreFlushSnapshotFromClient.UTIL |
private static HBaseTestingUtility |
TestSnapshotStoreFileSize.UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
SnapshotTestingUtils.confirmSnapshotValid(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshotDescriptor,
org.apache.hadoop.hbase.TableName tableName,
byte[] family) |
static ArrayList |
SnapshotTestingUtils.corruptSnapshot(HBaseTestingUtility util,
String snapshotName)
Corrupt the specified snapshot by deleting some files.
|
static org.apache.hadoop.hbase.client.Table |
MobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
byte[]... families)
Create a Mob table.
|
static void |
MobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
byte[][] splitKeys,
int regionReplication,
byte[]... families) |
static void |
MobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
byte[][] splitKeys,
int regionReplication,
String storeFileTracker,
byte[]... families) |
static void |
MobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
byte[][] splitKeys,
int regionReplication,
String storeFileTracker,
String cpClassName,
byte[]... families) |
static void |
MobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
int regionReplication,
byte[]... families)
Create the Mob Table.
|
static void |
MobSnapshotTestingUtils.createMobTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
int regionReplication,
String storeFileTracker,
byte[]... families) |
static void |
MobSnapshotTestingUtils.createPreSplitMobTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
int nRegions,
byte[]... families) |
static void |
SnapshotTestingUtils.createPreSplitTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
int nRegions,
byte[]... families) |
static void |
SnapshotTestingUtils.createTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
byte[]... families) |
static void |
SnapshotTestingUtils.createTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
int regionReplication,
byte[]... families) |
static void |
SnapshotTestingUtils.createTable(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
int regionReplication,
int nRegions,
byte[]... families) |
static void |
SnapshotTestingUtils.deleteArchiveDirectory(HBaseTestingUtility util) |
(package private) static org.apache.hadoop.fs.Path |
TestExportSnapshot.getLocalDestinationDir(HBaseTestingUtility htu) |
static void |
SnapshotTestingUtils.loadData(HBaseTestingUtility util,
org.apache.hadoop.hbase.client.BufferedMutator mutator,
int rows,
byte[]... families) |
static void |
SnapshotTestingUtils.loadData(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
int rows,
byte[]... families) |
static void |
MobSnapshotTestingUtils.verifyMobRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestFlushSnapshotFromClient.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestMobRestoreFlushSnapshotFromClient.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestRestoreFlushSnapshotFromClient.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
static void |
SnapshotTestingUtils.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
protected void |
TestMobFlushSnapshotFromClient.verifyRowCount(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
long expectedRows) |
static void |
SnapshotTestingUtils.waitForTableToBeOnline(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private HBaseTestingUtility |
TestTestingHBaseClusterReplicationShareZkDfs.util |
private HBaseTestingUtility |
TestTestingHBaseClusterReplicationShareDfs.util |
private HBaseTestingUtility |
TestTestingHBaseClusterReplicationShareZk.util |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestBindExceptionHandling.HTU |
protected static HBaseTestingUtility |
TestThriftHttpServer.TEST_UTIL |
protected static HBaseTestingUtility |
TestThriftServerCmdLine.TEST_UTIL |
private static HBaseTestingUtility |
TestCallQueue.UTIL |
private static HBaseTestingUtility |
TestThriftServer.UTIL |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestThriftConnection.TEST_UTIL |
private static HBaseTestingUtility |
TestThriftHBaseServiceHandlerWithLabels.UTIL |
private static HBaseTestingUtility |
TestThriftHBaseServiceHandler.UTIL |
private static HBaseTestingUtility |
TestThriftHBaseServiceHandlerWithReadOnly.UTIL |
Modifier and Type | Field and Description |
---|---|
private HBaseTestingUtility |
TestCanaryTool.testingUtility |
(package private) static HBaseTestingUtility |
TestLoadIncrementalHFilesSplitRecovery.util |
(package private) static HBaseTestingUtility |
TestLoadIncrementalHFiles.util |
Modifier and Type | Method and Description |
---|---|
static int |
TestLoadIncrementalHFiles.loadHFiles(String testName,
org.apache.hadoop.hbase.client.TableDescriptor htd,
HBaseTestingUtility util,
byte[] fam,
byte[] qual,
boolean preCreateTable,
byte[][] tableSplitKeys,
byte[][][] hfileRanges,
boolean useMap,
boolean deleteFile,
boolean copyFiles,
int initRowCount,
int factor) |
static int |
TestLoadIncrementalHFiles.loadHFiles(String testName,
org.apache.hadoop.hbase.client.TableDescriptor htd,
HBaseTestingUtility util,
byte[] fam,
byte[] qual,
boolean preCreateTable,
byte[][] tableSplitKeys,
byte[][][] hfileRanges,
boolean useMap,
boolean deleteFile,
boolean copyFiles,
int initRowCount,
int factor,
int depth) |
Modifier and Type | Field and Description |
---|---|
private HBaseTestingUtility |
TestFSUtils.htu |
(package private) HBaseTestingUtility |
MockServer.htu |
static HBaseTestingUtility |
TestRegionSplitCalculator.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionMover2.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionMover3.TEST_UTIL |
protected static HBaseTestingUtility |
BaseTestHBaseFsck.TEST_UTIL |
private static HBaseTestingUtility |
TestHBaseFsckEncryption.TEST_UTIL |
protected static HBaseTestingUtility |
TestCoprocessorScanPolicy.TEST_UTIL |
protected static HBaseTestingUtility |
TestMiniClusterLoadSequential.TEST_UTIL |
private static HBaseTestingUtility |
TestFSVisitor.TEST_UTIL |
private static HBaseTestingUtility |
TestRegionMover1.TEST_UTIL |
private HBaseTestingUtility |
ProcessBasedLocalHBaseCluster.testUtil |
private static HBaseTestingUtility |
TestHBaseFsckReplication.UTIL |
private static HBaseTestingUtility |
TestHBaseFsckCleanReplicationBarriers.UTIL |
private static HBaseTestingUtility |
TestConnectionCache.UTIL |
private static HBaseTestingUtility |
TestRegionSplitter.UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
BaseTestHBaseFsck.createTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.HTableDescriptor htd,
byte[][] splitKeys) |
static void |
BaseTestHBaseFsck.deleteTable(HBaseTestingUtility testUtil,
org.apache.hadoop.hbase.TableName tableName) |
static org.apache.hadoop.fs.Path |
HFileArchiveTestingUtil.getStoreArchivePath(HBaseTestingUtility util,
String tableName,
byte[] storeName) |
Constructor and Description |
---|
MockServer(HBaseTestingUtility htu) |
MockServer(HBaseTestingUtility htu,
boolean zkw) |
Modifier and Type | Field and Description |
---|---|
protected HBaseTestingUtility |
TestMajorCompactor.utility |
protected static HBaseTestingUtility |
TestMajorCompactionRequest.UTILITY |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestWALSplit.TEST_UTIL |
private HBaseTestingUtility |
WALPerformanceEvaluation.TEST_UTIL |
(package private) static HBaseTestingUtility |
TestSecureWAL.TEST_UTIL |
private static HBaseTestingUtility |
TestWALRootDir.TEST_UTIL |
protected static HBaseTestingUtility |
CompressedWALTestBase.TEST_UTIL |
protected static HBaseTestingUtility |
TestWALFactory.TEST_UTIL |
private static HBaseTestingUtility |
TestWALOpenAfterDNRollingStart.TEST_UTIL |
private HBaseTestingUtility |
TestWALFiltering.TEST_UTIL |
(package private) static HBaseTestingUtility |
TestWALReaderOnSecureWAL.TEST_UTIL |
private static HBaseTestingUtility |
TestFSHLogProvider.TEST_UTIL |
(package private) static HBaseTestingUtility |
TestDisabledWAL.TEST_UTIL |
private static HBaseTestingUtility |
TestBoundedRegionGroupingStrategy.TEST_UTIL |
private static HBaseTestingUtility |
TestWALSplitWithDeletedTableData.TEST_UTIL |
private HBaseTestingUtility |
TestWALMethods.util |
private static HBaseTestingUtility |
TestWrongMetaWALFileName.UTIL |
(package private) static HBaseTestingUtility |
TestWALSplitToHFile.UTIL |
protected static HBaseTestingUtility |
WALCorruptionDueToDanglingByteBufferTestBase.UTIL |
protected static HBaseTestingUtility |
WALCorruptionWithMultiPutDueToDanglingByteBufferTestBase.UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestZooKeeperACL.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestHelloHBase.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestHelloHBase.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
private static HBaseTestingUtility |
TestShadedHBaseTestingUtility.TEST_UTIL |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.