|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridNearGetFuture.MiniFuture |
From |
To |
|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtLockFuture.MiniFuture |
From |
To |
|
Change Parameter Type lsnr : IgniteInClosure<? super IgniteInternalFuture<R>> to lsnr : IgniteInClosure<? super IgniteFuture<R>> in method public listenAsync(lsnr IgniteInClosure<? super IgniteFuture<R>>) : void in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl |
From |
To |
|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtTxFinishFuture.MiniFuture |
From |
To |
|
Change Parameter Type doneCb : IgniteClosure<? super IgniteInternalFuture<R>,T> to doneCb : IgniteClosure<? super IgniteFuture<R>,T> in method public chain(doneCb IgniteClosure<? super IgniteFuture<R>,T>) : IgniteFuture<T> in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl.ScheduleFutureSnapshot |
From |
To |
|
Change Parameter Type lsnr : IgniteInClosure<? super IgniteInternalFuture<R>>... to lsnr : IgniteInClosure<? super IgniteFuture<R>>... in method public stopListenAsync(lsnr IgniteInClosure<? super IgniteFuture<R>>...) : void in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl.ScheduleFutureSnapshot |
From |
To |
|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridPartitionedGetFuture.MiniFuture |
From |
To |
|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtTxPrepareFuture.MiniFuture |
From |
To |
|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridNearLockFuture.MiniFuture |
From |
To |
|
Change Parameter Type lsnr : IgniteInClosure<? super IgniteInternalFuture<R>> to lsnr : IgniteInClosure<? super IgniteFuture<R>> in method private notifyListener(lsnr IgniteInClosure<? super IgniteFuture<R>>, res R, err Throwable, syncNotify boolean) : void in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl |
From |
To |
|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtForceKeysFuture.MiniFuture |
From |
To |
|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxPrepareFuture.MiniFuture |
From |
To |
|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.colocated.GridDhtColocatedLockFuture.MiniFuture |
From |
To |
|
Change Parameter Type lsnr : IgniteInClosure<? super IgniteInternalFuture<R>> to lsnr : IgniteInClosure<? super IgniteFuture<R>> in method public listenAsync(lsnr IgniteInClosure<? super IgniteFuture<R>>) : void in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl.ScheduleFutureSnapshot |
From |
To |
|
Change Parameter Type lsnr : IgniteInClosure<? super IgniteInternalFuture<R>>... to lsnr : IgniteInClosure<? super IgniteFuture<R>>... in method public stopListenAsync(lsnr IgniteInClosure<? super IgniteFuture<R>>...) : void in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl |
From |
To |
|
Change Parameter Type e : ClusterTopologyException to e : ClusterTopologyCheckedException in method package onResult(e ClusterTopologyCheckedException) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxFinishFuture.MiniFuture |
From |
To |
|
Change Return Type ComputeTaskFuture<R> to GridTaskFutureImpl<R> in method public execute(task ComputeTask<T,R>, arg T) : GridTaskFutureImpl<R> in class org.apache.ignite.internal.processors.task.GridTaskProcessor |
From |
To |
|
Change Return Type ClusterTopologyException to ClusterTopologyCheckedException in method private newTopologyException(nested Throwable, nodeId UUID) : ClusterTopologyCheckedException in class org.apache.ignite.internal.processors.cache.distributed.dht.colocated.GridDhtColocatedLockFuture |
From |
To |
|
Change Return Type IgniteInternalFuture<R> to IgniteFuture<R> in method public callLocal(c Callable<R>) : IgniteFuture<R> in class org.apache.ignite.internal.IgniteSchedulerImpl |
From |
To |
|
Change Return Type IgniteInternalFuture<?> to IgniteFuture<?> in method public runLocal(r Runnable) : IgniteFuture<?> in class org.apache.ignite.IgniteScheduler |
From |
To |
|
Change Return Type ComputeTaskFuture<R> to GridTaskFutureImpl<R> in method public execute(taskName String, arg T) : GridTaskFutureImpl<R> in class org.apache.ignite.internal.processors.task.GridTaskProcessor |
From |
To |
|
Change Return Type IgniteInternalFuture<T> to IgniteFuture<T> in method public chain(doneCb IgniteClosure<? super IgniteFuture<R>,T>) : IgniteFuture<T> in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl.ScheduleFutureSnapshot |
From |
To |
|
Change Return Type IgniteInternalFuture<?> to IgniteFuture<?> in method public runLocal(r Runnable) : IgniteFuture<?> in class org.apache.ignite.internal.IgniteSchedulerImpl |
From |
To |
|
Change Return Type ClusterGroupEmptyException to ClusterGroupEmptyCheckedException in method public emptyTopologyException() : ClusterGroupEmptyCheckedException in class org.apache.ignite.internal.util.GridUtils |
From |
To |
|
Change Return Type ComputeTaskFuture<R> to GridTaskFutureImpl<R> in method public execute(task ComputeTask<T,R>, arg T, sys boolean) : GridTaskFutureImpl<R> in class org.apache.ignite.internal.processors.task.GridTaskProcessor |
From |
To |
|
Change Return Type ClusterTopologyException to ClusterTopologyCheckedException in method private newTopologyException(nested Throwable, nodeId UUID) : ClusterTopologyCheckedException in class org.apache.ignite.internal.processors.cache.distributed.near.GridNearLockFuture |
From |
To |
|
Change Return Type IgniteInternalFuture<R> to IgniteFuture<R> in method public callLocal(c Callable<R>) : IgniteFuture<R> in class org.apache.ignite.IgniteScheduler |
From |
To |
|
Change Return Type ComputeTaskFuture<R> to GridTaskFutureImpl<R> in method private startTask(taskName String, taskCls Class<?>, task ComputeTask<T,R>, sesId IgniteUuid, arg T, sys boolean) : GridTaskFutureImpl<R> in class org.apache.ignite.internal.processors.task.GridTaskProcessor |
From |
To |
|
Change Return Type ComputeTaskFuture<R> to GridTaskFutureImpl<R> in method public execute(taskCls Class<? extends ComputeTask<T,R>>, arg T) : GridTaskFutureImpl<R> in class org.apache.ignite.internal.processors.task.GridTaskProcessor |
From |
To |
|
Change Variable Type ignored : ClusterTopologyException to ignored : IgniteInterruptedCheckedException in method private registerHandler(nodeId UUID, routineId UUID, hnd GridContinuousHandler, bufSize int, interval long, autoUnsubscribe boolean, loc boolean) : boolean in class org.apache.ignite.internal.processors.continuous.GridContinuousProcessor |
From |
To |
|
Change Variable Type fut : ComputeTaskFuture<R> to fut : GridTaskFutureImpl<R> in method public taskFutures() : Map<IgniteUuid,ComputeTaskFuture<R>> in class org.apache.ignite.internal.processors.task.GridTaskProcessor |
From |
To |
|
Change Variable Type fut : IgniteInternalFuture<?> to fut : IgniteFuture<?> in method public testCallLocal() : void in class org.apache.ignite.internal.processors.schedule.GridScheduleSelfTest |
From |
To |
|
Change Variable Type lsnr : IgniteInClosure<? super IgniteInternalFuture<R>> to lsnr : IgniteInClosure<? super IgniteFuture<R>> in method public run() : void in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl.notifyListeners.runLocalSafe |
From |
To |
|
Change Variable Type lsnr : IgniteInClosure<IgniteInternalFuture> to lsnr : IgniteInClosure<IgniteFuture> in method private runTest(g Ignite, threadCnt int, taskCnt int, dur long, iterCntr LongAdder) : void in class org.apache.ignite.loadtests.job.GridJobExecutionSingleNodeSemaphoreLoadTest |
From |
To |
|
Change Variable Type tmp : Collection<IgniteInClosure<? super IgniteInternalFuture<R>>> to tmp : Collection<IgniteInClosure<? super IgniteFuture<R>>> in method private notifyListeners(res R, err Throwable) : void in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl |
From |
To |
|
Change Variable Type lsnr : IgniteInClosure<IgniteInternalFuture<?>> to lsnr : IgniteInClosure<IgniteFuture<?>> in method public call() : Object in class org.apache.ignite.loadtests.job.GridJobExecutionLoadTestClientSemaphore |
From |
To |
|
Change Variable Type e : IgniteInternalFuture<?> to e : IgniteFuture<?> in method public testScheduleRunnable() : void in class org.apache.ignite.internal.processors.schedule.GridScheduleSelfTest |
From |
To |
|
Change Variable Type t : IgniteInternalFuture to t : IgniteFuture in method private runTest(g Ignite, threadCnt int, taskCnt int, dur long, iterCntr LongAdder) : void in class org.apache.ignite.loadtests.job.GridJobExecutionSingleNodeSemaphoreLoadTest |
From |
To |
|
Change Variable Type e : IgniteCheckedException to e : IgniteException in method private warmUp(noThreads int) : void in class org.apache.ignite.loadtests.job.GridJobExecutionLoadTestClientSemaphore |
From |
To |
|
Change Variable Type f : IgniteInternalFuture<?> to f : IgniteFuture<?> in method private colocateJobs() : void in class org.apache.ignite.loadtests.colocation.GridTestMain |
From |
To |
|
Change Variable Type e : IgniteInternalFuture<?> to e : IgniteFuture<?> in method public testScheduleCallable() : void in class org.apache.ignite.internal.processors.schedule.GridScheduleSelfTest |
From |
To |
|
Change Variable Type o : IgniteInternalFuture<?> to o : IgniteFuture<?> in method private colocateJobs() : void in class org.apache.ignite.loadtests.colocation.GridTestMain |
From |
To |
|
Change Variable Type lsnr : IgniteInClosure<? super IgniteInternalFuture<R>> to lsnr : IgniteInClosure<? super IgniteFuture<R>> in method private notifyListeners(res R, err Throwable) : void in class org.apache.ignite.internal.processors.schedule.ScheduleFutureImpl |
From |
To |
|
Change Variable Type t : IgniteInternalFuture<?> to t : IgniteFuture<?> in method public call() : Object in class org.apache.ignite.loadtests.job.GridJobExecutionLoadTestClientSemaphore |
From |
To |
|
Change Variable Type q : BlockingQueue<IgniteInternalFuture> to q : BlockingQueue<IgniteFuture> in method private colocateJobs() : void in class org.apache.ignite.loadtests.colocation.GridTestMain |
From |
To |
|
Change Variable Type fut : IgniteInternalFuture<?> to fut : IgniteFuture<?> in method public testRunLocal() : void in class org.apache.ignite.internal.processors.schedule.GridScheduleSelfTest |
From |
To |
|
Change Variable Type fut : IgniteInternalFuture<?> to fut : IgniteFuture<?> in method public testScheduler() : void in class org.apache.ignite.marshaller.GridMarshallerAbstractTest |
From |
To |