|
Change Parameter Type writerTable : HTableInterface to writerTable : Table in method public getHTableForCoprocessorScan(env RegionCoprocessorEnvironment, writerTable Table) : Table in class org.apache.phoenix.util.ServerUtil |
From |
To |
|
Change Parameter Type tableName : byte[] to tableName : TableName in method private getTableFromSingletonPool(env RegionCoprocessorEnvironment, tableName TableName) : Table in class org.apache.phoenix.util.ServerUtil |
From |
To |
|
Change Parameter Type tableName : byte[] to tableName : TableName in method public getHTableForCoprocessorScan(env RegionCoprocessorEnvironment, tableName TableName) : Table in class org.apache.phoenix.util.ServerUtil |
From |
To |
|
Change Parameter Type metaTable : HTableInterface to metaTable : Table in method public updateIndexState(indexTableName String, minTimeStamp long, metaTable Table, newState PIndexState) : MetaDataMutationResult in class org.apache.phoenix.util.IndexUtil |
From |
To |
|
Change Parameter Type tableName : byte[] to tableName : TableName in method public clearTableRegionCache(tableName TableName) : void in class org.apache.phoenix.query.DelegateConnectionQueryServices |
From |
To |
|
Change Parameter Type table : HTableInterface to table : Table in method public dumpTable(table Table) : void in class org.apache.phoenix.util.TestUtil |
From |
To |
|
Change Parameter Type metatable : HTableInterface to metatable : Table in method public mapTableToNamespace(admin HBaseAdmin, metatable Table, tableName String, props ReadOnlyProps, ts Long, pTableType PTableType, tenantId PName) : void in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Parameter Type hTable : HTableInterface to hTable : Table in method public TephraTransactionTable(ctx PhoenixTransactionContext, hTable Table) in class org.apache.phoenix.transaction.TephraTransactionTable |
From |
To |
|
Change Parameter Type htable : HTableInterface to htable : Table in method public getTransactionalTable(ctx PhoenixTransactionContext, htable Table) : PhoenixTransactionalTable in class org.apache.phoenix.transaction.TransactionFactory |
From |
To |
|
Change Parameter Type metatable : HTableInterface to metatable : Table in method private mapTableToNamespace(admin HBaseAdmin, metatable Table, srcTableName String, destTableName String, props ReadOnlyProps, ts Long, phoenixTableName String, pTableType PTableType, tenantId PName) : void in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Parameter Type connection : HConnection to connection : Connection in method public getTable(tableName byte[], connection Connection, pool ExecutorService) : Table in class org.apache.phoenix.query.HTableFactory.HTableFactoryImpl |
From |
To |
|
Change Parameter Type htable : HTableInterface to htable : Table in method public getPhoenixTransactionTable(phoenixTransactionContext PhoenixTransactionContext, htable Table, pTable PTable) : PhoenixTransactionalTable in class org.apache.phoenix.util.TransactionUtil |
From |
To |
|
Change Parameter Type delegate : HTableInterface to delegate : Table in method public DelegateHTable(delegate Table) in class org.apache.phoenix.execute.DelegateHTable |
From |
To |
|
Change Parameter Type t : HTableInterface to t : Table in method private insertData(tableName byte[], admin HBaseAdmin, t Table) : void in class org.apache.phoenix.end2end.MappingTableDataTypeIT |
From |
To |
|
Change Parameter Type hTable : HTableInterface to hTable : Table in method public TephraTransactionTable(ctx PhoenixTransactionContext, hTable Table, pTable PTable) in class org.apache.phoenix.transaction.TephraTransactionTable |
From |
To |
|
Change Parameter Type statsHTable : HTableInterface to statsHTable : Table in method public readStatistics(statsHTable Table, key GuidePostsKey, clientTimeStamp long) : GuidePostsInfo in class org.apache.phoenix.schema.stats.StatisticsUtil |
From |
To |
|
Change Parameter Type tableName : byte[] to name : TableName in method public clearTableRegionCache(name TableName) : void in class org.apache.phoenix.query.ConnectionQueryServices |
From |
To |
|
Change Parameter Type statsTable : HTableInterface to statsTable : Table in method public truncateStats(metaTable Table, statsTable Table) : boolean in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Parameter Type statsWriterTable : HTableInterface to statsWriterTable : Table in method private StatisticsWriter(statsReaderTable Table, statsWriterTable Table, tableName String, clientTimeStamp long, guidePostDepth long) in class org.apache.phoenix.schema.stats.StatisticsWriter |
From |
To |
|
Change Parameter Type htable : HTableInterface to htable : Table in method public addServerCache(htable Table, key byte[], cacheUsingTable PTable, cacheId byte[], cachePtr ImmutableBytesWritable, cacheFactory ServerCacheFactory, txState byte[]) : boolean in class org.apache.phoenix.cache.ServerCacheClient |
From |
To |
|
Change Parameter Type statsReaderTable : HTableInterface to statsReaderTable : Table in method private StatisticsWriter(statsReaderTable Table, statsWriterTable Table, tableName String, clientTimeStamp long, guidePostDepth long) in class org.apache.phoenix.schema.stats.StatisticsWriter |
From |
To |
|
Change Parameter Type metaTable : HTableInterface to metaTable : Table in method public updateIndexState(indexTableKey byte[], minTimeStamp long, metaTable Table, newState PIndexState) : MetaDataMutationResult in class org.apache.phoenix.util.IndexUtil |
From |
To |
|
Change Parameter Type htable : HTableInterface to htable : Table in method private assertTenantIds(e Expression, htable Table, filter Filter, tenantIds String[]) : void in class org.apache.phoenix.end2end.PhoenixRuntimeIT |
From |
To |
|
Change Parameter Type connection : HConnection to connection : Connection in method public getTable(tableName byte[], connection Connection, pool ExecutorService) : Table in class org.apache.phoenix.query.HTableFactory |
From |
To |
|
Change Parameter Type delegate : HTableInterface to delegate : Table in method private MetaDataAwareHTable(delegate Table, tableRef TableRef) in class org.apache.phoenix.execute.MutationState.MetaDataAwareHTable |
From |
To |
|
Change Parameter Type tables : Map<ImmutableBytesPtr,HTableInterface> to tables : Map<ImmutableBytesPtr,Table> in method public FakeTableFactory(tables Map<ImmutableBytesPtr,Table>) in class org.apache.phoenix.hbase.index.write.FakeTableFactory |
From |
To |
|
Change Parameter Type keyValue : KeyValue to keyValue : Cell in method private addSaltByte(keyValue Cell, nSaltBuckets int) : KeyValue in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Parameter Type metaTable : HTableInterface to metaTable : Table in method public truncateStats(metaTable Table, statsTable Table) : boolean in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public run() : void in class org.apache.phoenix.coprocessor.MetaDataRegionObserver.postOpen.r |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method private initTableValues() : String in class org.apache.phoenix.end2end.NativeHBaseTypesIT |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testDeleteAfterFailure() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type t : HTableInterface to t : Table in method public testDisabledLocalIndexes() : void in class org.apache.phoenix.end2end.DisableLocalIndexIT |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method private findChildViews_4_11(region Region, tenantId byte[], schemaName byte[], tableName byte[]) : TableViewFinder in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method private initGuidepostDepth() : void in class org.apache.phoenix.schema.stats.DefaultStatisticsCollector |
From |
To |
|
Change Variable Type statsWriterTable : HTableInterface to statsWriterTable : Table in method public newWriter(env RegionCoprocessorEnvironment, tableName String, clientTimeStamp long, guidePostDepth long) : StatisticsWriter in class org.apache.phoenix.schema.stats.StatisticsWriter |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public clearCache() : long in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testUpdateIndexState() : void in class org.apache.phoenix.end2end.MetaDataEndPointIT |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method private testIndexWriteFailureDuringRebuild(indexStateOnFailure PIndexState) : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type hIndex : HTableInterface to hIndex : Table in method private assertNoIndexDeletes(conn Connection, minTimestamp long, fullIndexName String) : void in class org.apache.phoenix.end2end.index.BaseIndexIT |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public testIndexHalfStoreFileReader() : void in class org.apache.phoenix.end2end.index.MutableIndexIT |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method private findChildViews_deprecated(region Region, tenantId byte[], table PTable, linkTypeBytes byte[]) : TableViewFinder in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl |
From |
To |
|
Change Variable Type tables : Map<ImmutableBytesPtr,HTableInterface> to tables : Map<ImmutableBytesPtr,Table> in method public testSynchronouslyCompletesAllWrites() : void in class org.apache.phoenix.hbase.index.write.TestIndexWriter |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public testSynchronouslyCompletesAllWrites() : void in class org.apache.phoenix.hbase.index.write.TestParalleIndexWriter |
From |
To |
|
Change Variable Type regularHConnection : HConnection to regularHConnection : Connection in method public testRebuildIndexConnectionProperties() : void in class org.apache.phoenix.end2end.RebuildIndexConnectionPropsIT |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public wrapResultUsingOffset(environment RegionCoprocessorEnvironment, result List<Cell>, offset int, dataColumns ColumnReference[], tupleProjector TupleProjector, dataRegion Region, indexMaintainer IndexMaintainer, viewConstants byte[][], ptr ImmutableBytesWritable) : void in class org.apache.phoenix.util.IndexUtil |
From |
To |
|
Change Variable Type keyValue : KeyValue to keyValue : Cell in method public truncateStats(metaTable Table, statsTable Table) : boolean in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type t : HTableInterface to t : Table in method public testMappingHbaseTableToPhoenixTable() : void in class org.apache.phoenix.end2end.MappingTableDataTypeIT |
From |
To |
|
Change Variable Type ht : HTableInterface to ht : Table in method private checkClientServerCompatibility(metaTable byte[]) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public dumpIndexStatus(conn Connection, indexName String) : void in class org.apache.phoenix.util.TestUtil |
From |
To |
|
Change Variable Type htable7 : HTableInterface to htable7 : Table in method private testGetTenantIdExpression(isSalted boolean) : void in class org.apache.phoenix.end2end.PhoenixRuntimeIT |
From |
To |
|
Change Variable Type htable2 : HTableInterface to htable2 : Table in method private testGetTenantIdExpression(isSalted boolean) : void in class org.apache.phoenix.end2end.PhoenixRuntimeIT |
From |
To |
|
Change Variable Type systemTable : HTableInterface to systemTable : Table in method private handleFailureWithExceptions(attempted Multimap<HTableInterfaceReference,Mutation>, cause Exception) : long in class org.apache.phoenix.index.PhoenixIndexFailurePolicy |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public testColumnQualifierForUpsertedValues() : void in class org.apache.phoenix.end2end.UpsertValuesIT |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method public initTable() : void in class org.apache.phoenix.end2end.DynamicColumnIT |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method public returnSequences(keys List<SequenceKey>, timestamp long, exceptions SQLException[]) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testUpperBoundSetOnRebuild() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testTimeBatchesInCoprocessorRequired() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type statsHTable : HTableInterface to statsHTable : Table in method public load(statsKey GuidePostsKey) : GuidePostsInfo in class org.apache.phoenix.query.GuidePostsCache.StatsLoader |
From |
To |
|
Change Variable Type tables : Map<ImmutableBytesPtr,HTableInterface> to tables : Map<ImmutableBytesPtr,Table> in method public testSynchronouslyCompletesAllWrites() : void in class org.apache.phoenix.hbase.index.write.TestParalleIndexWriter |
From |
To |
|
Change Variable Type keyValue : KeyValue to keyValue : Cell in method private copyTable(conn PhoenixConnection, sourceName byte[], targetName byte[]) : void in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public addServerCache(keyRanges ScanRanges, cachePtr ImmutableBytesWritable, txState byte[], cacheFactory ServerCacheFactory, cacheUsingTableRef TableRef, storeCacheOnClient boolean) : ServerCache in class org.apache.phoenix.cache.ServerCacheClient |
From |
To |
|
Change Variable Type hindex : HTableInterface to hindex : Table in method public delete(deletes List<Delete>) : void in class org.apache.phoenix.execute.MutationState.MetaDataAwareHTable |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method private incrementSequenceValues(sequenceAllocations List<SequenceAllocation>, timestamp long, values long[], exceptions SQLException[], op Sequence.ValueOp) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method public testNegativeCompareNegativeValue() : void in class org.apache.phoenix.end2end.NativeHBaseTypesIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public testCreateViewOnExistingTable() : void in class org.apache.phoenix.end2end.QueryDatabaseMetaDataIT |
From |
To |
|
Change Variable Type statsTable : HTableInterface to statsTable : Table in method public run() : void in class org.apache.phoenix.coprocessor.MetaDataRegionObserver.postOpen.r |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public call() : Boolean in class org.apache.phoenix.hbase.index.write.TrackingParallelWriterIndexCommitter.write.add |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testDeleteBeforeFailure() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public testSelectFromViewOnExistingTable() : void in class org.apache.phoenix.end2end.ColumnProjectionOptimizationIT |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public testSynchronouslyCompletesAllWrites() : void in class org.apache.phoenix.hbase.index.write.TestParalleWriterIndexCommitter |
From |
To |
|
Change Variable Type statsReaderTable : HTableInterface to statsReaderTable : Table in method public newWriter(env RegionCoprocessorEnvironment, tableName String, clientTimeStamp long, guidePostDepth long) : StatisticsWriter in class org.apache.phoenix.schema.stats.StatisticsWriter |
From |
To |
|
Change Variable Type htable5 : HTableInterface to htable5 : Table in method private testGetTenantIdExpression(isSalted boolean) : void in class org.apache.phoenix.end2end.PhoenixRuntimeIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public dropSequence(tenantId String, schemaName String, sequenceName String, timestamp long) : long in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method private returnAllSequences(sequenceMap ConcurrentMap<SequenceKey,Sequence>) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public clearTableFromCache(tenantId byte[], schemaName byte[], tableName byte[], clientTS long) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method private getIndexUpdates(env RegionCoprocessorEnvironment, indexMetaData PhoenixIndexMetaData, mutationIterator Iterator<Mutation>, txRollbackAttribute byte[]) : Collection<Pair<Mutation,byte[]>> in class org.apache.phoenix.index.PhoenixTransactionalIndexer |
From |
To |
|
Change Variable Type tables : Map<ImmutableBytesPtr,HTableInterface> to tables : Map<ImmutableBytesPtr,Table> in method public testShutdownInterruptsAsExpected() : void in class org.apache.phoenix.hbase.index.write.TestIndexWriter |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testMultiVersionsAfterFailure() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type keyValue : KeyValue to keyValue : Cell in method public upgradeSequenceTable(conn PhoenixConnection, nSaltBuckets int, oldTable PTable) : boolean in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testUpsertNullTwiceAfterFailure() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testTableSentWhenIndexStateChanges() : void in class org.apache.phoenix.end2end.UpdateCacheAcrossDifferentClientsIT |
From |
To |
|
Change Variable Type metatable : HTableInterface to metatable : Table in method public upgradeTable(conn PhoenixConnection, srcTable String) : void in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public addServerCache(startkeyOfRegion byte[], cache ServerCache, cacheFactory HashCacheFactory, txState byte[], pTable PTable) : boolean in class org.apache.phoenix.cache.ServerCacheClient |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testWriteWhileRebuilding() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type iterateOverTable : HTableInterface to iterateOverTable : Table in method private removeServerCache(cache ServerCache, remainingOnServers Set<HRegionLocation>) : void in class org.apache.phoenix.cache.ServerCacheClient |
From |
To |
|
Change Variable Type sysMutexTable : HTableInterface to sysMutexTable : Table in method public releaseUpgradeMutex(mutexRowKey byte[]) : boolean in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public testCreateTableToBeTransactional() : void in class org.apache.phoenix.tx.ParameterizedTransactionIT |
From |
To |
|
Change Variable Type tables : Map<ImmutableBytesPtr,HTableInterface> to tables : Map<ImmutableBytesPtr,Table> in method public testSynchronouslyCompletesAllWrites() : void in class org.apache.phoenix.hbase.index.write.TestParalleWriterIndexCommitter |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method private send(tableRefIterator Iterator<TableRef>) : void in class org.apache.phoenix.execute.MutationState |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testMultiValuesAtSameTS() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type sysTable : HTableInterface to sysTable : Table in method public upgradeSequenceTable(conn PhoenixConnection, nSaltBuckets int, oldTable PTable) : boolean in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public getResolverForCreation(statement CreateTableStatement, connection PhoenixConnection) : ColumnResolver in class org.apache.phoenix.compile.FromCompiler |
From |
To |
|
Change Variable Type hTable : HTableInterface to hTable : Table in method private initTableValues() : void in class org.apache.phoenix.end2end.DynamicFamilyIT |
From |
To |
|
Change Variable Type htable3 : HTableInterface to htable3 : Table in method private testGetTenantIdExpression(isSalted boolean) : void in class org.apache.phoenix.end2end.PhoenixRuntimeIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public testMakeBaseTableTransactional() : void in class org.apache.phoenix.end2end.AlterTableWithViewsIT |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testLocalIndexAutomaticRepair() : void in class org.apache.phoenix.end2end.index.LocalIndexIT |
From |
To |
|
Change Variable Type seqTable : HTableInterface to seqTable : Table in method public upgradeSequenceTable(conn PhoenixConnection, nSaltBuckets int, oldTable PTable) : boolean in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type connection : HConnection to connection : Connection in method private generateSplits(jobConf JobConf, qplan QueryPlan, splits List<KeyRange>, query String) : List<InputSplit> in class org.apache.phoenix.hive.mapreduce.PhoenixInputFormat |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public getTableDescriptor(tableName byte[]) : HTableDescriptor in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testDeleteAndUpsertValuesAtSameTS2() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public testNonTxToTxTable() : void in class org.apache.phoenix.tx.ParameterizedTransactionIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public clearMetaDataCache(conn Connection) : void in class org.apache.phoenix.util.TestUtil |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public call() : Void in class org.apache.phoenix.hbase.index.write.ParallelWriterIndexCommitter.write.add |
From |
To |
|
Change Variable Type pool : HTablePool to conn : Connection in method private getTableFromSingletonPool(env RegionCoprocessorEnvironment, tableName TableName) : Table in class org.apache.phoenix.util.ServerUtil |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public doMajorCompaction(conn Connection, tableName String) : void in class org.apache.phoenix.util.TestUtil |
From |
To |
|
Change Variable Type target : HTableInterface to target : Table in method private copyTable(conn PhoenixConnection, sourceName byte[], targetName byte[]) : void in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type ht : HTableInterface to ht : Table in method private metaDataCoprocessorExec(tableKey byte[], callable Batch.Call<MetaDataService,MetaDataResponse>, tableName byte[]) : MetaDataMutationResult in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type hcon : HConnection to hcon : Connection in method public tableRegionsOnline(conf Configuration, table PTable) : boolean in class org.apache.phoenix.util.MetaDataUtil |
From |
To |
|
Change Variable Type rebuildIndexHConnection : HConnection to rebuildIndexHConnection : Connection in method public testRebuildIndexConnectionProperties() : void in class org.apache.phoenix.end2end.RebuildIndexConnectionPropsIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method private testCompactUpdatesStats(statsUpdateFreq Integer, tableName String) : void in class org.apache.phoenix.end2end.StatsCollectorIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public createSequence(tenantId String, schemaName String, sequenceName String, startWith long, incrementBy long, cacheSize long, minValue long, maxValue long, cycle boolean, timestamp long) : long in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type htable6 : HTableInterface to htable6 : Table in method private testGetTenantIdExpression(isSalted boolean) : void in class org.apache.phoenix.end2end.PhoenixRuntimeIT |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testUpsertNullAfterFailure() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method protected testUpdatableViewWithIndex(saltBuckets Integer, localIndex boolean) : void in class org.apache.phoenix.end2end.BaseViewIT |
From |
To |
|
Change Variable Type htable1 : HTableInterface to htable1 : Table in method private testGetTenantIdExpression(isSalted boolean) : void in class org.apache.phoenix.end2end.PhoenixRuntimeIT |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public run() : void in class org.apache.phoenix.coprocessor.MetaDataRegionObserver.BuildIndexScheduleTask |
From |
To |
|
Change Variable Type sysMutexTable : HTableInterface to sysMutexTable : Table in method package createSysMutexTable(admin HBaseAdmin, props ReadOnlyProps) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type source : HTableInterface to source : Table in method private copyTable(conn PhoenixConnection, sourceName byte[], targetName byte[]) : void in class org.apache.phoenix.util.UpgradeUtil |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testMultiValuesWhenDisableAndInactive() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testDeleteAndUpsertValuesAtSameTS1() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type sysMutexTable : HTableInterface to sysMutexTable : Table in method private putUnlockKVInSysMutex(row byte[]) : void in class org.apache.phoenix.end2end.UpgradeIT |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testCompactionDuringRebuild() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public getHTable(table PTable) : Table in class org.apache.phoenix.execute.MutationState |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testConcurrentUpsertsWithRebuild() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method private removeBaseColumnCountKV(tenantId String, schemaName String, tableName String) : void in class org.apache.phoenix.end2end.UpgradeIT |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public testNonTxToTxTableFailure() : void in class org.apache.phoenix.tx.ParameterizedTransactionIT |
From |
To |
|
Change Variable Type metatable : HTableInterface to metatable : Table in method package ensureSystemTablesMigratedToSystemNamespace(props ReadOnlyProps) : void in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type htable : HTableInterface to htable : Table in method public testExternalTxContext() : void in class org.apache.phoenix.tx.FlappingTransactionIT |
From |
To |
|
Change Variable Type table : HTableInterface to table : Table in method public testSynchronouslyCompletesAllWrites() : void in class org.apache.phoenix.hbase.index.write.TestIndexWriter |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testBatchingDuringRebuild() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |
|
Change Variable Type sysMutexTable : HTableInterface to sysMutexTable : Table in method public acquireUpgradeMutex(currentServerSideTableTimestamp long, rowToLock byte[]) : boolean in class org.apache.phoenix.query.ConnectionQueryServicesImpl |
From |
To |
|
Change Variable Type statsHTable : HTableInterface to statsHTable : Table in method public testEmptyGuidePostGeneratedWhenDataSizeLessThanGPWidth() : void in class org.apache.phoenix.end2end.StatsCollectorIT |
From |
To |
|
Change Variable Type htableForRawScan : HTableInterface to htableForRawScan : Table in method public doMajorCompaction(conn Connection, tableName String) : void in class org.apache.phoenix.util.TestUtil |
From |
To |
|
Change Variable Type metaTable : HTableInterface to metaTable : Table in method public testDeleteAndUpsertAfterFailure() : void in class org.apache.phoenix.end2end.index.PartialIndexRebuilderIT |
From |
To |