|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<?> in method public avg(table AsyncTable<?>, ci ColumnInterpreter<R,S,P,Q,T>, scan Scan) : CompletableFuture<Double> in class org.apache.hadoop.hbase.client.coprocessor.AsyncAggregationClient |
From |
To |
|
Change Parameter Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method public getTableHRegionLocations(metaTable AsyncTable<AdvancedScanResultConsumer>, tableName Optional<TableName>) : CompletableFuture<List<HRegionLocation>> in class org.apache.hadoop.hbase.AsyncMetaTableAccessor |
From |
To |
|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<?> in method private sumByRegion(table AsyncTable<?>, ci ColumnInterpreter<R,S,P,Q,T>, scan Scan) : CompletableFuture<NavigableMap<byte[],S>> in class org.apache.hadoop.hbase.client.coprocessor.AsyncAggregationClient |
From |
To |
|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<AdvancedScanResultConsumer> in method public AsyncTableResultScanner(table AsyncTable<AdvancedScanResultConsumer>, scan Scan, maxCacheSize long) in class org.apache.hadoop.hbase.client.AsyncTableResultScanner |
From |
To |
|
Change Parameter Type table : AsyncTableBase to table : AsyncTable<?> in method package AsyncBufferedMutatorImpl(table AsyncTable<?>, writeBufferSize long) in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl |
From |
To |
|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<AdvancedScanResultConsumer> in method private findMedian(future CompletableFuture<R>, table AsyncTable<AdvancedScanResultConsumer>, ci ColumnInterpreter<R,S,P,Q,T>, scan Scan, sumByRegion NavigableMap<byte[],S>) : void in class org.apache.hadoop.hbase.client.coprocessor.AsyncAggregationClient |
From |
To |
|
Change Parameter Type metaTable : RawAsyncTable to metaTable : AsyncTable<?> in method public getRegionLocationWithEncodedName(metaTable AsyncTable<?>, encodedRegionName byte[]) : CompletableFuture<Optional<HRegionLocation>> in class org.apache.hadoop.hbase.AsyncMetaTableAccessor |
From |
To |
|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<?> in method public rowCount(table AsyncTable<?>, ci ColumnInterpreter<R,S,P,Q,T>, scan Scan) : CompletableFuture<Long> in class org.apache.hadoop.hbase.client.coprocessor.AsyncAggregationClient |
From |
To |
|
Change Parameter Type info : HRegionInfo to info : RegionInfo in method package noMoreResultsForReverseScan(scan Scan, info RegionInfo) : boolean in class org.apache.hadoop.hbase.client.ConnectionUtils |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method public coprocessorService(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>, serverName ServerName) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method public coprocessorService(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin |
From |
To |
|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<?> in method public std(table AsyncTable<?>, ci ColumnInterpreter<R,S,P,Q,T>, scan Scan) : CompletableFuture<Double> in class org.apache.hadoop.hbase.client.coprocessor.AsyncAggregationClient |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method public coprocessorService(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>, callback CoprocessorCallback<R>) : CoprocessorServiceBuilder<S,R> in class org.apache.hadoop.hbase.client.RawAsyncTableImpl |
From |
To |
|
Change Parameter Type rawTable : RawAsyncTable to rawTable : AsyncTable<AdvancedScanResultConsumer> in method package AsyncTableImpl(conn AsyncConnectionImpl, rawTable AsyncTable<AdvancedScanResultConsumer>, pool ExecutorService) in class org.apache.hadoop.hbase.client.AsyncTableImpl |
From |
To |
|
Change Parameter Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method private scanMeta(metaTable AsyncTable<AdvancedScanResultConsumer>, startRow Optional<byte[]>, stopRow Optional<byte[]>, type QueryType, maxRows int, visitor Visitor) : CompletableFuture<Void> in class org.apache.hadoop.hbase.AsyncMetaTableAccessor |
From |
To |
|
Change Parameter Type consumer : RawScanResultConsumer to consumer : AdvancedScanResultConsumer in method public AsyncScanSingleRegionRpcRetryingCaller(retryTimer HashedWheelTimer, conn AsyncConnectionImpl, scan Scan, scanMetrics ScanMetrics, scannerId long, resultCache ScanResultCache, consumer AdvancedScanResultConsumer, stub Interface, loc HRegionLocation, isRegionServerRemote boolean, scannerLeaseTimeoutPeriodNs long, pauseNs long, maxAttempts int, scanTimeoutNs long, rpcTimeoutNs long, startLogErrorsCnt int) in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller |
From |
To |
|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<?> in method public min(table AsyncTable<?>, ci ColumnInterpreter<R,S,P,Q,T>, scan Scan) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.coprocessor.AsyncAggregationClient |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method private coprocessorService(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>, region RegionInfo, row byte[]) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.RawAsyncTableImpl |
From |
To |
|
Change Parameter Type info : HRegionInfo to info : RegionInfo in method package noMoreResultsForScan(scan Scan, info RegionInfo) : boolean in class org.apache.hadoop.hbase.client.ConnectionUtils |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method public coprocessorService(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>, row byte[]) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.RawAsyncTableImpl |
From |
To |
|
Change Parameter Type consumer : RawScanResultConsumer to consumer : AdvancedScanResultConsumer in method public AsyncClientScanner(scan Scan, consumer AdvancedScanResultConsumer, tableName TableName, conn AsyncConnectionImpl, pauseNs long, maxAttempts int, scanTimeoutNs long, rpcTimeoutNs long, startLogErrorsCnt int) in class org.apache.hadoop.hbase.client.AsyncClientScanner |
From |
To |
|
Change Parameter Type metaTable : RawAsyncTable to metaTable : AsyncTable<?> in method public getRegionLocation(metaTable AsyncTable<?>, regionName byte[]) : CompletableFuture<Optional<HRegionLocation>> in class org.apache.hadoop.hbase.AsyncMetaTableAccessor |
From |
To |
|
Change Parameter Type consumer : RawScanResultConsumer to consumer : AdvancedScanResultConsumer in method public scan(scan Scan, consumer AdvancedScanResultConsumer) : void in class org.apache.hadoop.hbase.client.RawAsyncTableImpl |
From |
To |
|
Change Parameter Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method private scanMeta(metaTable AsyncTable<AdvancedScanResultConsumer>, tableName Optional<TableName>, type QueryType, visitor Visitor) : CompletableFuture<Void> in class org.apache.hadoop.hbase.AsyncMetaTableAccessor |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method public coprocessorService(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method public coprocessorService(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>, serverName ServerName) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin |
From |
To |
|
Change Parameter Type metaTable : RawAsyncTable to metaTable : AsyncTable<?> in method public getTableState(metaTable AsyncTable<?>, tableName TableName) : CompletableFuture<Optional<TableState>> in class org.apache.hadoop.hbase.AsyncMetaTableAccessor |
From |
To |
|
Change Parameter Type consumer : RawScanResultConsumer to consumer : AdvancedScanResultConsumer in method public consumer(consumer AdvancedScanResultConsumer) : ScanSingleRegionCallerBuilder in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder |
From |
To |
|
Change Parameter Type metaTable : RawAsyncTable to metaTable : AsyncTable<?> in method private getMetaScan(metaTable AsyncTable<?>, rowUpperLimit int) : Scan in class org.apache.hadoop.hbase.AsyncMetaTableAccessor |
From |
To |
|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<?> in method public max(table AsyncTable<?>, ci ColumnInterpreter<R,S,P,Q,T>, scan Scan) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.coprocessor.AsyncAggregationClient |
From |
To |
|
Change Parameter Type metaTable : RawAsyncTable to metaTable : AsyncTable<?> in method public tableExists(metaTable AsyncTable<?>, tableName TableName) : CompletableFuture<Boolean> in class org.apache.hadoop.hbase.AsyncMetaTableAccessor |
From |
To |
|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<AdvancedScanResultConsumer> in method public median(table AsyncTable<AdvancedScanResultConsumer>, ci ColumnInterpreter<R,S,P,Q,T>, scan Scan) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.coprocessor.AsyncAggregationClient |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method private onLocateComplete(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>, callback CoprocessorCallback<R>, locs List<HRegionLocation>, endKey byte[], endKeyInclusive boolean, locateFinished AtomicBoolean, unfinishedRequest AtomicInteger, loc HRegionLocation, error Throwable) : void in class org.apache.hadoop.hbase.client.RawAsyncTableImpl |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method public coprocessorService(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.AsyncAdmin |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method public coprocessorService(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>, serverName ServerName) : CompletableFuture<R> in class org.apache.hadoop.hbase.client.AsyncAdmin |
From |
To |
|
Change Parameter Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method private getTableRegionsAndLocations(metaTable AsyncTable<AdvancedScanResultConsumer>, tableName Optional<TableName>, excludeOfflinedSplitParents boolean) : CompletableFuture<List<Pair<RegionInfo,ServerName>>> in class org.apache.hadoop.hbase.AsyncMetaTableAccessor |
From |
To |
|
Change Parameter Type table : RawAsyncTable to table : AsyncTable<?> in method public sum(table AsyncTable<?>, ci ColumnInterpreter<R,S,P,Q,T>, scan Scan) : CompletableFuture<S> in class org.apache.hadoop.hbase.client.coprocessor.AsyncAggregationClient |
From |
To |
|
Change Parameter Type callable : CoprocessorCallable<S,R> to callable : ServiceCaller<S,R> in method public CoprocessorServiceBuilderImpl(stubMaker Function<RpcChannel,S>, callable ServiceCaller<S,R>, callback CoprocessorCallback<R>) in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CoprocessorServiceBuilderImpl |
From |
To |
|
Change Return Type AsyncTableBuilder<AsyncTable> to AsyncTableBuilder<ScanResultConsumer> in method public getTableBuilder(tableName TableName, pool ExecutorService) : AsyncTableBuilder<ScanResultConsumer> in class org.apache.hadoop.hbase.client.AsyncConnection |
From |
To |
|
Change Return Type AsyncTableBuilder<RawAsyncTable> to AsyncTableBuilder<AdvancedScanResultConsumer> in method public getTableBuilder(tableName TableName) : AsyncTableBuilder<AdvancedScanResultConsumer> in class org.apache.hadoop.hbase.client.AsyncConnectionImpl |
From |
To |
|
Change Return Type AsyncTableBuilder<T> to AsyncTableBuilder<C> in method public setOperationTimeout(timeout long, unit TimeUnit) : AsyncTableBuilder<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type AsyncTableBuilder<T> to AsyncTableBuilder<C> in method public setStartLogErrorsCnt(startLogErrorsCnt int) : AsyncTableBuilder<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type RawAsyncTable to AsyncTable<?> in method private getRawTable(tableName TableName) : AsyncTable<?> in class org.apache.hadoop.hbase.client.TestAsyncTableBatch |
From |
To |
|
Change Return Type RawAsyncTable to AsyncTable<AdvancedScanResultConsumer> in method public getTable(tableName TableName) : AsyncTable<AdvancedScanResultConsumer> in class org.apache.hadoop.hbase.client.AsyncConnection |
From |
To |
|
Change Return Type AsyncTableBuilderBase<T> to AsyncTableBuilderBase<C> in method public setRetryPause(pause long, unit TimeUnit) : AsyncTableBuilderBase<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase |
From |
To |
|
Change Return Type AsyncTableBuilder<T> to AsyncTableBuilder<C> in method public setWriteRpcTimeout(timeout long, unit TimeUnit) : AsyncTableBuilder<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type AsyncTableBuilderBase<T> to AsyncTableBuilderBase<C> in method public setWriteRpcTimeout(timeout long, unit TimeUnit) : AsyncTableBuilderBase<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase |
From |
To |
|
Change Return Type AsyncTable to AsyncTable<?> in method private getTable(tableName TableName) : AsyncTable<?> in class org.apache.hadoop.hbase.client.TestAsyncTableBatch |
From |
To |
|
Change Return Type AsyncTableBuilder<T> to AsyncTableBuilder<C> in method public setReadRpcTimeout(timeout long, unit TimeUnit) : AsyncTableBuilder<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type AsyncTableBuilder<T> to AsyncTableBuilder<C> in method public setMaxRetries(maxRetries int) : AsyncTableBuilder<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type AsyncTableBuilder<RawAsyncTable> to AsyncTableBuilder<AdvancedScanResultConsumer> in method public getTableBuilder(tableName TableName) : AsyncTableBuilder<AdvancedScanResultConsumer> in class org.apache.hadoop.hbase.client.AsyncConnection |
From |
To |
|
Change Return Type AsyncTableBuilder<T> to AsyncTableBuilder<C> in method public setScanTimeout(timeout long, unit TimeUnit) : AsyncTableBuilder<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type AsyncTableBuilder<AsyncTable> to AsyncTableBuilder<ScanResultConsumer> in method public getTableBuilder(tableName TableName, pool ExecutorService) : AsyncTableBuilder<ScanResultConsumer> in class org.apache.hadoop.hbase.client.AsyncConnectionImpl |
From |
To |
|
Change Return Type AsyncTableBuilder<T> to AsyncTableBuilder<C> in method public setRpcTimeout(timeout long, unit TimeUnit) : AsyncTableBuilder<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type AsyncTableBuilderBase<T> to AsyncTableBuilderBase<C> in method public setScanTimeout(timeout long, unit TimeUnit) : AsyncTableBuilderBase<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase |
From |
To |
|
Change Return Type AsyncTableBuilderBase<T> to AsyncTableBuilderBase<C> in method public setStartLogErrorsCnt(startLogErrorsCnt int) : AsyncTableBuilderBase<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase |
From |
To |
|
Change Return Type AsyncTable to AsyncTable<ScanResultConsumer> in method public getTable(tableName TableName, pool ExecutorService) : AsyncTable<ScanResultConsumer> in class org.apache.hadoop.hbase.client.AsyncConnection |
From |
To |
|
Change Return Type AsyncTableBuilderBase<T> to AsyncTableBuilderBase<C> in method public setRpcTimeout(timeout long, unit TimeUnit) : AsyncTableBuilderBase<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase |
From |
To |
|
Change Return Type T to AsyncTable<C> in method public build() : AsyncTable<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type AsyncTableBuilderBase<T> to AsyncTableBuilderBase<C> in method public setMaxAttempts(maxAttempts int) : AsyncTableBuilderBase<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase |
From |
To |
|
Change Return Type AsyncTableBuilder<T> to AsyncTableBuilder<C> in method public setMaxAttempts(maxAttempts int) : AsyncTableBuilder<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type AsyncTableBuilder<T> to AsyncTableBuilder<C> in method public setRetryPause(pause long, unit TimeUnit) : AsyncTableBuilder<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilder |
From |
To |
|
Change Return Type RawAsyncTable to AsyncTable<?> in method private getRawTable() : AsyncTable<?> in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Return Type AsyncTableBuilderBase<T> to AsyncTableBuilderBase<C> in method public setOperationTimeout(timeout long, unit TimeUnit) : AsyncTableBuilderBase<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase |
From |
To |
|
Change Return Type AsyncTable to AsyncTable<?> in method private getTable() : AsyncTable<?> in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Return Type AsyncTableBuilderBase<T> to AsyncTableBuilderBase<C> in method public setReadRpcTimeout(timeout long, unit TimeUnit) : AsyncTableBuilderBase<C> in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase |
From |
To |
|
Change Variable Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method public testCreateTableNumberOfRegions() : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method public testIncrement() : void in class org.apache.hadoop.hbase.client.TestAsyncTableNoncedRetry |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method private testTruncateTable(tableName TableName, preserveSplits boolean) : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public test() : void in class org.apache.hadoop.hbase.client.TestAsyncTableBatch |
From |
To |
|
Change Variable Type consumer : SimpleRawScanResultConsumer to consumer : BufferingScanResultConsumer in method private doScanWithRawAsyncTable(scan Scan) : Pair<List<Result>,ScanMetrics> in class org.apache.hadoop.hbase.client.TestAsyncTableScanMetrics |
From |
To |
|
Change Variable Type hri : HRegionInfo to hri : RegionInfo in method public testCreateTableWithRegions() : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |
|
Change Variable Type rawTableGetter : Function<TableName,AsyncTableBase> to rawTableGetter : Function<TableName,AsyncTable<?>> in method public params() : List<Object[]> in class org.apache.hadoop.hbase.client.TestAsyncTableBatch |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<AdvancedScanResultConsumer> in method private doTest(reversed boolean) : void in class org.apache.hadoop.hbase.client.TestRawAsyncScanCursor |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method private startAndWriteData(tableName TableName, value byte[]) : HRegionServer in class org.apache.hadoop.hbase.client.TestAsyncClusterAdminApi |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testCheckAndMutate() : void in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Variable Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method public testSplitSwitch() : void in class org.apache.hadoop.hbase.client.TestAsyncRegionAdminApi |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testMixed() : void in class org.apache.hadoop.hbase.client.TestAsyncTableBatch |
From |
To |
|
Change Variable Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method public testMergeRegions() : void in class org.apache.hadoop.hbase.client.TestAsyncRegionAdminApi |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method private splitTest(tableName TableName, rowCount int, isSplitRegion boolean, splitPoint byte[]) : void in class org.apache.hadoop.hbase.client.TestAsyncRegionAdminApi |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method private loadData(tableName TableName, families byte[][], rows int, flushes int) : void in class org.apache.hadoop.hbase.client.TestAsyncRegionAdminApi |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method public testLocateError() : void in class org.apache.hadoop.hbase.client.TestAsyncSingleRequestRpcRetryingCaller |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testCheckAndPut() : void in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Variable Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method private splitTest(tableName TableName, rowCount int, isSplitRegion boolean, splitPoint byte[]) : void in class org.apache.hadoop.hbase.client.TestAsyncRegionAdminApi |
From |
To |
|
Change Variable Type info : HRegionInfo to info : RegionInfo in method private onScanComplete(tableName TableName, req LocateRequest, results List<Result>, error Throwable) : void in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator |
From |
To |
|
Change Variable Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method public testCreateTableWithRegions() : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |
|
Change Variable Type asyncTable : RawAsyncTable to asyncTable : AsyncTable<?> in method private createAndLoadTable(tables TableName[]) : void in class org.apache.hadoop.hbase.client.TestAsyncClusterAdminApi |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method public testAppend() : void in class org.apache.hadoop.hbase.client.TestAsyncTableNoncedRetry |
From |
To |
|
Change Variable Type table : AsyncTable to table : AsyncTable<?> in method public run(args String[]) : int in class org.apache.hadoop.hbase.client.example.AsyncClientExample |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testCheckAndDelete() : void in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method public testRegionMove() : void in class org.apache.hadoop.hbase.client.TestAsyncSingleRequestRpcRetryingCaller |
From |
To |
|
Change Variable Type table1 : RawAsyncTable to table1 : AsyncTable<?> in method public testDisableAndEnableTables() : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |
|
Change Variable Type server2Regions : Map<ServerName,List<HRegionInfo>> to server2Regions : Map<ServerName,List<RegionInfo>> in method private verifyRoundRobinDistribution(regions List<HRegionLocation>, expectedRegions int) : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |
|
Change Variable Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method public testMergeSwitch() : void in class org.apache.hadoop.hbase.client.TestAsyncRegionAdminApi |
From |
To |
|
Change Variable Type tableGetter : Function<TableName,AsyncTableBase> to tableGetter : Function<TableName,AsyncTable<?>> in method public params() : List<Object[]> in class org.apache.hadoop.hbase.client.TestAsyncTableBatch |
From |
To |
|
Change Variable Type table : AsyncTable to table : AsyncTable<ScanResultConsumer> in method protected doScan(scan Scan) : List<Result> in class org.apache.hadoop.hbase.client.TestAsyncTableScan |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testMutateRow() : void in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testPartialSuccess() : void in class org.apache.hadoop.hbase.client.TestAsyncTableBatch |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testSimple() : void in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method public testCompactionTimestamps() : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method public testDisableAndEnableTable() : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<AdvancedScanResultConsumer> in method public testSizeLimit() : void in class org.apache.hadoop.hbase.client.TestRawAsyncScanCursor |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testIncrement() : void in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Variable Type scanConsumer : SimpleRawScanResultConsumer to scanConsumer : BufferingScanResultConsumer in method protected doScan(scan Scan) : List<Result> in class org.apache.hadoop.hbase.client.TestRawAsyncTableScan |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testAppend() : void in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Variable Type table : AsyncTableBase to table : AsyncTable<?> in method public testSimpleMultiple() : void in class org.apache.hadoop.hbase.client.TestAsyncTable |
From |
To |
|
Change Variable Type table : AsyncTable to table : AsyncTable<?> in method protected doScan(scan Scan) : List<Result> in class org.apache.hadoop.hbase.client.TestAsyncTableScanner |
From |
To |
|
Change Variable Type table2 : RawAsyncTable to table2 : AsyncTable<?> in method public testDisableAndEnableTables() : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |
|
Change Variable Type table : RawAsyncTable to table : AsyncTable<?> in method public test() : void in class org.apache.hadoop.hbase.client.TestAsyncBufferMutator |
From |
To |
|
Change Variable Type metaTable : RawAsyncTable to metaTable : AsyncTable<AdvancedScanResultConsumer> in method public testEnableTableRetainAssignment() : void in class org.apache.hadoop.hbase.client.TestAsyncTableAdminApi |
From |
To |