|
Change Parameter Type tableName : byte[] to tableName : TableName in method public initHRegion(tableName TableName, startKey byte[], stopKey byte[], callingMethod String, conf Configuration, isReadOnly boolean, families byte[]...) : HRegion in class org.apache.hadoop.hbase.regionserver.TestHRegion |
From |
To |
|
Change Parameter Type targetTableName : String to targetTableName : TableName in method private writeTestData(sourceTableName TableName, targetTableName TableName) : void in class org.apache.hadoop.hbase.mapreduce.TestSyncTable |
From |
To |
|
Change Parameter Type htable : HTable to htable : Table in method private checkExistence(htable Table, row byte[], family byte[], quality byte[], value byte[]) : void in class org.apache.hadoop.hbase.client.TestHTableMultiplexerFlushCache |
From |
To |
|
Change Parameter Type sourceTableName : String to sourceTableName : TableName in method private hashSourceTable(sourceTableName TableName, testDir Path) : void in class org.apache.hadoop.hbase.mapreduce.TestSyncTable |
From |
To |
|
Change Parameter Type targetTableName : String to targetTableName : TableName in method private assertEqualTables(expectedRows int, sourceTableName TableName, targetTableName TableName) : void in class org.apache.hadoop.hbase.mapreduce.TestSyncTable |
From |
To |
|
Change Parameter Type sourceTableName : String to sourceTableName : TableName in method private assertEqualTables(expectedRows int, sourceTableName TableName, targetTableName TableName) : void in class org.apache.hadoop.hbase.mapreduce.TestSyncTable |
From |
To |
|
Change Parameter Type t : HTable to t : Table in method private waitOnSplit(t Table) : List<HRegionLocation> in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Parameter Type table : HTable to table : Table in method private runIncrementalPELoad(conf Configuration, table Table, regionLocator RegionLocator, outDir Path) : void in class org.apache.hadoop.hbase.mapreduce.TestHFileOutputFormat |
From |
To |
|
Change Parameter Type t : HTable to t : Table in method private assertAllOnLine(t Table) : void in class org.apache.hadoop.hbase.io.encoding.TestLoadAndSwitchEncodeOnDisk |
From |
To |
|
Change Parameter Type sourceTableName : String to sourceTableName : TableName in method private syncTables(sourceTableName TableName, targetTableName TableName, testDir Path) : Counters in class org.apache.hadoop.hbase.mapreduce.TestSyncTable |
From |
To |
|
Change Parameter Type tableName : byte[] to tableName : TableName in method package initHRegion(tableName TableName, callingMethod String, families byte[]...) : HRegion in class org.apache.hadoop.hbase.regionserver.TestHRegion |
From |
To |
|
Change Parameter Type ht : HTable to ht : Table in method private generateRows(numberOfRows int, ht Table, family byte[], qf byte[], value byte[]) : void in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Parameter Type tableName : byte[] to tableName : TableName in method private createWALCompatibleWithFaultyFileSystem(callingMethod String, conf Configuration, tableName TableName) : WAL in class org.apache.hadoop.hbase.regionserver.TestHRegion |
From |
To |
|
Change Parameter Type table : HTable to table : Table in method package verifyEdit(familyNum int, putNum int, table Table) : void in class org.apache.hadoop.hbase.regionserver.TestPerColumnFamilyFlush |
From |
To |
|
Change Parameter Type htable : HTable to htable : Table in method private checkExistence(htable Table, row byte[], family byte[], quality byte[]) : void in class org.apache.hadoop.hbase.client.TestHTableMultiplexer |
From |
To |
|
Change Parameter Type tableName : byte[] to tableName : TableName in method public initHRegion(tableName TableName, startKey byte[], stopKey byte[], callingMethod String, conf Configuration, isReadOnly boolean, durability Durability, wal WAL, families byte[]...) : HRegion in class org.apache.hadoop.hbase.regionserver.TestHRegion |
From |
To |
|
Change Parameter Type sourceTableName : String to sourceTableName : TableName in method private writeTestData(sourceTableName TableName, targetTableName TableName) : void in class org.apache.hadoop.hbase.mapreduce.TestSyncTable |
From |
To |
|
Change Parameter Type tableName : byte[] to tableName : TableName in method private initHRegion(tableName TableName, callingMethod String, conf Configuration, isReadOnly boolean, families byte[]...) : HRegion in class org.apache.hadoop.hbase.regionserver.TestHRegion |
From |
To |
|
Change Parameter Type ht : HTable to ht : Table in method private getScanResult(startRow byte[], stopRow byte[], ht Table) : List<Cell> in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Parameter Type tables : HTable... to tables : Table... in method private doGets(maxOps int, tables Table...) : long in class org.apache.hadoop.hbase.quotas.TestQuotaThrottle |
From |
To |
|
Change Parameter Type tables : HTable... to tables : Table... in method private doPuts(maxOps int, tables Table...) : int in class org.apache.hadoop.hbase.quotas.TestQuotaThrottle |
From |
To |
|
Change Parameter Type t : HTable to t : Table in method private splitTable(t Table) : List<HRegionLocation> in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Parameter Type table : HTable to table : Table in method private performMultiplePutAndFlush(admin HBaseAdmin, table Table, row byte[], family byte[], nFlushes int, nPuts int) : void in class org.apache.hadoop.hbase.client.TestFromClientSide3 |
From |
To |
|
Change Parameter Type ht : HTable to ht : Table in method private getResultsSize(ht Table, scan Scan) : int in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Parameter Type targetTableName : String to targetTableName : TableName in method private syncTables(sourceTableName TableName, targetTableName TableName, testDir Path) : Counters in class org.apache.hadoop.hbase.mapreduce.TestSyncTable |
From |
To |
|
Change Variable Type table : HTable to locator : RegionLocator in method public testNonCachedGetRegionLocation() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testAsyncScanner() : void in class org.apache.hadoop.hbase.client.TestScannersFromClientSide |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testForCheckingIfEnableAndDisableWorksFineAfterSwitch() : void in class org.apache.hadoop.hbase.master.TestMasterRestartAfterDisablingTable |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public setupBeforeClass() : void in class org.apache.hadoop.hbase.coprocessor.TestDoubleColumnInterpreter |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testMetaScanner() : void in class org.apache.hadoop.hbase.TestMetaTableAccessor |
From |
To |
|
Change Variable Type hTable : HTable to hTable : Table in method public testSSHCleanupDaugtherRegionsOfAbortedSplit() : void in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testHTableExistsMethodSingleRegionMultipleGets() : void in class org.apache.hadoop.hbase.client.TestFromClientSide3 |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMasterOpsWhileSplitting() : void in class org.apache.hadoop.hbase.master.TestMaster |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testMasterRestartAtRegionSplitPendingCatalogJanitor() : void in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public setUpBeforeClass() : void in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatTestBase |
From |
To |
|
Change Variable Type htable2 : HTable to htable2 : Table in method public testHTableMultiplexer() : void in class org.apache.hadoop.hbase.client.TestHTableMultiplexer |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testCompactionTimestamps() : void in class org.apache.hadoop.hbase.client.TestAdmin1 |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMasterOpsWhileSplitting() : void in class org.apache.hadoop.hbase.regionserver.TestEndToEndSplitTransaction |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testLeaseRenewal() : void in class org.apache.hadoop.hbase.client.TestFromClientSide3 |
From |
To |
|
Change Variable Type htable : HTable to htable : Table in method public testOnRegionChange() : void in class org.apache.hadoop.hbase.client.TestHTableMultiplexerFlushCache |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testScanOnReopenedRegion() : void in class org.apache.hadoop.hbase.client.TestScannersFromClientSide |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testExceptionFromCoprocessorDuringPut() : void in class org.apache.hadoop.hbase.coprocessor.TestRegionServerCoprocessorExceptionWithRemove |
From |
To |
|
Change Variable Type htable : HTable to htable : Table in method public testGroupOrSplitWhenRegionHoleExistsInMeta() : void in class org.apache.hadoop.hbase.mapreduce.TestLoadIncrementalHFilesSplitRecovery |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method package installTable(zkw ZooKeeperWatcher, tname String, fname String, nrs int, existingRegions int) : Table in class org.apache.hadoop.hbase.master.TestDistributedLogSplitting |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testShutdownFixupWhenDaughterHasSplit() : void in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testRegionCaching() : void in class org.apache.hadoop.hbase.client.TestHCM |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testSmallReversedScanUnderMultiRegions() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type t1 : HTable to t1 : Table in method public testHashTable() : void in class org.apache.hadoop.hbase.mapreduce.TestHashTable |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testIncrementOnSameColumn() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testExceptionFromCoprocessorDuringPut() : void in class org.apache.hadoop.hbase.coprocessor.TestRegionServerCoprocessorExceptionWithAbort |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testWeirdCacheBehaviour() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testReplayCmd() : void in class org.apache.hadoop.hbase.master.TestDistributedLogSplitting |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testGetRegion() : void in class org.apache.hadoop.hbase.client.TestAdmin2 |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testRSSplitDaughtersAreOnlinedAfterShutdownHandling() : void in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster |
From |
To |
|
Change Variable Type results : Boolean[] to results : boolean[] in method public testHTableExistsMethodMultipleRegionsMultipleGets() : void in class org.apache.hadoop.hbase.client.TestFromClientSide3 |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testRegionTransitionOperations() : void in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testOveralyOnOtherCluster() : void in class org.apache.hadoop.hbase.TestHBaseOnOtherDfsCluster |
From |
To |
|
Change Variable Type regions : Map<HRegionInfo,ServerName> to regions : List<HRegionLocation> in method private splitTable(t Table) : List<HRegionLocation> in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type hTable : HTable to hTable : Table in method public testAdvancedConfigOverride() : void in class org.apache.hadoop.hbase.client.TestFromClientSide3 |
From |
To |
|
Change Variable Type e : Entry<HRegionInfo,ServerName> to e : HRegionLocation in method public testRowRange() : void in class org.apache.hadoop.hbase.regionserver.TestServerCustomProtocol |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public manualTest(args String[]) : void in class org.apache.hadoop.hbase.mapreduce.TestHFileOutputFormat |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMultiRowRangeFilterWithRangeOverlap() : void in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testCoprocessorService() : void in class org.apache.hadoop.hbase.coprocessor.TestCoprocessorEndpoint |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testSplitAndMergeWithReplicaTable() : void in class org.apache.hadoop.hbase.client.TestAdmin1 |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testGlobalAuthorizationForNewRegisteredRS() : void in class org.apache.hadoop.hbase.security.access.TestAccessController |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMultiRowRangeWithFilterListAndOperator() : void in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Variable Type table : HTable to table : Table in method private doIncrementalLoadTest(shouldChangeRegions boolean) : void in class org.apache.hadoop.hbase.mapreduce.TestHFileOutputFormat |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMultiRowRangeFilterWithExclusive() : void in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Variable Type table : HTable to table : Table in method private doGets(maxOps int, tables Table...) : long in class org.apache.hadoop.hbase.quotas.TestQuotaThrottle |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testResultSizeEstimation() : void in class org.apache.hadoop.hbase.client.TestResultSizeEstimation |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testResultSizeEstimationWithTags() : void in class org.apache.hadoop.hbase.client.TestResultSizeEstimation |
From |
To |
|
Change Variable Type regions : Map<HRegionInfo,ServerName> to regions : List<HRegionLocation> in method public testFilterAcrossMultipleRegions() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testScanNext() : void in class org.apache.hadoop.hbase.regionserver.TestRegionServerMetrics |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testBasicRollingRestart() : void in class org.apache.hadoop.hbase.master.TestRollingRestart |
From |
To |
|
Change Variable Type original : HTable to original : Table in method private runTestSnapshotMetadataChangesIndependent(online boolean) : void in class org.apache.hadoop.hbase.client.TestSnapshotCloneIndependence |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testClusterStatus() : void in class org.apache.hadoop.hbase.client.TestHCM |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testExistingZnodeBlocksSplitAndWeRollback() : void in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testDisallowWritesInRecovering() : void in class org.apache.hadoop.hbase.master.TestDistributedLogSplitting |
From |
To |
|
Change Variable Type table : HTable to table : Table in method private testConnectionClose(allowsInterrupt boolean) : void in class org.apache.hadoop.hbase.client.TestHCM |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testLegacyRecovery() : void in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverInterface |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testCacheSeqNums() : void in class org.apache.hadoop.hbase.client.TestHCM |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public beforeClass() : void in class org.apache.hadoop.hbase.mapreduce.TestMultithreadedTableMapper |
From |
To |
|
Change Variable Type e : Entry<HRegionInfo,ServerName> to e : HRegionLocation in method protected deleteRegion(conf Configuration, tbl Table, startKey byte[], endKey byte[]) : void in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRebuildTestCore |
From |
To |
|
Change Variable Type sourceTable : HTable to sourceTable : Table in method private writeTestData(sourceTableName TableName, targetTableName TableName) : void in class org.apache.hadoop.hbase.mapreduce.TestSyncTable |
From |
To |
|
Change Variable Type results : Boolean[] to results : boolean[] in method public testHTableExistsMethodSingleRegionMultipleGets() : void in class org.apache.hadoop.hbase.client.TestFromClientSide3 |
From |
To |
|
Change Variable Type t : HTable to t : Table in method private createTableAndWait(tableName TableName, cf byte[]) : Table in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster |
From |
To |
|
Change Variable Type original : HTable to original : Table in method private runTestRegionOperationsIndependent(online boolean) : void in class org.apache.hadoop.hbase.client.TestSnapshotCloneIndependence |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testEmptyReturnType() : void in class org.apache.hadoop.hbase.regionserver.TestServerCustomProtocol |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMultiRowRangeWithFilterListOrOperator() : void in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMultiRowRangeFilterWithoutRangeOverlap() : void in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testHTableExistsMethodMultipleRegionsMultipleGets() : void in class org.apache.hadoop.hbase.client.TestFromClientSide3 |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testCacheOnWriteEvictOnClose() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public createRandomTable(tableName TableName, families Collection<String>, maxVersions int, numColsPerRow int, numFlushes int, numRegions int, numRowsPerFlush int) : Table in class org.apache.hadoop.hbase.HBaseTestingUtility |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testScanMetrics() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testCheckAndMutate() : void in class org.apache.hadoop.hbase.client.TestCheckAndMutate |
From |
To |
|
Change Variable Type htable : HTable to htable : Table in method public testRegionOperations() : void in class org.apache.hadoop.hbase.namespace.TestNamespaceAuditor |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testRowCounterTimeRange() : void in class org.apache.hadoop.hbase.mapreduce.TestRowCounter |
From |
To |
|
Change Variable Type conn : Connection to conn : ClusterConnection in method public testClientTracksServerPushback() : void in class org.apache.hadoop.hbase.client.TestClientPushback |
From |
To |
|
Change Variable Type regionsMap : Map<HRegionInfo,ServerName> to allRegionLocations : List<HRegionLocation> in method public testNonCachedGetRegionLocation() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type table : HTable to table : Table in method private prepareData() : Store in class org.apache.hadoop.hbase.regionserver.compactions.TestCompactionWithThroughputController |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testNonceRecovery() : void in class org.apache.hadoop.hbase.master.TestDistributedLogSplitting |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testDataCorrectnessReplayingRecoveredEdits() : void in class org.apache.hadoop.hbase.regionserver.TestHRegionOnCluster |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testReversedScanUnderMultiRegions() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type table : HTable to table : Table in method private doTestLogReplay() : void in class org.apache.hadoop.hbase.regionserver.TestPerColumnFamilyFlush |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testFilterAcrossMultipleRegions() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testConnectionCut() : void in class org.apache.hadoop.hbase.client.TestHCM |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public beforeAllTests() : void in class org.apache.hadoop.hbase.master.TestMasterTransitions |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public test() : void in class org.apache.hadoop.hbase.master.TestGetLastFlushedSequenceId |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testReconstruction() : void in class org.apache.hadoop.hbase.TestFullLogReconstruction |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testScanNextForSmallScan() : void in class org.apache.hadoop.hbase.regionserver.TestRegionServerMetrics |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testCoprocessorServiceNullResponse() : void in class org.apache.hadoop.hbase.coprocessor.TestCoprocessorEndpoint |
From |
To |
|
Change Variable Type targetTable : HTable to targetTable : Table in method private writeTestData(sourceTableName TableName, targetTableName TableName) : void in class org.apache.hadoop.hbase.mapreduce.TestSyncTable |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testBasics() : void in class org.apache.hadoop.hbase.client.TestFromClientSideNoCodec |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public setupBeforeClass() : void in class org.apache.hadoop.hbase.coprocessor.TestAggregateProtocol |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testPreWALRestoreSkip() : void in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverInterface |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMultiRowRangeFilterWithEmptyStartRow() : void in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public manualTest(args String[]) : void in class org.apache.hadoop.hbase.mapreduce.TestHFileOutputFormat2 |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public beforeClass() : void in class org.apache.hadoop.hbase.mapreduce.TestTableMapReduceBase |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testExcludeAllFromMinorCompaction() : void in class org.apache.hadoop.hbase.mapreduce.TestHFileOutputFormat |
From |
To |
|
Change Variable Type htable1 : HTable to htable1 : Table in method public testHTableMultiplexer() : void in class org.apache.hadoop.hbase.client.TestHTableMultiplexer |
From |
To |
|
Change Variable Type regions : Map<HRegionInfo,ServerName> to regions : List<HRegionLocation> in method package splitTest(splitPoint byte[], familyNames byte[][], rowCounts int[], numVersions int, blockSize int) : void in class org.apache.hadoop.hbase.client.TestAdmin1 |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public loadTest() : void in class org.apache.hadoop.hbase.io.encoding.TestLoadAndSwitchEncodeOnDisk |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public bulkLoadHFileTest() : void in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverInterface |
From |
To |
|
Change Variable Type table : HTable to table : Table in method private doIncrementalLoadTest(shouldChangeRegions boolean) : void in class org.apache.hadoop.hbase.mapreduce.TestHFileOutputFormat2 |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMultiRowRangeFilterWithInclusive() : void in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public beforeClass() : void in class org.apache.hadoop.hbase.client.TestMultiParallel |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testMulti() : void in class org.apache.hadoop.hbase.client.TestHCM |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public setupBeforeClass() : void in class org.apache.hadoop.hbase.coprocessor.TestBigDecimalColumnInterpreter |
From |
To |
|
Change Variable Type t : HTable to t : Table in method public testRetrying() : void in class org.apache.hadoop.hbase.TestMetaTableAccessor |
From |
To |
|
Change Variable Type table : HTable to table : Table in method private doPuts(maxOps int, tables Table...) : int in class org.apache.hadoop.hbase.quotas.TestQuotaThrottle |
From |
To |
|
Change Variable Type table : HTable to table : Table in method package verifyRegionsUsingHTable() : void in class org.apache.hadoop.hbase.regionserver.TestEndToEndSplitTransaction.RegionChecker |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testRecovery() : void in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverInterface |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testRowsPutBufferedManyManyFlushes() : void in class org.apache.hadoop.hbase.client.TestFromClientSide |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testGlobalMemStore() : void in class org.apache.hadoop.hbase.TestGlobalMemStoreSize |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testMultiRowRangeFilterWithEmptyStopRow() : void in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter |
From |
To |
|
Change Variable Type firstGoodPair : Map.Entry<HRegionInfo,ServerName> to firstGoodPair : HRegionLocation in method public testRegionTransitionOperations() : void in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public before() : void in class org.apache.hadoop.hbase.regionserver.TestServerCustomProtocol |
From |
To |
|
Change Variable Type table : HTable to table : Table in method public testExcludeMinorCompaction() : void in class org.apache.hadoop.hbase.mapreduce.TestHFileOutputFormat |
From |
To |
|
Change Variable Type ht : HTable to ht : Table in method public testReadWriteSeqIdFiles() : void in class org.apache.hadoop.hbase.master.TestDistributedLogSplitting |
From |
To |