|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public hasLocalIndexColumnFamily(desc TableDescriptor) : boolean in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Parameter Type newTableDescriptor : HTableDescriptor to newTableDescriptor : TableDescriptor in method private pollForUpdatedTableDescriptor(admin Admin, newTableDescriptor TableDescriptor, tableName byte[]) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type newDesc : HTableDescriptor to newDesc : TableDescriptor in method private modifyTable(tableName byte[], newDesc TableDescriptor, shouldPoll boolean) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method private markRegionAsCompacting(regionInfo RegionInfo) : void in class org.apache.phoenix.coprocessor.StatisticsCollectionRunTrackerIT |
From |
To |
|
Change Parameter Type colDescriptor : HColumnDescriptor to colDescriptor : ColumnFamilyDescriptor in method private checkTransactionalVersionsValue(colDescriptor ColumnFamilyDescriptor) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method private getTTL(table PTable, tableDesc TableDescriptor, newTTL Integer) : int in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type htableDesc : HTableDescriptor to htableDesc : TableDescriptor in method public invalidateAll(htableDesc TableDescriptor) : void in class org.apache.phoenix.query.GuidePostsCache |
From |
To |
|
Change Parameter Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method private markRunningUpdateStats(regionInfo RegionInfo) : void in class org.apache.phoenix.coprocessor.StatisticsCollectionRunTrackerIT |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public build(desc TableDescriptor, clazz Class<? extends IndexCodec>) : TableDescriptor in class org.apache.phoenix.hbase.index.covered.CoveredColumnIndexSpecifierBuilder |
From |
To |
|
Change Parameter Type tableDescriptor : HTableDescriptor to tableDescriptorBuilder : TableDescriptorBuilder in method private setTransactional(physicalTableName byte[], tableDescriptorBuilder TableDescriptorBuilder, tableType PTableType, txValue String, tableProps Map<String,Object>) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type tableDescriptors : Set<HTableDescriptor> to tableDescriptors : Set<TableDescriptor> in method private sendHBaseMetaData(tableDescriptors Set<TableDescriptor>, pollingNeeded boolean) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public getNonLocalIndexColumnFamilies(desc TableDescriptor) : List<byte[]> in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Parameter Type htd : HTableDescriptor to htd : TableDescriptor in method public SnapshotScanner(conf Configuration, fs FileSystem, rootDir Path, htd TableDescriptor, hri RegionInfo, scan Scan) in class org.apache.phoenix.iterate.SnapshotScanner |
From |
To |
|
Change Parameter Type tableDesc : HTableDescriptor to tableDescBuilder : TableDescriptorBuilder in method private setTTLForNewCFs(familyProps Map<String,Map<String,Object>>, table PTable, tableDescBuilder TableDescriptorBuilder, newTTL Integer) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type toRegion : HRegionInfo to toRegion : RegionInfo in method private copyLocalIndexHFiles(conf Configuration, fromRegion RegionInfo, toRegion RegionInfo, move boolean) : void in class org.apache.phoenix.end2end.index.LocalIndexIT |
From |
To |
|
Change Parameter Type hcd : HColumnDescriptor to hcd : ColumnFamilyDescriptorBuilder in method private modifyColumnFamilyDescriptor(hcd ColumnFamilyDescriptorBuilder, props Map<String,Object>) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type columnDesc : HColumnDescriptor to columnDescBuilder : ColumnFamilyDescriptorBuilder in method private setHColumnDescriptorValue(columnDescBuilder ColumnFamilyDescriptorBuilder, key String, value Object) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type descriptor : HTableDescriptor to builder : TableDescriptorBuilder in method private addCoprocessors(tableName byte[], builder TableDescriptorBuilder, tableType PTableType, tableProps Map<String,Object>) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type fromRegion : HRegionInfo to fromRegion : RegionInfo in method private copyLocalIndexHFiles(conf Configuration, fromRegion RegionInfo, toRegion RegionInfo, move boolean) : void in class org.apache.phoenix.end2end.index.LocalIndexIT |
From |
To |
|
Change Parameter Type htableProps : Map<ImmutableBytesWritable,ImmutableBytesWritable> to htableProps : Map<Bytes,Bytes> in method private createPropertiesMap(htableProps Map<Bytes,Bytes>) : Map<String,Object> in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type descriptorsToUpdate : Set<HTableDescriptor> to descriptorsToUpdate : Set<TableDescriptor> in method private updateDescriptorForTx(table PTable, tableProps Map<String,Object>, tableDescriptorBuilder TableDescriptorBuilder, txValue String, descriptorsToUpdate Set<TableDescriptor>, origDescriptors Set<TableDescriptor>) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type keyValue : KeyValue to keyValue : Cell in method protected wrapKeyValueAsResult(keyValue Cell) : Tuple in class org.apache.phoenix.execute.ClientAggregatePlan.ClientGroupedAggregatingResultIterator |
From |
To |
|
Change Parameter Type existingDesc : HTableDescriptor to existingDesc : TableDescriptor in method private generateTableDescriptor(physicalTableName byte[], existingDesc TableDescriptor, tableType PTableType, tableProps Map<String,Object>, families List<Pair<byte[],Map<String,Object>>>, splits byte[][], isNamespaceMapped boolean) : TableDescriptorBuilder in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type hri : HRegionInfo to hri : RegionInfo in method public SnapshotScanner(conf Configuration, fs FileSystem, rootDir Path, htd TableDescriptor, hri RegionInfo, scan Scan) in class org.apache.phoenix.iterate.SnapshotScanner |
From |
To |
|
Change Parameter Type tableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method private setSharedIndexMaxVersion(table PTable, tableDescriptor TableDescriptor, indexDescriptorBuilder TableDescriptorBuilder) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to descBuilder : TableDescriptorBuilder in method public enableIndexing(descBuilder TableDescriptorBuilder, builder Class<? extends IndexBuilder>, properties Map<String,String>, priority int) : void in class org.apache.phoenix.hbase.index.Indexer |
From |
To |
|
Change Parameter Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method public getActualStartRow(localIndexScan Scan, regionInfo RegionInfo) : byte[] in class org.apache.phoenix.util.ScanUtil |
From |
To |
|
Change Parameter Type tableDescriptor : HTableDescriptor to tableDescriptorBuilder : TableDescriptorBuilder in method private updateDescriptorForTx(table PTable, tableProps Map<String,Object>, tableDescriptorBuilder TableDescriptorBuilder, txValue String, descriptorsToUpdate Set<TableDescriptor>, origDescriptors Set<TableDescriptor>) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type keyValue : KeyValue to keyValue : Cell in method protected wrapKeyValueAsResult(keyValue Cell) : Tuple in class org.apache.phoenix.execute.ClientAggregatePlan.ClientUngroupedAggregatingResultIterator |
From |
To |
|
Change Parameter Type origDescriptors : Set<HTableDescriptor> to origDescriptors : Set<TableDescriptor> in method private updateDescriptorForTx(table PTable, tableProps Map<String,Object>, tableDescriptorBuilder TableDescriptorBuilder, txValue String, descriptorsToUpdate Set<TableDescriptor>, origDescriptors Set<TableDescriptor>) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Parameter Type actions : List<? extends Row> to gets : List<Get> in method public exists(gets List<Get>) : boolean[] in class org.apache.phoenix.transaction.OmidTransactionTable |
From |
To |
|
Change Parameter Type desc : HTableDescriptor to desc : TableDescriptor in method public build(desc TableDescriptor) : TableDescriptor in class org.apache.phoenix.hbase.index.covered.CoveredColumnIndexSpecifierBuilder |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method private preSplitSequenceTable(conn PhoenixConnection, nSaltBuckets int) : void in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method private ensureViewIndexTableDropped(physicalTableName byte[], timestamp long) : boolean in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public testShutdownInterruptsAsExpected() : void in class org.apache.phoenix.hbase.index.write.TestIndexWriter |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public upgradeLocalIndexes(metaConnection PhoenixConnection) : PhoenixConnection in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSetTTLForTableWithOnlyPKCols() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type htd : HTableDescriptor to htd : TableDescriptor in method public testReplayEditsWrittenViaHRegion() : void in class org.apache.hadoop.hbase.regionserver.wal.WALReplayWithIndexWritesAndCompressedWALIT |
From |
To |
|
Change Variable Type regionsOfUserTable : List<HRegionInfo> to regionsOfUserTable : List<RegionInfo> in method public testLocalIndexScanAfterRegionSplit() : void in class org.apache.phoenix.end2end.LocalIndexSplitMergeIT |
From |
To |
|
Change Variable Type colDef : HColumnDescriptor to colDefBuilder : ColumnFamilyDescriptorBuilder in method public upgradeLocalIndexes(metaConnection PhoenixConnection) : PhoenixConnection in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetPropertyAndAddColumnUsingDefaultColumnFamilySpecifier() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testAddingPkColAndSettingProperties() : void in class org.apache.phoenix.end2end.AlterTableIT |
From |
To |
|
Change Variable Type cf : HColumnDescriptor to cf : ColumnFamilyDescriptor in method public getNonLocalIndexColumnFamilies(desc TableDescriptor) : List<byte[]> in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testCreateTableColumnFamilyHBaseAttribs6() : void in class org.apache.phoenix.end2end.CreateTableIT |
From |
To |
|
Change Variable Type columnDesc : HColumnDescriptor to columnDescBuilder : ColumnFamilyDescriptorBuilder in method private generateColumnFamilyDescriptor(family Pair<byte[],Map<String,Object>>, tableType PTableType) : ColumnFamilyDescriptor in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSetHTableAndHColumnProperties() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type mockRegionInfo : HRegionInfo to mockRegionInfo : RegionInfo in method public setup() : void in class org.apache.phoenix.hbase.index.covered.NonTxIndexBuilderTest |
From |
To |
|
Change Variable Type value : ImmutableBytesWritable to value : Bytes in method private createPropertiesMap(htableProps Map<Bytes,Bytes>) : Map<String,Object> in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetTTLForTableWithOnlyPKCols() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetPropertyAndAddColumnForDefaultColumnFamily() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method private getParallelScans(startKey byte[], stopKey byte[]) : List<List<Scan>> in class org.apache.phoenix.iterate.BaseResultIterators |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetPropertyAndAddColumnForDifferentColumnFamilies() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method public testStateBeforeAndAfterUpdateStatsCommand() : void in class org.apache.phoenix.coprocessor.StatisticsCollectionRunTrackerIT |
From |
To |
|
Change Variable Type descriptor : HTableDescriptor to descriptor : TableDescriptor in method private sendHBaseMetaData(tableDescriptors Set<TableDescriptor>, pollingNeeded boolean) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetPropertyAndAddColumnForNewColumnFamily() : void in class org.apache.phoenix.end2end.AlterTableIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testCreateTableColumnFamilyHBaseAttribs7() : void in class org.apache.phoenix.end2end.CreateTableIT |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method private ensureLocalIndexTableDropped(physicalTableName byte[], timestamp long) : boolean in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type origTableDescriptor : HTableDescriptor to origTableDescriptor : TableDescriptor in method private separateAndValidateProperties(table PTable, properties Map<String,List<Pair<String,Object>>>, colFamiliesForPColumnsToBeAdded Set<String>, families List<Pair<byte[],Map<String,Object>>>, tableProps Map<String,Object>) : Pair<TableDescriptor,TableDescriptor> in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type htd : HTableDescriptor to htd : TableDescriptor in method public testLocalIndexTableRegionSplitPolicyAndSplitKeys() : void in class org.apache.phoenix.end2end.index.LocalIndexIT |
From |
To |
|
Change Variable Type hri1 : HRegionInfo to hri1 : RegionInfo in method private ensureTablesOnDifferentRegionServers(tableName1 String, tableName2 String) : void in class org.apache.phoenix.rpc.PhoenixServerRpcIT |
From |
To |
|
Change Variable Type tableDescriptors : Set<HTableDescriptor> to tableDescriptors : Set<TableDescriptor> in method public addColumn(tableMetaData List<Mutation>, table PTable, stmtProperties Map<String,List<Pair<String,Object>>>, colFamiliesForPColumnsToBeAdded Set<String>, columns List<PColumn>) : MetaDataMutationResult in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetHColumnPropertyForTableWithOnlyPKCols1() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type tableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method private testBuildingLocalIndexShouldHandleNoSuchColumnFamilyException(coveredIndex boolean) : void in class org.apache.phoenix.end2end.FlappingLocalIndexIT |
From |
To |
|
Change Variable Type dataTable : HTableDescriptor to dataTable : TableDescriptor in method public testTableDescriptorPriority() : void in class org.apache.phoenix.end2end.index.BaseIndexIT |
From |
To |
|
Change Variable Type cols : HColumnDescriptor[] to cols : ColumnFamilyDescriptor[] in method public testReplicationWithMutableIndexes() : void in class org.apache.phoenix.end2end.index.MutableIndexReplicationIT |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSetHColumnPropertyForTableWithOnlyPKCols1() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testNewColumnFamilyInheritsTTLOfEmptyCF() : void in class org.apache.phoenix.end2end.FlappingAlterTableIT |
From |
To |
|
Change Variable Type tableDesc2 : HTableDescriptor to tableDesc2 : TableDescriptor in method public testAlteringViewConditionallyModifiesHTableMetadata() : void in class org.apache.phoenix.end2end.AlterMultiTenantTableWithViewsIT |
From |
To |
|
Change Variable Type onlineRegion : HRegionInfo to onlineRegion : RegionInfo in method public testRegionCloseDuringUpsertSelect() : void in class org.apache.phoenix.execute.UpsertSelectOverlappingBatchesIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testCreateTableColumnFamilyHBaseAttribs8() : void in class org.apache.phoenix.end2end.CreateTableIT |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method public hasViewIndexTable(connection PhoenixConnection, physicalTableName byte[]) : boolean in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetHTableAndHColumnProperties() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type descriptor : HTableDescriptor to descriptor : TableDescriptor in method public removeCoprocessor(conn Connection, tableName String, coprocessorClass Class) : void in class org.apache.phoenix.util.TestUtil |
From |
To |
|
Change Variable Type htableDesc : HTableDescriptor to htableDesc : TableDescriptor in method private ensureViewIndexTableCreated(table PTable, timestamp long, isNamespaceMapped boolean) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSetHColumnPropertyAndAddColumnForDefaultCFForTableWithOnlyPKCols() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type cdA : HColumnDescriptor to cdA : ColumnFamilyDescriptor in method public testCreateOnExistingTable() : void in class org.apache.phoenix.end2end.QueryDatabaseMetaDataIT |
From |
To |
|
Change Variable Type table : HTableDescriptor to table : TableDescriptor in method private disableAndDropNonSystemTables() : void in class org.apache.phoenix.query.BaseTest |
From |
To |
|
Change Variable Type descriptor : HTableDescriptor to descriptor : TableDescriptor in method public addCoprocessor(conn Connection, tableName String, coprocessorClass Class) : void in class org.apache.phoenix.util.TestUtil |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testNewColumnFamilyInheritsTTLOfEmptyCF() : void in class org.apache.phoenix.end2end.FlappingAlterTableIT |
From |
To |
|
Change Variable Type existingTableDescriptor : HTableDescriptor to existingTableDescriptor : TableDescriptor in method private separateAndValidateProperties(table PTable, properties Map<String,List<Pair<String,Object>>>, colFamiliesForPColumnsToBeAdded Set<String>, families List<Pair<byte[],Map<String,Object>>>, tableProps Map<String,Object>) : Pair<TableDescriptor,TableDescriptor> in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type tableDescriptor : HTableDescriptor to tableDescriptorBuilder : TableDescriptorBuilder in method private generateTableDescriptor(physicalTableName byte[], existingDesc TableDescriptor, tableType PTableType, tableProps Map<String,Object>, families List<Pair<byte[],Map<String,Object>>>, splits byte[][], isNamespaceMapped boolean) : TableDescriptorBuilder in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type onlineRegions : List<HRegionInfo> to onlineRegions : List<RegionInfo> in method public testRegionCloseDuringUpsertSelect() : void in class org.apache.phoenix.execute.UpsertSelectOverlappingBatchesIT |
From |
To |
|
Change Variable Type table : HTableDescriptor to table : TableDescriptor in method public upgradeLocalIndexes(metaConnection PhoenixConnection) : PhoenixConnection in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetHColumnPropertyForTableWithOnlyPKCols2() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testAddNewColumnFamilyProperties() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method public testProperties() : void in class org.apache.phoenix.tx.TransactionIT |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSetHColumnPropertyForTableWithOnlyPKCols2() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type entry : Map.Entry<ImmutableBytesWritable,ImmutableBytesWritable> to entry : Map.Entry<Bytes,Bytes> in method private createPropertiesMap(htableProps Map<Bytes,Bytes>) : Map<String,Object> in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type hri2 : HRegionInfo to hri2 : RegionInfo in method private ensureTablesOnDifferentRegionServers(tableName1 String, tableName2 String) : void in class org.apache.phoenix.rpc.PhoenixServerRpcIT |
From |
To |
|
Change Variable Type tableRegions : List<HRegionInfo> to tableRegions : List<RegionInfo> in method private createTableAndGetRegion(tableName String) : RegionInfo in class org.apache.phoenix.coprocessor.StatisticsCollectionRunTrackerIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testAddNewColumnFamilyProperties() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type htableDesc : HTableDescriptor to htableDesc : TableDescriptor in method private dropTables(tableNamesToDelete List<byte[]>) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testAddProperyToExistingColumnFamily() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetPropertyAndAddColumnForExistingColumnFamily() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type key : ImmutableBytesWritable to key : Bytes in method private createPropertiesMap(htableProps Map<Bytes,Bytes>) : Map<String,Object> in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method private pollForUpdatedTableDescriptor(admin Admin, newTableDescriptor TableDescriptor, tableName byte[]) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method private createTableInternal(statement CreateTableStatement, splits byte[][], parent PTable, viewStatement String, viewType ViewType, viewColumnConstants byte[][], isViewColumnReferenced BitSet, allocateIndexId boolean, indexType IndexType, asyncCreatedDate Date, tableProps Map<String,Object>, commonFamilyProps Map<String,Object>) : PTable in class org.apache.phoenix.schema.MetaDataClient |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetPropertyAndAddColumnWhenTableHasExplicitDefaultColumnFamily() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type dataRegion : HRegionInfo to dataRegion : RegionInfo in method public testRegionCloseDuringUpsertSelect() : void in class org.apache.phoenix.execute.UpsertSelectOverlappingBatchesIT |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method public testReplicationWithMutableIndexes() : void in class org.apache.phoenix.end2end.index.MutableIndexReplicationIT |
From |
To |
|
Change Variable Type propertyTTL : String to propertyTTL : byte[] in method public testProperties() : void in class org.apache.phoenix.tx.TransactionIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testCreateTableColumnFamilyHBaseAttribs1() : void in class org.apache.phoenix.end2end.CreateTableIT |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSetHColumnPropertyAndAddColumnForNewCFForTableWithOnlyPKCols() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type hcon : Connection to hcon : ClusterConnection in method public tableRegionsOnline(conf Configuration, table PTable) : boolean in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Variable Type indexTableDesc : HTableDescriptor to indexTableBuilder : TableDescriptorBuilder in method public testWaitsOnIndexRegionToReload() : void in class org.apache.phoenix.hbase.index.write.TestWALRecoveryCaching |
From |
To |
|
Change Variable Type indexDescriptor : HTableDescriptor to indexDescriptor : TableDescriptor in method private updateDescriptorForTx(table PTable, tableProps Map<String,Object>, tableDescriptorBuilder TableDescriptorBuilder, txValue String, descriptorsToUpdate Set<TableDescriptor>, origDescriptors Set<TableDescriptor>) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type origTableDescriptors : Set<HTableDescriptor> to origTableDescriptors : Set<TableDescriptor> in method public addColumn(tableMetaData List<Mutation>, table PTable, stmtProperties Map<String,List<Pair<String,Object>>>, colFamiliesForPColumnsToBeAdded Set<String>, columns List<PColumn>) : MetaDataMutationResult in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type tableDesc1 : HTableDescriptor to tableDesc1 : TableDescriptor in method public testAlteringViewConditionallyModifiesHTableMetadata() : void in class org.apache.phoenix.end2end.AlterMultiTenantTableWithViewsIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetHColumnPropertyAndAddColumnForNewCFForTableWithOnlyPKCols() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type hRegion : HRegionInfo to hRegion : RegionInfo in method public testSplitDuringUpsertSelect() : void in class org.apache.phoenix.execute.UpsertSelectOverlappingBatchesIT |
From |
To |
|
Change Variable Type tableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method private createTableInternal(statement CreateTableStatement, splits byte[][], parent PTable, viewStatement String, viewType ViewType, viewColumnConstants byte[][], isViewColumnReferenced BitSet, allocateIndexId boolean, indexType IndexType, asyncCreatedDate Date, tableProps Map<String,Object>, commonFamilyProps Map<String,Object>) : PTable in class org.apache.phoenix.schema.MetaDataClient |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testCreateTable() : void in class org.apache.phoenix.end2end.CreateTableIT |
From |
To |
|
Change Variable Type regionManifest : SnapshotProtos.SnapshotRegionManifest to regionManifest : SnapshotRegionManifest in method private getRegionLocationsFromManifest(manifest SnapshotManifest) : List<HRegionLocation> in class org.apache.phoenix.iterate.MapReduceParallelScanGrouper |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testTTLAssignmentForNewEmptyCF() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type dataTableDesc : HTableDescriptor to dataTableDesc : TableDescriptor in method public upgradeLocalIndexes(metaConnection PhoenixConnection) : PhoenixConnection in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSettingPropertiesWhenTableHasDefaultColFamilySpecified() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type htd : HTableDescriptor to htd : TableDescriptor in method public setup(parent Stoppable, env RegionCoprocessorEnvironment) : void in class org.apache.phoenix.index.PhoenixIndexFailurePolicy |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method private ensureViewIndexTableCreated(physicalTableName byte[], tableProps Map<String,Object>, families List<Pair<byte[],Map<String,Object>>>, splits byte[][], timestamp long, isNamespaceMapped boolean) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testCreateTableColumnFamilyHBaseAttribs2() : void in class org.apache.phoenix.end2end.CreateTableIT |
From |
To |
|
Change Variable Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method private toBoundaries(regionLocations List<HRegionLocation>) : List<byte[]> in class org.apache.phoenix.iterate.BaseResultIterators |
From |
To |
|
Change Variable Type cf : HColumnDescriptor to cf : ColumnFamilyDescriptor in method public upgradeLocalIndexes(metaConnection PhoenixConnection) : PhoenixConnection in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetHColumnPropertyAndAddColumnForDefaultCFForTableWithOnlyPKCols() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type cf : HColumnDescriptor to cf : ColumnFamilyDescriptor in method public getLocalIndexColumnFamilies(conn PhoenixConnection, physicalTableName byte[]) : List<byte[]> in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Variable Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method public testStateBeforeAndAfterMajorCompaction() : void in class org.apache.phoenix.coprocessor.StatisticsCollectionRunTrackerIT |
From |
To |
|
Change Variable Type coprocessors : List<String> to coprocessors : Collection<String> in method public upgradeLocalIndexes(metaConnection PhoenixConnection) : PhoenixConnection in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method private getLocalIndexNames(ref HTableInterfaceReference, mutations Collection<Mutation>) : Collection<? extends String> in class org.apache.phoenix.index.PhoenixIndexFailurePolicy |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testTTLAssignmentForNewEmptyCF() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type regionsOfUserTable : List<HRegionInfo> to regionsOfUserTable : List<RegionInfo> in method public testLocalIndexScanAfterRegionsMerge() : void in class org.apache.phoenix.end2end.LocalIndexSplitMergeIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetHTableHColumnAndPhoenixTableProperties() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method private getParallelScans(scan Scan) : List<List<Scan>> in class org.apache.phoenix.iterate.BaseResultIterators |
From |
To |
|
Change Variable Type cdB : HColumnDescriptor to cdB : ColumnFamilyDescriptor in method public testCreateOnExistingTable() : void in class org.apache.phoenix.end2end.QueryDatabaseMetaDataIT |
From |
To |
|
Change Variable Type hri : HRegionInfo to hri : RegionInfo in method private init() : void in class org.apache.phoenix.iterate.TableSnapshotResultIterator |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetHColumnProperties() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type regions : List<HRegionInfo> to regions : List<RegionInfo> in method public testIndexHalfStoreFileReader() : void in class org.apache.phoenix.end2end.index.MutableIndexIT |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSetHTableHColumnAndPhoenixTableProperties() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type tableRegions : List<HRegionInfo> to tableRegions : List<RegionInfo> in method public testLocalIndexAutomaticRepair() : void in class org.apache.phoenix.end2end.index.LocalIndexIT |
From |
To |
|
Change Variable Type newTableDescriptor : HTableDescriptor to newTableDescriptorBuilder : TableDescriptorBuilder in method private separateAndValidateProperties(table PTable, properties Map<String,List<Pair<String,Object>>>, colFamiliesForPColumnsToBeAdded Set<String>, families List<Pair<byte[],Map<String,Object>>>, tableProps Map<String,Object>) : Pair<TableDescriptor,TableDescriptor> in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type hri : HRegionInfo to hri : RegionInfo in method public initSnapshotScanner() : boolean in class org.apache.phoenix.iterate.TableSnapshotResultIterator |
From |
To |
|
Change Variable Type cf : HColumnDescriptor to cf : ColumnFamilyDescriptor in method private ensureLocalIndexTableDropped(physicalTableName byte[], timestamp long) : boolean in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testAddProperyToExistingColumnFamily() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSettingNotHColumnNorPhoenixPropertyEndsUpAsHTableProperty() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type cf : HColumnDescriptor to cf : ColumnFamilyDescriptor in method public testDropLocalIndexShouldDeleteDataFromLocalIndexTable() : void in class org.apache.phoenix.end2end.index.LocalIndexIT |
From |
To |
|
Change Variable Type dataTableRegions : List<Region> to dataTableRegions : List<HRegion> in method public testRecoveryRegionPostOpen() : void in class org.apache.hadoop.hbase.regionserver.wal.WALRecoveryRegionPostOpenIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testCreateTableColumnFamilyHBaseAttribs3() : void in class org.apache.phoenix.end2end.CreateTableIT |
From |
To |
|
Change Variable Type tableDescriptorPair : Pair<HTableDescriptor,HTableDescriptor> to tableDescriptorPair : Pair<TableDescriptor,TableDescriptor> in method public addColumn(tableMetaData List<Mutation>, table PTable, stmtProperties Map<String,List<Pair<String,Object>>>, colFamiliesForPColumnsToBeAdded Set<String>, columns List<PColumn>) : MetaDataMutationResult in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type existingDesc : HTableDescriptor to existingDesc : TableDescriptor in method private ensureTableCreated(physicalTableName byte[], tableType PTableType, props Map<String,Object>, families List<Pair<byte[],Map<String,Object>>>, splits byte[][], modifyExistingMetaData boolean, isNamespaceMapped boolean) : TableDescriptor in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method public hasLocalIndexTable(connection PhoenixConnection, physicalTableName byte[]) : boolean in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Variable Type newDesc : HTableDescriptor to newDesc : TableDescriptorBuilder in method private ensureTableCreated(physicalTableName byte[], tableType PTableType, props Map<String,Object>, families List<Pair<byte[],Map<String,Object>>>, splits byte[][], modifyExistingMetaData boolean, isNamespaceMapped boolean) : TableDescriptor in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type localIndexTables : HTableDescriptor[] to localIndexTables : TableDescriptor[] in method public upgradeLocalIndexes(metaConnection PhoenixConnection) : PhoenixConnection in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type tableRegions : List<HRegionInfo> to tableRegions : List<RegionInfo> in method private ensureTablesOnDifferentRegionServers(tableName1 String, tableName2 String) : void in class org.apache.phoenix.rpc.PhoenixServerRpcIT |
From |
To |
|
Change Variable Type regionsOfUserTable : List<HRegionInfo> to regionsOfUserTable : List<RegionInfo> in method private splitDuringScan(conn1 Connection, tableName String, indexName String, strings String[], admin Admin, isReverse boolean) : List<RegionInfo> in class org.apache.phoenix.end2end.index.MutableIndexSplitIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testSetPropertyAndAddColumnForNewAndExistingColumnFamily() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSetHTableProperties() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type cf : HColumnDescriptor to cf : ColumnFamilyDescriptor in method public hasLocalIndexColumnFamily(desc TableDescriptor) : boolean in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Variable Type indexRegions : List<HRegionInfo> to indexRegions : List<RegionInfo> in method public testIndexHalfStoreFileReader() : void in class org.apache.phoenix.end2end.index.MutableIndexIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testCreateTableColumnFamilyHBaseAttribs4() : void in class org.apache.phoenix.end2end.CreateTableIT |
From |
To |
|
Change Variable Type online : List<Region> to online : List<HRegion> in method private getRegionsFromServerForTable(cluster MiniHBaseCluster, server ServerName, table byte[]) : List<HRegion> in class org.apache.phoenix.hbase.index.write.TestWALRecoveryCaching |
From |
To |
|
Change Variable Type htableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method public testCreateTableToBeTransactional() : void in class org.apache.phoenix.tx.ParameterizedTransactionIT |
From |
To |
|
Change Variable Type colDesc : HColumnDescriptor to colDesc : ColumnFamilyDescriptor in method public testProperties() : void in class org.apache.phoenix.tx.TransactionIT |
From |
To |
|
Change Variable Type keyValue : Entry<ImmutableBytesWritable,ImmutableBytesWritable> to keyValue : Entry<Bytes,Bytes> in method public upgradeLocalIndexes(metaConnection PhoenixConnection) : PhoenixConnection in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type regionManifests : List<SnapshotProtos.SnapshotRegionManifest> to regionManifests : List<SnapshotRegionManifest> in method private getRegionLocationsFromManifest(manifest SnapshotManifest) : List<HRegionLocation> in class org.apache.phoenix.iterate.MapReduceParallelScanGrouper |
From |
To |
|
Change Variable Type tableDescriptor : HTableDescriptor to tableDescriptor : TableDescriptor in method public addColumn(tableMetaData List<Mutation>, table PTable, stmtProperties Map<String,List<Pair<String,Object>>>, colFamiliesForPColumnsToBeAdded Set<String>, columns List<PColumn>) : MetaDataMutationResult in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type tableColDescriptor : HColumnDescriptor to tableColDescriptor : ColumnFamilyDescriptor in method private setSharedIndexMaxVersion(table PTable, tableDescriptor TableDescriptor, indexDescriptorBuilder TableDescriptorBuilder) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type desc : HTableDescriptor to desc : TableDescriptor in method public getLocalIndexColumnFamilies(conn PhoenixConnection, physicalTableName byte[]) : List<byte[]> in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testAddingPkColAndSettingProperties() : void in class org.apache.phoenix.end2end.AlterTableIT |
From |
To |
|
Change Variable Type tableDesc : HTableDescriptor to tableDesc : TableDescriptor in method public testSettingPropertiesWhenTableHasDefaultColFamilySpecified() : void in class org.apache.phoenix.end2end.SetPropertyIT |
From |
To |
|
Change Variable Type indexTable : HTableDescriptor to indexTable : TableDescriptor in method public testTableDescriptorPriority() : void in class org.apache.phoenix.end2end.index.BaseIndexIT |
From |
To |
|
Change Variable Type tables : HTableDescriptor[] to tables : TableDescriptor[] in method private disableAndDropNonSystemTables() : void in class org.apache.phoenix.query.BaseTest |
From |
To |
|
Change Variable Type online : List<Region> to online : List<HRegion> in method private ensureTablesLiveOnSameServer(cluster MiniHBaseCluster, indexTable byte[], primaryTable byte[]) : ServerName in class org.apache.phoenix.hbase.index.write.TestWALRecoveryCaching |
From |
To |
|
Change Variable Type columnDescriptor : HColumnDescriptor to columnDescriptor : ColumnFamilyDescriptor in method private generateTableDescriptor(physicalTableName byte[], existingDesc TableDescriptor, tableType PTableType, tableProps Map<String,Object>, families List<Pair<byte[],Map<String,Object>>>, splits byte[][], isNamespaceMapped boolean) : TableDescriptorBuilder in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type htd : HTableDescriptor to htd : TableDescriptor in method public testTableDescriptorPriority() : void in class org.apache.phoenix.end2end.index.BaseIndexIT |
From |
To |
|
Change Variable Type regions : List<HRegionInfo> to regions : List<RegionInfo> in method public testSplitDuringUpsertSelect() : void in class org.apache.phoenix.execute.UpsertSelectOverlappingBatchesIT |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testCreateTableColumnFamilyHBaseAttribs5() : void in class org.apache.phoenix.end2end.CreateTableIT |
From |
To |
|
Change Variable Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method public testMajorCompactionPreventsUpdateStatsFromRunning() : void in class org.apache.phoenix.coprocessor.StatisticsCollectionRunTrackerIT |
From |
To |
|
Change Variable Type table : HTableDescriptor to table : TableDescriptor in method public upgradeSystemTables(url String, props Properties) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type columnFamilies : HColumnDescriptor[] to columnFamilies : ColumnFamilyDescriptor[] in method public testAddColumnForNewColumnFamily() : void in class org.apache.phoenix.end2end.FlappingAlterTableIT |
From |
To |
|
Change Variable Type regionInfo : HRegionInfo to regionInfo : RegionInfo in method public testUpdateStatsPreventsAnotherUpdateStatsFromRunning() : void in class org.apache.phoenix.coprocessor.StatisticsCollectionRunTrackerIT |
From |
To |
|
Change Variable Type cdC : HColumnDescriptor to cdC : ColumnFamilyDescriptor in method public testCreateOnExistingTable() : void in class org.apache.phoenix.end2end.QueryDatabaseMetaDataIT |
From |
To |
|
Change Variable Type tableDesc3 : HTableDescriptor to tableDesc3 : TableDescriptor in method public testAlteringViewConditionallyModifiesHTableMetadata() : void in class org.apache.phoenix.end2end.AlterMultiTenantTableWithViewsIT |
From |
To |
|
Change Variable Type origTableDescriptor : HTableDescriptor to origTableDescriptor : TableDescriptor in method public addColumn(tableMetaData List<Mutation>, table PTable, stmtProperties Map<String,List<Pair<String,Object>>>, colFamiliesForPColumnsToBeAdded Set<String>, columns List<PColumn>) : MetaDataMutationResult in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type snapshotDescription : HBaseProtos.SnapshotDescription to snapshotDescription : SnapshotDescription in method public getRegionBoundaries(context StatementContext, tableName byte[]) : List<HRegionLocation> in class org.apache.phoenix.iterate.MapReduceParallelScanGrouper |
From |
To |