|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public createEncryptionContext(conf Configuration, family ColumnFamilyDescriptor) : Encryption.Context in class org.apache.hadoop.hbase.security.EncryptionUtil |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public getSplitPolicyClass(htd TableDescriptor, conf Configuration) : Class<? extends RegionSplitPolicy> in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to td : TableDescriptor in method public createPreSplitLoadTestTable(conf Configuration, td TableDescriptor, cds ColumnFamilyDescriptor[], splitter SplitAlgorithm, numRegionsPerServer int) : int in class org.apache.hadoop.hbase.HBaseTestingUtility |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public testTableCoprocessorAttrs(conf Configuration, htd TableDescriptor) : void in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost |
From |
To |
|
Change Parameter Type tableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method public computeHDFSBlocksDistribution(conf Configuration, tableDescriptor TableDescriptor, regionInfo HRegionInfo) : HDFSBlocksDistribution in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type hTableDescriptor : HTableDescriptor to tableDesctiptor : TableDescriptor in method public TableInfo(tableDesctiptor TableDescriptor, regionLocator RegionLocator) in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2.TableInfo |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public createTableAsync(desc TableDescriptor, splitKeys byte[][]) : Future<Void> in class org.apache.hadoop.hbase.client.Admin |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public CompactionCompletionNotifyingRegion(tableDir Path, log WAL, fs FileSystem, confParam Configuration, info HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverScannerOpenHook.CompactionCompletionNotifyingRegion |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public MobCacheConfig(conf Configuration, family ColumnFamilyDescriptor) in class org.apache.hadoop.hbase.mob.MobCacheConfig |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method protected createCacheConf(family ColumnFamilyDescriptor) : void in class org.apache.hadoop.hbase.regionserver.HStore |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public HMobStore(region HRegion, family ColumnFamilyDescriptor, confParam Configuration) in class org.apache.hadoop.hbase.regionserver.HMobStore |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public openHRegion(rootDir Path, info HRegionInfo, htd TableDescriptor, wal WAL, conf Configuration) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public createTable(desc TableDescriptor) : void in class org.apache.hadoop.hbase.client.Admin |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public createTable(desc TableDescriptor, splitKeys byte[][]) : void in class org.apache.hadoop.hbase.client.HBaseAdmin |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public createTable(desc TableDescriptor, startKey byte[], endKey byte[], numRegions int) : void in class org.apache.hadoop.hbase.client.Admin |
From |
To |
|
Change Parameter Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method public publishReadTiming(serverName ServerName, region HRegionInfo, column ColumnFamilyDescriptor, msTime long) : void in class org.apache.hadoop.hbase.tool.Canary.StdOutSink |
From |
To |
|
Change Parameter Type allTables : List<HTableDescriptor> to allTables : List<TableDescriptor> in method package serializeColumnFamilyAttribute(fn Function<ColumnFamilyDescriptor,String>, allTables List<TableDescriptor>) : String in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2 |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public ErrorThrowingHRegion(tableDir Path, wal WAL, fs FileSystem, confParam Configuration, regionInfo HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.regionserver.TestRegionServerAbort.ErrorThrowingHRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public openHRegion(info HRegionInfo, htd TableDescriptor, wal WAL, conf Configuration, rsServices RegionServerServices, reporter CancelableProgressable) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method protected createCacheConf(family ColumnFamilyDescriptor) : void in class org.apache.hadoop.hbase.regionserver.HMobStore |
From |
To |
|
Change Parameter Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method public publishWriteTiming(serverName ServerName, region HRegionInfo, column ColumnFamilyDescriptor, msTime long) : void in class org.apache.hadoop.hbase.tool.Canary.StdOutSink |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public createTableAsync(desc TableDescriptor, splitKeys byte[][]) : Future<Void> in class org.apache.hadoop.hbase.client.HBaseAdmin |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method protected instantiateHStore(family ColumnFamilyDescriptor) : HStore in class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInCompletionRegion |
From |
To |
|
Change Parameter Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method public publishReadFailure(serverName ServerName, region HRegionInfo, column ColumnFamilyDescriptor, e Exception) : void in class org.apache.hadoop.hbase.tool.Canary.Sink |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public createWriter(conf Configuration, fs FileSystem, family ColumnFamilyDescriptor, path Path, maxKeyCount long, compression Compression.Algorithm, cacheConfig CacheConfig, cryptoContext Encryption.Context, checksumType ChecksumType, bytesPerChecksum int, blocksize int, bloomType BloomType, isCompaction boolean) : StoreFileWriter in class org.apache.hadoop.hbase.mob.MobUtils |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method package newHRegion(tableDir Path, wal WAL, fs FileSystem, conf Configuration, regionInfo HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public ScanInfo(conf Configuration, family ColumnFamilyDescriptor, ttl long, timeToPurgeDeletes long, comparator CellComparator) in class org.apache.hadoop.hbase.regionserver.ScanInfo |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public HRegionWithSeqId(tableDir Path, wal WAL, fs FileSystem, confParam Configuration, regionInfo HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.regionserver.TestHRegion.HRegionWithSeqId |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public openHRegion(conf Configuration, fs FileSystem, rootDir Path, tableDir Path, info HRegionInfo, htd TableDescriptor, wal WAL, rsServices RegionServerServices, reporter CancelableProgressable) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method protected BlockCompactionsInCompletionHStore(region HRegion, family ColumnFamilyDescriptor, confParam Configuration) in class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInCompletionHStore |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public CreateTableFuture(admin HBaseAdmin, desc TableDescriptor, splitKeys byte[][], response CreateTableResponse) in class org.apache.hadoop.hbase.client.HBaseAdmin.CreateTableFuture |
From |
To |
|
Change Parameter Type hTableDescriptor : HTableDescriptor to hTableDescriptor : TableDescriptor in method public createHRegion(info HRegionInfo, rootDir Path, conf Configuration, hTableDescriptor TableDescriptor, wal WAL) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public MockHRegion(tableDir Path, log WAL, fs FileSystem, conf Configuration, regionInfo HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.regionserver.TestAtomicOperation.MockHRegion |
From |
To |
|
Change Parameter Type hTableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public buildModifyTableRequest(tableName TableName, tableDesc TableDescriptor, nonceGroup long, nonce long) : ModifyTableRequest in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public createTable(desc TableDescriptor, splitKeys byte[][]) : void in class org.apache.hadoop.hbase.client.Admin |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method protected instantiateHStore(family ColumnFamilyDescriptor) : HStore in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method public publishReadFailure(serverName ServerName, region HRegionInfo, column ColumnFamilyDescriptor, e Exception) : void in class org.apache.hadoop.hbase.tool.Canary.StdOutSink |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public BlockCompactionsInPrepRegion(tableDir Path, log WAL, fs FileSystem, confParam Configuration, info HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInPrepRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public openHRegion(rootDir Path, info HRegionInfo, htd TableDescriptor, wal WAL, conf Configuration, rsServices RegionServerServices, reporter CancelableProgressable) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public createTable(desc TableDescriptor) : void in class org.apache.hadoop.hbase.client.HBaseAdmin |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public determineTTLFromFamily(family ColumnFamilyDescriptor) : long in class org.apache.hadoop.hbase.regionserver.HStore |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public openHRegion(conf Configuration, fs FileSystem, rootDir Path, info HRegionInfo, htd TableDescriptor, wal WAL, rsServices RegionServerServices, reporter CancelableProgressable) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public warmupHRegion(info HRegionInfo, htd TableDescriptor, wal WAL, conf Configuration, rsServices RegionServerServices, reporter CancelableProgressable) : void in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type tableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method public configureIncrementalLoad(job Job, tableDescriptor TableDescriptor, regionLocator RegionLocator) : void in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2 |
From |
To |
|
Change Parameter Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method public publishReadTiming(serverName ServerName, region HRegionInfo, column ColumnFamilyDescriptor, msTime long) : void in class org.apache.hadoop.hbase.tool.Canary.Sink |
From |
To |
|
Change Parameter Type fn : Function<HColumnDescriptor,String> to fn : Function<ColumnFamilyDescriptor,String> in method package serializeColumnFamilyAttribute(fn Function<ColumnFamilyDescriptor,String>, allTables List<TableDescriptor>) : String in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2 |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public createTable(desc TableDescriptor, startKey byte[], endKey byte[], numRegions int) : void in class org.apache.hadoop.hbase.client.HBaseAdmin |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method package getTableCoprocessorAttrsFromSchema(conf Configuration, htd TableDescriptor) : List<TableCoprocessorAttribute> in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost |
From |
To |
|
Change Parameter Type tableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method public computeHDFSBlocksDistribution(conf Configuration, tableDescriptor TableDescriptor, regionInfo HRegionInfo, tablePath Path) : HDFSBlocksDistribution in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public openHRegion(info HRegionInfo, htd TableDescriptor, wal WAL, conf Configuration) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public openHRegion(conf Configuration, fs FileSystem, rootDir Path, info HRegionInfo, htd TableDescriptor, wal WAL) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public CompactionBlockerRegion(tableDir Path, log WAL, fs FileSystem, confParam Configuration, info HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.TestIOFencing.CompactionBlockerRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public getFlushPolicyClass(htd TableDescriptor, conf Configuration) : Class<? extends FlushPolicy> in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory |
From |
To |
|
Change Parameter Type tableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method public configureIncrementalLoadMap(job Job, tableDescriptor TableDescriptor) : void in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2 |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public HRegion(tableDir Path, wal WAL, fs FileSystem, confParam Configuration, regionInfo HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public HRegion(fs HRegionFileSystem, wal WAL, confParam Configuration, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method public publishWriteTiming(serverName ServerName, region HRegionInfo, column ColumnFamilyDescriptor, msTime long) : void in class org.apache.hadoop.hbase.tool.Canary.Sink |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method package getConstraints(desc TableDescriptor, classloader ClassLoader) : List<? extends Constraint> in class org.apache.hadoop.hbase.constraint.Constraints |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public BlockCompactionsInCompletionRegion(tableDir Path, log WAL, fs FileSystem, confParam Configuration, info HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInCompletionRegion |
From |
To |
|
Change Parameter Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method protected HStore(region HRegion, family ColumnFamilyDescriptor, confParam Configuration) in class org.apache.hadoop.hbase.regionserver.HStore |
From |
To |
|
Change Parameter Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method public publishWriteFailure(serverName ServerName, region HRegionInfo, column ColumnFamilyDescriptor, e Exception) : void in class org.apache.hadoop.hbase.tool.Canary.Sink |
From |
To |
|
Change Parameter Type hTableDescriptor : HTableDescriptor to hTableDescriptor : TableDescriptor in method public createHRegion(info HRegionInfo, rootDir Path, conf Configuration, hTableDescriptor TableDescriptor, wal WAL, initialize boolean) : HRegion in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public HeartbeatHRegion(tableDir Path, wal WAL, fs FileSystem, confParam Configuration, regionInfo HRegionInfo, htd TableDescriptor, rsServices RegionServerServices) in class org.apache.hadoop.hbase.regionserver.TestScannerHeartbeatMessages.HeartbeatHRegion |
From |
To |
|
Change Parameter Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method public publishWriteFailure(serverName ServerName, region HRegionInfo, column ColumnFamilyDescriptor, e Exception) : void in class org.apache.hadoop.hbase.tool.Canary.StdOutSink |
From |
To |
|
Change Variable Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method public read() : Void in class org.apache.hadoop.hbase.tool.Canary.RegionTask |
From |
To |
|
Change Variable Type hcd : HColumnDescriptor to hcd : ColumnFamilyDescriptor in method public createVisibilityLabelFilter(region Region, authorizations Authorizations) : Filter in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils |
From |
To |
|
Change Variable Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method protected createSubmittableJob(conf Configuration, args String[]) : Job in class org.apache.hadoop.hbase.mapreduce.ImportTsv |
From |
To |
|
Change Variable Type hdt : HTableDescriptor to td : TableDescriptor in method public testChangeTable() : void in class org.apache.hadoop.hbase.client.TestReplicaWithCluster |
From |
To |
|
Change Variable Type fam : HColumnDescriptor to fam : ColumnFamilyDescriptor in method private checkEncryption() : void in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Variable Type column : HColumnDescriptor to column : ColumnFamilyDescriptor in method private write() : Void in class org.apache.hadoop.hbase.tool.Canary.RegionTask |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public getTableName() : String in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl |
From |
To |
|
Change Variable Type tableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method package serializeColumnFamilyAttribute(fn Function<ColumnFamilyDescriptor,String>, allTables List<TableDescriptor>) : String in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2 |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public getNamespace() : String in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method protected configureForRegion(region HRegion) : void in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy |
From |
To |
|
Change Variable Type c : HColumnDescriptor to c : ColumnFamilyDescriptor in method package splitScan(regionList LinkedList<Pair<byte[],byte[]>>, connection Connection, tableName TableName, splitAlgo SplitAlgorithm) : LinkedList<Pair<byte[],byte[]>> in class org.apache.hadoop.hbase.util.RegionSplitter |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public read() : Void in class org.apache.hadoop.hbase.tool.Canary.RegionTask |
From |
To |
|
Change Variable Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public computeHDFSBlocksDistribution(conf Configuration, tableDescriptor TableDescriptor, regionInfo HRegionInfo, tablePath Path) : HDFSBlocksDistribution in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Variable Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public preFlushScannerOpen(c ObserverContext<RegionCoprocessorEnvironment>, store Store, scanners List<KeyValueScanner>, s InternalScanner) : InternalScanner in class org.apache.hadoop.hbase.util.TestCoprocessorScanPolicy.ScanObserver |
From |
To |
|
Change Variable Type fam : HColumnDescriptor to fam : ColumnFamilyDescriptor in method private checkCompressionCodecs() : void in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method private verifyRegionServerUpdated(plan FavoredNodesPlan) : void in class org.apache.hadoop.hbase.master.TestRegionPlacement |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method private write() : Void in class org.apache.hadoop.hbase.tool.Canary.RegionTask |
From |
To |
|
Change Variable Type bHdt : HTableDescriptor to bHdt : TableDescriptor in method public testChangeTable() : void in class org.apache.hadoop.hbase.client.TestReplicaWithCluster |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method protected configureForRegion(region HRegion) : void in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy |
From |
To |
|
Change Variable Type htd : HTableDescriptor to td : TableDescriptor in method public testSnapshotHFileArchiving() : void in class org.apache.hadoop.hbase.master.cleaner.TestSnapshotFromMaster |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method protected waitForAllRegionsOnline(deadlineTs long, splitKeys byte[][]) : void in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture |
From |
To |
|
Change Variable Type htd : HTableDescriptor to td : TableDescriptor in method public createTestRegion(tableName String, cd ColumnFamilyDescriptor) : HRegion in class org.apache.hadoop.hbase.HBaseTestingUtility |
From |
To |
|
Change Variable Type htd : HTableDescriptor to htd : TableDescriptor in method public evaluate() : boolean in class org.apache.hadoop.hbase.HBaseTestingUtility.predicateTableAvailable |
From |
To |
|
Change Variable Type tableDescriptors : List<HTableDescriptor> to tableDescriptors : List<TableDescriptor> in method package configureIncrementalLoad(job Job, multiTableInfo List<TableInfo>, cls Class<? extends OutputFormat<?,?>>) : void in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2 |
From |
To |
|
Change Variable Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method private validateFamiliesInHFiles(table Table, queue Deque<LoadQueueItem>, silence boolean) : void in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles |
From |
To |
|
Change Variable Type familyDescriptor : HColumnDescriptor to familyDescriptor : ColumnFamilyDescriptor in method package serializeColumnFamilyAttribute(fn Function<ColumnFamilyDescriptor,String>, allTables List<TableDescriptor>) : String in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2 |
From |
To |
|
Change Variable Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public preStoreScannerOpen(c ObserverContext<RegionCoprocessorEnvironment>, store Store, scan Scan, targetCols NavigableSet<byte[]>, s KeyValueScanner, readPt long) : KeyValueScanner in class org.apache.hadoop.hbase.util.TestCoprocessorScanPolicy.ScanObserver |
From |
To |
|
Change Variable Type tDesc : HTableDescriptor to tDesc : TableDescriptor in method protected createSubmittableJob(conf Configuration, args String[]) : Job in class org.apache.hadoop.hbase.mapreduce.ImportTsv |
From |
To |
|
Change Variable Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method public preCompactScannerOpen(c ObserverContext<RegionCoprocessorEnvironment>, store Store, scanners List<? extends KeyValueScanner>, scanType ScanType, earliestPutTs long, s InternalScanner) : InternalScanner in class org.apache.hadoop.hbase.util.TestCoprocessorScanPolicy.ScanObserver |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method public start(environment CoprocessorEnvironment) : void in class org.apache.hadoop.hbase.constraint.ConstraintProcessor |
From |
To |
|
Change Variable Type family : HColumnDescriptor to family : ColumnFamilyDescriptor in method private initializeStores(reporter CancelableProgressable, status MonitoredTask) : long in class org.apache.hadoop.hbase.regionserver.HRegion |
From |
To |
|
Change Variable Type htd : HTableDescriptor to htd : TableDescriptor in method package splitScan(regionList LinkedList<Pair<byte[],byte[]>>, connection Connection, tableName TableName, splitAlgo SplitAlgorithm) : LinkedList<Pair<byte[],byte[]>> in class org.apache.hadoop.hbase.util.RegionSplitter |
From |
To |
|
Change Variable Type singleTableDescriptor : ArrayList<HTableDescriptor> to singleTableDescriptor : ArrayList<TableDescriptor> in method public configureIncrementalLoadMap(job Job, tableDescriptor TableDescriptor) : void in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2 |
From |
To |
|
Change Variable Type hcd : HColumnDescriptor to hcd : ColumnFamilyDescriptor in method private internalPreRead(c ObserverContext<RegionCoprocessorEnvironment>, query Query, opType OpType) : void in class org.apache.hadoop.hbase.security.access.AccessController |
From |
To |
|
Change Variable Type confirmedHtd : HTableDescriptor to confirmedHtd : TableDescriptor in method public testGetTableDescriptor() : void in class org.apache.hadoop.hbase.client.TestAdmin1 |
From |
To |