|
Change Parameter Type lsnr : IgnitePredicate<? extends IgniteEvent> to lsnr : IgnitePredicate<? extends Event> in method public stopLocalListen(lsnr IgnitePredicate<? extends Event>, types int...) : boolean in class org.apache.ignite.internal.IgniteEventsImpl |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public record(evt Event) : void in class org.apache.ignite.spi.eventstorage.EventStorageSpi |
From |
To |
|
Change Parameter Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method package events(evts Collection<Event>) : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageMessage |
From |
To |
|
Change Parameter Type lsnr : IgnitePredicate<? extends IgniteEvent> to lsnr : IgnitePredicate<? extends Event> in method public addLocalEventListener(lsnr IgnitePredicate<? extends Event>, types int[]) : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Parameter Type evt : IgniteDiscoveryEvent to evt : DiscoveryEvent in method public onDiscoveryEvent(evt DiscoveryEvent) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtForceKeysFuture |
From |
To |
|
Change Parameter Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method package addListener(ignite Ignite, lsnr IgnitePredicate<Event>) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultiNodeLockAbstractTest |
From |
To |
|
Change Parameter Type evt : IgniteDiscoveryEvent to evt : DiscoveryEvent in method private processNodeLeft(evt DiscoveryEvent) : void in class org.apache.ignite.internal.processors.hadoop.jobtracker.GridHadoopJobTracker |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionLockUnlockSelfTest.EvictListener |
From |
To |
|
Change Parameter Type e : IgniteEvent to e : Event in method public apply(e Event) : boolean in class org.apache.ignite.tests.p2p.GridEventConsumeFilter |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public record(evt Event) : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Parameter Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method public setFilter(filter IgnitePredicate<Event>) : void in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.GridDeploymentSelfTest.DeploymentEventListener |
From |
To |
|
Change Parameter Type p : IgnitePredicate<? super IgniteEvent> to p : IgnitePredicate<? super Event> in method public waitForEvent(timeout long, c Runnable, p IgnitePredicate<? super Event>, types int...) : Event in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.GridEventStorageSelfTest.TestEventFilter |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest.CacheEventListener |
From |
To |
|
Change Parameter Type lsnr : IgnitePredicate<? extends IgniteEvent> to lsnr : IgnitePredicate<? extends Event> in method private UserListenerWrapper(lsnr IgnitePredicate<? extends Event>) in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager.UserListenerWrapper |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheQueryNodeRestartSelfTest.CollectingEventListener |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.gridify.AbstractAopTest.TestEventListener |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest.CollectingEventListener |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public GridDhtPartitionsExchangeFuture(cctx GridCacheSharedContext<K,V>, reassign boolean, discoEvt DiscoveryEvent, exchId GridDhtPartitionExchangeId) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.distributed.GridCacheEventAbstractTest.TestEventListener |
From |
To |
|
Change Parameter Type o : IgniteEvent to o : Event in method public compareTo(o Event) : int in class org.apache.ignite.events.EventAdapter |
From |
To |
|
Change Parameter Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method package GridEventConsumeHandler(cb IgniteBiPredicate<UUID,Event>, filter IgnitePredicate<Event>, types int[]) in class org.apache.ignite.internal.GridEventConsumeHandler |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.spi.discovery.GridAbstractDiscoveryRandomStartStopTest.DiscoveryListener |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.tests.p2p.GridP2PEventFilterExternalPath1 |
From |
To |
|
Change Parameter Type e : IgniteEvent to e : Event in method private filterByTaskName(e Event, taskName String) : boolean in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.tests.p2p.GridP2PEventFilterExternalPath2 |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method package exchangeFuture(exchId GridDhtPartitionExchangeId, discoEvt DiscoveryEvent) : GridDhtPartitionsExchangeFuture<K,V> in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public calculateAffinity(topVer long, discoEvt DiscoveryEvent) : List<List<ClusterNode>> in class org.apache.ignite.internal.processors.cache.GridCacheAffinityManager |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapSelfTest.SwapListener |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public recordLocal(evt Event) : void in class org.apache.ignite.IgniteEvents |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method private checkLaunchCoordinator(discoEvt DiscoveryEvent) : void in class org.apache.ignite.internal.processors.clock.GridClockSyncProcessor |
From |
To |
|
Change Parameter Type lsnrs : Map<IgnitePredicate<? extends IgniteEvent>,int[]> to lsnrs : Map<IgnitePredicate<? extends Event>,int[]> in method public setLocalEventListeners(lsnrs Map<IgnitePredicate<? extends Event>,int[]>) : void in class org.apache.ignite.configuration.IgniteConfiguration |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method private notifyListeners(evt Event) : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method private preloadEvent(type int, discoEvt DiscoveryEvent) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionDemandPool |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method private notifyListeners(set Collection<GridLocalEventListener>, evt Event) : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.GridEventStorageSelfTest.TestEventListener |
From |
To |
|
Change Parameter Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method private executeFail(g ClusterGroup, filter IgnitePredicate<Event>) : void in class org.apache.ignite.p2p.GridP2PMissedResourceCacheSizeSelfTest |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultiNodeLockAbstractTest.UnlockListener |
From |
To |
|
Change Parameter Type lsnr : IgnitePredicate<? extends IgniteEvent> to lsnr : IgnitePredicate<? extends Event> in method public stopLocalListen(lsnr IgnitePredicate<? extends Event>, types int...) : boolean in class org.apache.ignite.IgniteEvents |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.fs.GridGgfsFragmentizerManager.FragmentizerCoordinator |
From |
To |
|
Change Parameter Type evt : IgniteDiscoveryEvent to evt : DiscoveryEvent in method protected TimeCoordinator(evt DiscoveryEvent) in class org.apache.ignite.internal.processors.clock.GridClockSyncProcessor.TimeCoordinator |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultiNodeAbstractTest.CacheEventListener |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public recordEvent(evt Event) : void in class org.apache.ignite.spi.IgniteSpiContext |
From |
To |
|
Change Parameter Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method private checkPartitionUnloadEvents(evts Collection<Event>, g Ignite, parts Collection<GridDhtLocalPartition<Object,Object>>) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedUnloadEventsSelfTest |
From |
To |
|
Change Parameter Type e : IgniteEvent to e : Event in method public apply(e Event) : boolean in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest.EventPredicate |
From |
To |
|
Change Parameter Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method protected checkPreloadEvents(evts Collection<Event>, g Ignite, keys Collection<? extends Object>) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePreloadEventsAbstractSelfTest |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.service.GridServiceProcessor.TopologyListener |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public GridCacheAffinityFunctionContextImpl(topSnapshot List<ClusterNode>, prevAssignment List<List<ClusterNode>>, discoEvt DiscoveryEvent, topVer long, backups int) in class org.apache.ignite.internal.processors.affinity.GridCacheAffinityFunctionContextImpl |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public calculate(topVer long, discoEvt DiscoveryEvent) : List<List<ClusterNode>> in class org.apache.ignite.internal.processors.affinity.GridAffinityAssignmentCache |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.task.GridTaskProcessor.TaskDiscoveryListener |
From |
To |
|
Change Parameter Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method private checkObjectUnloadEvents(evts Collection<Event>, g Ignite, keys Collection<?>) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedUnloadEventsSelfTest |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheBasicApiAbstractTest.CacheEventListener |
From |
To |
|
Change Parameter Type e : IgniteEvent to e : Event in method private filterByTaskSessionId(e Event, taskSessionId IgniteUuid) : boolean in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.DiscoTopologyFuture |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public GridDhtPartitionsExchangeFuture(cctx GridCacheSharedContext<K,V>, discoEvt DiscoveryEvent, exchId GridDhtPartitionExchangeId) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method private notifyListener(evt Event) : void in class org.apache.ignite.testframework.GridSpiTestContext |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method private preloadEvent(part int, type int, discoEvt DiscoveryEvent) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionDemandPool |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.fs.GridGgfsImpl.FormatDiscoveryListener |
From |
To |
|
Change Parameter Type lsnr : IgnitePredicate<? extends IgniteEvent> to lsnr : IgnitePredicate<? extends Event> in method public localListen(lsnr IgnitePredicate<? extends Event>, types int[]) : void in class org.apache.ignite.internal.IgniteEventsImpl |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest.CustomEventFilter |
From |
To |
|
Change Parameter Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method package GridEventStorageMessage(evts Collection<Event>, ex Throwable) in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageMessage |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public recordEvent(evt Event) : void in class org.apache.ignite.testframework.GridSpiTestContext |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.internal.managers.eventstorage.GridLocalEventListener |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method private checkLaunchCoordinator(discoEvt DiscoveryEvent) : void in class org.apache.ignite.internal.processors.fs.GridGgfsFragmentizerManager |
From |
To |
|
Change Parameter Type lsnr : IgnitePredicate<? extends IgniteEvent> to lsnr : IgnitePredicate<? extends Event> in method public localListen(lsnr IgnitePredicate<? extends Event>, types int...) : void in class org.apache.ignite.IgniteEvents |
From |
To |
|
Change Parameter Type evt : IgniteDiscoveryEvent to evt : DiscoveryEvent in method package addEvent(evt DiscoveryEvent) : void in class org.apache.ignite.internal.processors.cache.GridCacheEvictionManager.BackupWorker |
From |
To |
|
Change Parameter Type evts : List<IgniteEvent> to evts : List<Event> in method private assertEvent(evtType int, expType int, evts List<Event>) : void in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager.UserListenerWrapper |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.GridRuntimeExceptionSelfTest.TaskFailedEventFilter |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.job.GridJobProcessor.JobDiscoveryListener |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public triggerEvent(evt Event) : void in class org.apache.ignite.testframework.GridSpiTestContext |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.ClusterMetricsSelfTest.MetricsUpdateLock |
From |
To |
|
Change Parameter Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(exchId GridDhtPartitionExchangeId, discoEvt DiscoveryEvent) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Parameter Type cb : IgniteBiPredicate<UUID,IgniteEvent> to cb : IgniteBiPredicate<UUID,Event> in method package GridEventConsumeHandler(cb IgniteBiPredicate<UUID,Event>, filter IgnitePredicate<Event>, types int[]) in class org.apache.ignite.internal.GridEventConsumeHandler |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public record(evt Event) : void in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheSwapSelfTest.SwapListener |
From |
To |
|
Change Parameter Type evt : IgniteDiscoveryEvent to evt : DiscoveryEvent in method public onDiscoveryEvent(evt DiscoveryEvent) : void in class org.apache.ignite.internal.processors.clock.GridClockSyncProcessor.TimeCoordinator |
From |
To |
|
Change Parameter Type lsnr : IgnitePredicate<? extends IgniteEvent> to lsnr : IgnitePredicate<? extends Event> in method public removeLocalEventListener(lsnr IgnitePredicate<? extends Event>, types int...) : boolean in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method package EventWrapper(evt Event) in class org.apache.ignite.internal.GridEventConsumeHandler.EventWrapper |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public onEvent(evt Event) : void in class org.apache.ignite.spi.discovery.GridAbstractDiscoveryTest.DiscoveryListener |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public recordLocal(evt Event) : void in class org.apache.ignite.internal.IgniteEventsImpl |
From |
To |
|
Change Parameter Type evt : IgniteEvent to evt : Event in method public apply(evt Event) : boolean in class org.apache.ignite.internal.ClusterMetricsSelfTest.JobFinishLock |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method public testTaskUndeployEvents() : void in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest |
From |
To |
|
Change Variable Type p : IgnitePredicate<IgniteEvent> to p : IgnitePredicate<Event> in method public testEventNodeId() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type le : IgniteLicenseEvent to le : LicenseEvent in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type futBackup : IgniteFuture<IgniteEvent> to futBackup : IgniteFuture<Event> in method public testSingleKey() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEvictionSelfTest |
From |
To |
|
Change Variable Type e : IgniteCacheEvent to e : CacheEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedAffinitySelfTest.ListenerJob.run.lsnr |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method private cleanupQueue() : void in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public apply(evt Event) : boolean in class org.apache.ignite.spi.discovery.tcp.GridTcpDiscoverySelfTest.testNodeAdded.localListen |
From |
To |
|
Change Variable Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method public testLocalNodeEventStorage() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method public testAddRemoveGlobalListener() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type evtList : List<IgniteEvent> to evtList : List<Event> in method public testDirWithFiles() : void in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest |
From |
To |
|
Change Variable Type evt : IgniteDeploymentEvent to evt : DeploymentEvent in method private recordUndeploy(dep GridDeployment) : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentLocalStore |
From |
To |
|
Change Variable Type je : IgniteJobEvent to je : JobEvent in method private filterByTaskSessionId(e Event, taskSessionId IgniteUuid) : boolean in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type evt0 : IgniteDiscoveryEvent to evt0 : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.fs.GridGgfsImpl.FormatDiscoveryListener |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public waitForEvent(p IgnitePredicate<T>, types int...) : IgniteInternalFuture<T> in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testExpiredEntriesPreloading() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheExpiredEntriesPreloadAbstractSelfTest |
From |
To |
|
Change Variable Type fut : IgniteFuture<IgniteEvent> to fut : IgniteFuture<Event> in method public testWaitForEvent() : void in class org.apache.ignite.internal.managers.events.GridEventStorageManagerSelfTest |
From |
To |
|
Change Variable Type e : IgniteSwapSpaceEvent to e : SwapSpaceEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.managers.swapspace.GridSwapSpaceManagerSelfTest.testSize.localListen |
From |
To |
|
Change Variable Type evt : IgniteDeploymentEvent to evt : DeploymentEvent in method private recordDeploy(cls Class<?>, alias String, recordEvt boolean) : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentLocalStore |
From |
To |
|
Change Variable Type p : IgnitePredicate<IgniteEvent> to p : IgnitePredicate<Event> in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi.onContextInitialized0.addLocalEventListener |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method private processTaskSessionRequest(nodeId UUID, req GridTaskSessionRequest) : void in class org.apache.ignite.internal.processors.job.GridJobProcessor |
From |
To |
|
Change Variable Type p : IgnitePredicate<IgniteEvent> to p : IgnitePredicate<Event> in method public testEventAfter() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type execLsnr : IgnitePredicate<IgniteEvent> to execLsnr : IgnitePredicate<Event> in method public testEvents() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type evt : IgniteTaskEvent to evt : TaskEvent in method private localListen() : void in class org.apache.ignite.examples.events.EventsExample |
From |
To |
|
Change Variable Type te : IgniteTaskEvent to te : TaskEvent in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method public testEvents() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method private checkPartitionUnloadEvents(evts Collection<Event>, g Ignite, parts Collection<GridDhtLocalPartition<Object,Object>>) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedUnloadEventsSelfTest |
From |
To |
|
Change Variable Type evt2 : IgniteEvent to evt2 : Event in method public testEventNode1() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type iter : Iterator<IgniteEvent> to iter : Iterator<Event> in method public testIntegrity() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<? extends IgniteEvent> to lsnr : IgnitePredicate<? extends Event> in method public start() : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Variable Type e : IgniteEvent to e : Event in method public eventAfter(tstamp long) : IgnitePredicate<Event> in class org.apache.ignite.internal.util.lang.GridFunc |
From |
To |
|
Change Variable Type p : IgnitePredicate<IgniteEvent> to p : IgnitePredicate<Event> in method public testEventNode1() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type t : IgniteBiTuple<Ignite,IgnitePredicate<IgniteEvent>> to t : IgniteBiTuple<Ignite,IgnitePredicate<Event>> in method public testExecution() : void in class org.apache.ignite.internal.GridProjectionAbstractTest |
From |
To |
|
Change Variable Type locLsnr : IgniteBiPredicate<UUID,IgniteTaskEvent> to locLsnr : IgniteBiPredicate<UUID,TaskEvent> in method private remoteListen() : void in class org.apache.ignite.examples.events.EventsExample |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryReadEvent to qe : CacheQueryReadEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testFieldsQueryEvents.localListen |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryReadEvent<Integer,Integer> to qe : CacheQueryReadEvent<Integer,Integer> in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testScanQueryEvents.localListen |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type evt1 : IgniteEvent to evt1 : Event in method public testEventNodeId() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method protected beforeTestsStarted() : void in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public waitForEvent(timeout long, c Runnable, p IgnitePredicate<? super Event>, types int...) : Event in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Variable Type fut : IgniteFuture<IgniteEvent> to fut : IgniteFuture<Event> in method public testEvictSynchronized() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedEvictionSelfTest |
From |
To |
|
Change Variable Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method private pullEvents(since long, evtCnt int) : List<Event> in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest |
From |
To |
|
Change Variable Type fut : GridFutureAdapter<IgniteEvent> to fut : GridFutureAdapter<Event> in method public waitForEvent(timeout long, c Runnable, p IgnitePredicate<? super Event>, types int...) : Event in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Variable Type rmtLsnr : IgnitePredicate<IgniteCacheEvent> to rmtLsnr : IgnitePredicate<CacheEvent> in method public main(args String[]) : void in class org.apache.ignite.examples.datagrid.CacheEventsExample |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentCommunication.sendResourceRequest.discoLsnr |
From |
To |
|
Change Variable Type evt3 : IgniteEvent to evt3 : Event in method public testEventId() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryExecutedEvent to qe : CacheQueryExecutedEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest.testEvents.execLsnr |
From |
To |
|
Change Variable Type e : IgniteCheckpointEvent to e : CheckpointEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.managers.checkpoint.GridCheckpointManagerAbstractSelfTest.doTest.localListen |
From |
To |
|
Change Variable Type se : IgniteSecureSessionEvent to se : SecureSessionEvent in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type evt : IgniteJobEvent to evt : JobEvent in method private handleException(node ClusterNode, req GridJobExecuteRequest, ex IgniteException, endTime long) : void in class org.apache.ignite.internal.processors.job.GridJobProcessor |
From |
To |
|
Change Variable Type ce : IgniteCacheEvent to ce : CacheEvent in method public apply(evt Event) : boolean in class org.apache.ignite.loadtests.cache.GridCacheSwapLoadTest.main.localListen |
From |
To |
|
Change Variable Type evt : IgniteDeploymentEvent to evt : DeploymentEvent in method public onDeployed(cls Class<?>) : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentPerVersionStore.SharedDeployment |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onKernalStart() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloader |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method public testFailTask() : void in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest |
From |
To |
|
Change Variable Type evt2 : IgniteEvent to evt2 : Event in method public testEventNode2() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method public run() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedAffinitySelfTest.ListenerJob |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryReadEvent<Integer,Person> to qe : CacheQueryExecutedEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testTextQueryEvents.localListen |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method public testSuccessTask() : void in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public testMultithreadedWithNodeRestart() : void in class org.apache.ignite.internal.processors.continuous.GridEventConsumeSelfTest |
From |
To |
|
Change Variable Type p : IgnitePredicate<IgniteEvent> to p : IgnitePredicate<Event> in method public testEventNode2() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method private checkNodeRemoved(backups int) : void in class org.apache.ignite.cache.affinity.fair.GridCachePartitionFairAffinitySelfTest |
From |
To |
|
Change Variable Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method public onMessage(nodeId UUID, msg Object) : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager.RequestListener |
From |
To |
|
Change Variable Type locEvts : Collection<IgniteEvent> to locEvts : Collection<Event> in method public testRemoteAndLocalNodeEventStorage() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method public testRemoteNodeEventStorage() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public testDiscoveryListener() : void in class org.apache.ignite.internal.GridDiscoverySelfTest |
From |
To |
|
Change Variable Type te : IgniteTaskEvent to te : TaskEvent in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryReadEvent to qe : CacheQueryReadEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest.testEvents.lsnr |
From |
To |
|
Change Variable Type evt : IgniteDeploymentEvent to evt : DeploymentEvent in method package recordUndeployed() : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentPerLoaderStore.IsolatedDeployment |
From |
To |
|
Change Variable Type remEvts : Collection<IgniteEvent> to remEvts : Collection<Event> in method public testRemoteAndLocalNodeEventStorage() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type evt : IgniteDiscoveryEvent to evt : DiscoveryEvent in method protected onKernalStart0() : void in class org.apache.ignite.internal.processors.cache.GridCacheEvictionManager |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testMemoryEventStorage() : void in class org.apache.ignite.spi.eventstorage.memory.GridMemoryEventStorageSpiSelfTest |
From |
To |
|
Change Variable Type maxEvt : IgniteEvent to maxEvt : Event in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type evt : IgniteDeploymentEvent to evt : DeploymentEvent in method package recordDeployed(cls Class<?>, recordEvt boolean) : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentPerLoaderStore.IsolatedDeployment |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryExecutedEvent to qe : CacheQueryExecutedEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testScanQueryEvents.localListen |
From |
To |
|
Change Variable Type je : IgniteJobEvent to je : JobEvent in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type e : IgniteEvent to e : Event in method public eventId(ids IgniteUuid...) : IgnitePredicate<Event> in class org.apache.ignite.internal.util.lang.GridFunc |
From |
To |
|
Change Variable Type ae : IgniteAuthenticationEvent to ae : AuthenticationEvent in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryExecutedEvent to qe : CacheQueryExecutedEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testTextQueryEvents.localListen |
From |
To |
|
Change Variable Type cacheEvt : IgniteCacheEvent to cacheEvt : CacheEvent in method protected checkPreloadEvents(evts Collection<Event>, g Ignite, keys Collection<? extends Object>) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePreloadEventsAbstractSelfTest |
From |
To |
|
Change Variable Type lsnrs : Collection<IgniteBiTuple<Ignite,IgnitePredicate<IgniteEvent>>> to lsnrs : Collection<IgniteBiTuple<Ignite,IgnitePredicate<Event>>> in method public testExecution() : void in class org.apache.ignite.internal.GridProjectionAbstractTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.fs.GridGgfsFragmentizerManager.FragmentizerCoordinator |
From |
To |
|
Change Variable Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method public testRemoteAndLocalNodeEventStorage() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method public testGetOutTx() : void in class org.apache.ignite.internal.processors.cache.GridCacheExAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type gridEvt : IgniteEvent to gridEvt : Event in method public testEvents() : void in class org.apache.ignite.marshaller.GridMarshallerAbstractTest |
From |
To |
|
Change Variable Type jobEvt : IgniteJobEvent to jobEvt : JobEvent in method public onEvent(evt Event) : void in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi.onContextInitialized0.addLocalEventListener |
From |
To |
|
Change Variable Type foundEvt : IgniteCacheEvent to foundEvt : CacheEvent in method private checkEventNodeIdsStrict(ids UUID...) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheTransformEventSelfTest |
From |
To |
|
Change Variable Type le : IgniteLicenseEvent to le : LicenseEvent in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testIntegrity() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type it : Iterator<IgniteTaskEvent> to it : Iterator<TaskEvent> in method public testTimedOutTask() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type evt : IgniteCacheEvent to evt : CacheEvent in method public main(args String[]) : void in class org.apache.ignite.examples.datagrid.CacheEventsExample |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager.onKernalStart0.addLocalEventListener |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.dataload.IgniteDataLoaderImpl.IgniteDataLoaderImpl |
From |
To |
|
Change Variable Type se : IgniteSecureSessionEvent to se : SecureSessionEvent in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public onMessage(nodeId UUID, msg Object) : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager.RequestListener |
From |
To |
|
Change Variable Type futBackup : IgniteFuture<IgniteEvent> to futBackup : IgniteFuture<Event> in method public testMultipleKeys() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEvictionSelfTest |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testForcePreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedPreloadEventsSelfTest |
From |
To |
|
Change Variable Type cacheEvt : IgniteCacheEvent to cacheEvt : CacheEvent in method private checkObjectUnloadEvents(evts Collection<Event>, g Ignite, keys Collection<?>) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedUnloadEventsSelfTest |
From |
To |
|
Change Variable Type evt : IgniteTaskEvent to evt : TaskEvent in method public testFailedTask() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type e : IgniteEvent to e : Event in method public eventType(types int...) : IgnitePredicate<Event> in class org.apache.ignite.internal.util.lang.GridFunc |
From |
To |
|
Change Variable Type evt : IgniteDeploymentEvent to evt : DeploymentEvent in method private recordDeployFailed(cls Class<?>, clsLdr ClassLoader, recordEvt boolean) : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentLocalStore |
From |
To |
|
Change Variable Type evtList : List<IgniteEvent> to evtList : List<Event> in method public testTwoFiles() : void in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest |
From |
To |
|
Change Variable Type expired : IgniteEvent to expired : Event in method private cleanupQueue() : void in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi |
From |
To |
|
Change Variable Type evt0 : IgniteJobEvent to evt0 : JobEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.GridJobSubjectIdSelfTest.testJobSubjectId.localListen |
From |
To |
|
Change Variable Type evt1 : IgniteEvent to evt1 : Event in method public testEventId() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi.onContextInitialized0.addLocalEventListener |
From |
To |
|
Change Variable Type futBackup : IgniteFuture<IgniteEvent> to futBackup : IgniteFuture<Event> in method public testReaders() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEvictionNearReadersSelfTest |
From |
To |
|
Change Variable Type e : IgniteEvent to e : Event in method public testLockFromNearOrBackup() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedExplicitLockNodeFailureSelfTest |
From |
To |
|
Change Variable Type e : IgniteEvent to e : Event in method private checkTransaction(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheNodeFailureAbstractTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.DiscoTopologyFuture |
From |
To |
|
Change Variable Type evt3 : IgniteEvent to evt3 : Event in method public testEventAfter() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onDiscovery(type int, topVer long, node ClusterNode, topSnapshot Collection<ClusterNode>, snapshots Map<Long,Collection<ClusterNode>>) : void in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start.setListener |
From |
To |
|
Change Variable Type it : Iterator<IgniteTaskEvent> to it : Iterator<TaskEvent> in method public testClosure() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type p : IgnitePredicate<IgniteEvent> to p : IgnitePredicate<Event> in method public testEventId() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type evt3 : IgniteEvent to evt3 : Event in method public testEventNode1() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentPerVersionStore.start |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method public testExecution() : void in class org.apache.ignite.internal.GridProjectionAbstractTest |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteTaskEvent> to lsnr : IgnitePredicate<TaskEvent> in method private localListen() : void in class org.apache.ignite.examples.events.EventsExample |
From |
To |
|
Change Variable Type de : IgniteDeploymentEvent to de : DeploymentEvent in method private filterByTaskName(e Event, taskName String) : boolean in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.job.GridJobProcessor.requestJobSiblings.discoLsnr |
From |
To |
|
Change Variable Type futPrimary : IgniteFuture<IgniteEvent> to futPrimary : IgniteFuture<Event> in method public testReaders() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEvictionNearReadersSelfTest |
From |
To |
|
Change Variable Type taskEvt : IgniteTaskEvent to taskEvt : TaskEvent in method public onEvent(evt Event) : void in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi.onContextInitialized0.addLocalEventListener |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method public testExecuteFailed() : void in class org.apache.ignite.internal.GridRuntimeExceptionSelfTest |
From |
To |
|
Change Variable Type je : IgniteJobEvent to je : JobEvent in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type evt : IgniteTaskEvent to evt : TaskEvent in method public testSimpleTask() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type e : IgniteEvent to e : Event in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type lsnrs : Map<IgnitePredicate<? extends IgniteEvent>,int[]> to lsnrs : Map<IgnitePredicate<? extends Event>,int[]> in method protected getConfiguration(gridName String) : IgniteConfiguration in class org.apache.ignite.internal.GridLocalEventListenerSelfTest |
From |
To |
|
Change Variable Type futPrimary : IgniteFuture<IgniteEvent> to futPrimary : IgniteFuture<Event> in method public testSingleKey() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEvictionSelfTest |
From |
To |
|
Change Variable Type ae : IgniteAuthorizationEvent to ae : AuthorizationEvent in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method public testReduceFailed() : void in class org.apache.ignite.internal.GridRuntimeExceptionSelfTest |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testMultiThreaded() : void in class org.apache.ignite.spi.eventstorage.memory.GridMemoryEventStorageMultiThreadedSelfTest |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method private sendSessionAttributes(attrs Map<?,?>, ses GridTaskSessionImpl) : void in class org.apache.ignite.internal.processors.task.GridTaskProcessor |
From |
To |
|
Change Variable Type it : Iterator<IgniteTaskEvent> to it : Iterator<TaskEvent> in method public testClient() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type p : IgnitePredicate<IgniteEvent> to p : IgnitePredicate<Event> in method public testEventType() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method private recordTaskEvent(evtType int, msg String) : void in class org.apache.ignite.internal.processors.task.GridTaskWorker |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.ClusterMetricsSelfTest.MetricsUpdateLock |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.streamer.IgniteStreamerImpl.start.addLocalEventListener |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public testAddRemoveDiscoListener() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testFilter() : void in class org.apache.ignite.spi.eventstorage.memory.GridMemoryEventStorageSpiSelfTest |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method public testTimeoutTask() : void in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest |
From |
To |
|
Change Variable Type evt3 : IgniteEvent to evt3 : Event in method public testEventNode2() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryReadEvent<Integer,Integer> to qe : CacheQueryExecutedEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testScanQueryEvents.localListen |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method protected getConfiguration(gridName String) : IgniteConfiguration in class org.apache.ignite.internal.GridLocalEventListenerSelfTest |
From |
To |
|
Change Variable Type ae : IgniteAuthenticationEvent to ae : AuthenticationEvent in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type rmtLsnr : IgnitePredicate<IgniteTaskEvent> to rmtLsnr : IgnitePredicate<TaskEvent> in method private remoteListen() : void in class org.apache.ignite.examples.events.EventsExample |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.cache.query.GridCacheDistributedQueryManager.start0.addListener |
From |
To |
|
Change Variable Type it : Iterator<IgniteTaskEvent> to it : Iterator<TaskEvent> in method public testFailedTask() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method public testOptimisticTransaction() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type e : IgniteEvent to e : Event in method public testLock() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheNodeFailureAbstractTest |
From |
To |
|
Change Variable Type evt : IgniteCacheEvent to evt : CacheEvent in method private checkEventNodeIdsStrict(ids UUID...) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheTransformEventSelfTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.GridDiscoveryEventSelfTest.testDaemonNodeJoin.localListen |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method private createCopy(ctx CacheAffinityFunctionContext, topSnapshot Iterable<ClusterNode>) : IgniteBiTuple<List<List<ClusterNode>>,Map<UUID,PartitionSet>> in class org.apache.ignite.cache.affinity.fair.CachePartitionFairAffinity |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method public testAddRemoveDiscoListener() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method public testCheckpointEvents() : void in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest |
From |
To |
|
Change Variable Type evt : IgniteJobEvent to evt : JobEvent in method private recordEvent(evtType int, msg String) : void in class org.apache.ignite.internal.processors.job.GridJobWorker |
From |
To |
|
Change Variable Type locJoinEvt : IgniteDiscoveryEvent to locJoinEvt : DiscoveryEvent in method protected onKernalStart0() : void in class org.apache.ignite.internal.processors.fs.GridGgfsFragmentizerManager |
From |
To |
|
Change Variable Type evtList : List<IgniteEvent> to evtList : List<Event> in method public testSingleFileOverwrite() : void in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest |
From |
To |
|
Change Variable Type evt0 : IgniteCacheEvent to evt0 : CacheEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.distributed.GridCacheTransformEventSelfTest.initialize.localListen |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.rest.handlers.task.GridTaskCommandHandler.requestTaskResult.discoLsnr |
From |
To |
|
Change Variable Type e : IgniteEvent to e : Event in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type node : ConcurrentLinkedDeque8.Node<IgniteEvent> to node : ConcurrentLinkedDeque8.Node<Event> in method private cleanupQueue() : void in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi |
From |
To |
|
Change Variable Type e : IgniteCacheEvent to e : CacheEvent in method public onEvent(evt Event) : void in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi.onContextInitialized0.addLocalEventListener |
From |
To |
|
Change Variable Type evtList : List<IgniteEvent> to evtList : List<Event> in method public testDeleteNonRecursive() : void in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testPreloadEvents() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePreloadEventsAbstractSelfTest |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryReadEvent<Integer,Person> to qe : CacheQueryReadEvent<Integer,Person> in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testTextQueryEvents.localListen |
From |
To |
|
Change Variable Type evt : IgniteDiscoveryEvent to evt : DiscoveryEvent in method private recordEvent(type int, topVer long, node ClusterNode, topSnapshot Collection<ClusterNode>) : void in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.DiscoveryWorker |
From |
To |
|
Change Variable Type objEvts : Collection<IgniteEvent> to objEvts : Collection<Event> in method public testUnloadEvents() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedUnloadEventsSelfTest |
From |
To |
|
Change Variable Type futs : Collection<IgniteFuture<IgniteEvent>> to futs : Collection<IgniteFuture<Event>> in method public testEvictSynchronized() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedEvictionSelfTest |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testRemoteNodeEventStorage() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type evt1 : IgniteEvent to evt1 : Event in method public testEventAfter() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type e : IgniteEvent to e : Event in method public testWaitForEvent() : void in class org.apache.ignite.internal.managers.events.GridEventStorageManagerSelfTest |
From |
To |
|
Change Variable Type partEvts : Collection<IgniteEvent> to partEvts : Collection<Event> in method public testUnloadEvents() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedUnloadEventsSelfTest |
From |
To |
|
Change Variable Type cacheEvt : IgniteCacheEvent to cacheEvt : CacheEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest.CollectingEventListener |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testLocalNodeEventStorage() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type ae : IgniteAuthorizationEvent to ae : AuthorizationEvent in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type je : IgniteJobEvent to je : JobEvent in method private filterByTaskName(e Event, taskName String) : boolean in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public testDistributedQuery() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedQuerySelfTest |
From |
To |
|
Change Variable Type it : Iterator<IgniteTaskEvent> to it : Iterator<TaskEvent> in method public testSimpleTask() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type evt1 : IgniteEvent to evt1 : Event in method public testEventNode1() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public testGetOutTx() : void in class org.apache.ignite.internal.processors.cache.GridCacheExAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type evtList : List<IgniteEvent> to evtList : List<Event> in method public testSingleFileNestedDirs() : void in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest |
From |
To |
|
Change Variable Type futOther : IgniteFuture<IgniteEvent> to futOther : IgniteFuture<Event> in method public testReaders() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEvictionNearReadersSelfTest |
From |
To |
|
Change Variable Type evtLsnrs : Map<IgnitePredicate<? extends IgniteEvent>,int[]> to evtLsnrs : Map<IgnitePredicate<? extends Event>,int[]> in method public start() : void in class org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method protected body() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.ExchangeWorker |
From |
To |
|
Change Variable Type e : IgniteCacheEvent to e : CacheEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheEvictionEventAbstractTest.testEvictionEvent.localListen |
From |
To |
|
Change Variable Type locLsnr : IgniteBiPredicate<UUID,IgniteCacheEvent> to locLsnr : IgniteBiPredicate<UUID,CacheEvent> in method public main(args String[]) : void in class org.apache.ignite.examples.datagrid.CacheEventsExample |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.clock.GridClockSyncProcessor.start.addLocalEventListener |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method protected checkPreloadEvents(evts Collection<Event>, g Ignite, keys Collection<? extends Object>) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePreloadEventsAbstractSelfTest |
From |
To |
|
Change Variable Type evt3 : IgniteEvent to evt3 : Event in method public testEventNodeId() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public testAddRemoveGlobalListener() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type cacheEvt : IgniteCacheEvent to cacheEvt : CacheEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultiNodeLockAbstractTest.UnlockListener |
From |
To |
|
Change Variable Type evt2 : IgniteEvent to evt2 : Event in method public testEventId() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryReadEvent<Integer,Integer> to qe : CacheQueryReadEvent<Integer,Integer> in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testSqlQueryEvents.localListen |
From |
To |
|
Change Variable Type unloadEvt : IgniteCachePreloadingEvent to unloadEvt : CachePreloadingEvent in method private checkPartitionUnloadEvents(evts Collection<Event>, g Ignite, parts Collection<GridDhtLocalPartition<Object,Object>>) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedUnloadEventsSelfTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.cache.GridCacheEvictionManager.start0.addListener |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.fs.GridGgfsFragmentizerManager.start0.addLocalEventListener |
From |
To |
|
Change Variable Type futPrimary : IgniteFuture<IgniteEvent> to futPrimary : IgniteFuture<Event> in method public testMultipleKeys() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEvictionSelfTest |
From |
To |
|
Change Variable Type evt : IgniteTaskEvent to evt : TaskEvent in method public testClient() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type evt : IgniteJobEvent to evt : JobEvent in method private recordJobEvent(evtType int, jobId IgniteUuid, evtNode ClusterNode, msg String) : void in class org.apache.ignite.internal.processors.task.GridTaskWorker |
From |
To |
|
Change Variable Type evt4 : IgniteEvent to evt4 : Event in method public testEventNode1() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryExecutedEvent to qe : CacheQueryExecutedEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testSqlQueryEvents.localListen |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method private pullEvents(since long, evtCnt int) : List<Event> in class org.apache.ignite.internal.GridEventStorageCheckAllEventsSelfTest |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method private checkTimedOutEvents(execId IgniteUuid) : void in class org.apache.ignite.internal.GridTaskTimeoutSelfTest |
From |
To |
|
Change Variable Type de : IgniteDiscoveryEvent to de : DiscoveryEvent in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type evt1 : IgniteEvent to evt1 : Event in method public testEventNode2() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type join : IgniteDiscoveryEvent to join : DiscoveryEvent in method public testDaemonNodeJoin() : void in class org.apache.ignite.internal.GridDiscoveryEventSelfTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method protected onKernalStart0() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Variable Type evt : IgniteTaskEvent to evt : TaskEvent in method public testClosure() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public testNodeLeaveBeforePreloadingComplete() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadMultiThreadedSelfTest |
From |
To |
|
Change Variable Type evtList : List<IgniteEvent> to evtList : List<Event> in method public testMoveFile() : void in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest |
From |
To |
|
Change Variable Type evt : IgniteTaskEvent to evt : TaskEvent in method public testTimedOutTask() : void in class org.apache.ignite.internal.TaskEventSubjectIdSelfTest |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method public testDistributedQuery() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedQuerySelfTest |
From |
To |
|
Change Variable Type de : IgniteDeploymentEvent to de : DeploymentEvent in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type evtList : List<IgniteEvent> to evtList : List<Event> in method public testSingleEmptyDir() : void in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryReadEvent<Integer,Integer> to qe : CacheQueryExecutedEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testSqlQueryEvents.localListen |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryExecutedEvent to qe : CacheQueryExecutedEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testFieldsQueryEvents.localListen |
From |
To |
|
Change Variable Type evtList : List<IgniteEvent> to evtList : List<Event> in method public testFileDataEvents() : void in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest |
From |
To |
|
Change Variable Type locJoinEvt : IgniteDiscoveryEvent to locJoinEvt : DiscoveryEvent in method public onKernalStart() : void in class org.apache.ignite.internal.processors.clock.GridClockSyncProcessor |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public collectEvents(g Ignite, evtOrderKey String, evtThrottleCntrKey String, all boolean) : Collection<VisorGridEvent> in class org.apache.ignite.internal.visor.util.VisorTaskUtils |
From |
To |
|
Change Variable Type qe : IgniteCacheQueryReadEvent to qe : CacheQueryExecutedEvent in method public apply(evt Event) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest.testFieldsQueryEvents.localListen |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method public testDiscoveryListener() : void in class org.apache.ignite.internal.GridDiscoverySelfTest |
From |
To |
|
Change Variable Type evts : Collection<IgniteEvent> to evts : Collection<Event> in method public testRemoteAndLocalNodeEventStorage() : void in class org.apache.ignite.internal.GridEventStorageSelfTest |
From |
To |
|
Change Variable Type de : IgniteDeploymentEvent to de : DeploymentEvent in method protected run(arg VisorNodeEventsCollectorTaskArg) : Collection<? extends VisorGridEvent> in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method public testMetricsSending() : void in class org.apache.ignite.spi.discovery.tcp.GridTcpDiscoverySelfTest |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method public testResultFailed() : void in class org.apache.ignite.internal.GridRuntimeExceptionSelfTest |
From |
To |
|
Change Variable Type evt4 : IgniteEvent to evt4 : Event in method public testEventNode2() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type te : IgniteTaskEvent to te : TaskEvent in method private filterByTaskSessionId(e Event, taskSessionId IgniteUuid) : boolean in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |
|
Change Variable Type lsnr1 : IgnitePredicate<IgniteEvent> to lsnr1 : IgnitePredicate<Event> in method public testMetricsSending() : void in class org.apache.ignite.spi.discovery.tcp.GridTcpDiscoverySelfTest |
From |
To |
|
Change Variable Type lsnr : IgnitePredicate<IgniteEvent> to lsnr : IgnitePredicate<Event> in method private removeListeners(ignite Ignite) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultiNodeLockAbstractTest |
From |
To |
|
Change Variable Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method public testMemoryEventStorage() : void in class org.apache.ignite.spi.eventstorage.memory.GridMemoryEventStorageSpiSelfTest |
From |
To |
|
Change Variable Type evts : List<IgniteEvent> to evts : List<Event> in method public testMapFailed() : void in class org.apache.ignite.internal.GridRuntimeExceptionSelfTest |
From |
To |
|
Change Variable Type evt : IgniteDiscoveryEvent to evt : DiscoveryEvent in method protected body() : void in class org.apache.ignite.internal.processors.cache.GridCacheEvictionManager.BackupWorker |
From |
To |
|
Change Variable Type evtList : List<IgniteEvent> to evtList : List<Event> in method public testNestedEmptyDirs() : void in class org.apache.ignite.ignitefs.GridGgfsEventsAbstractSelfTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method public onEvent(evt Event) : void in class org.apache.ignite.internal.processors.fs.GridGgfsDataManager.start0.addLocalEventListener |
From |
To |
|
Change Variable Type evt2 : IgniteEvent to evt2 : Event in method public testEventNodeId() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type filter : IgnitePredicate<IgniteEvent> to filter : IgnitePredicate<Event> in method public _testNodeJoinWithP2P() : void in class org.apache.ignite.internal.processors.continuous.GridEventConsumeSelfTest |
From |
To |
|
Change Variable Type evt : IgniteDeploymentEvent to evt : DeploymentEvent in method package recordUndeployed(leftNodeId UUID) : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentPerVersionStore.SharedDeployment |
From |
To |
|
Change Variable Type evt : IgniteEvent to evt : Event in method private checkObjectUnloadEvents(evts Collection<Event>, g Ignite, keys Collection<?>) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedUnloadEventsSelfTest |
From |
To |
|
Change Variable Type discoEvt : IgniteDiscoveryEvent to discoEvt : DiscoveryEvent in method private checkRandomReassignment(backups int) : void in class org.apache.ignite.cache.affinity.fair.GridCachePartitionFairAffinitySelfTest |
From |
To |
|
Change Variable Type te : IgniteTaskEvent to te : TaskEvent in method private filterByTaskName(e Event, taskName String) : boolean in class org.apache.ignite.internal.visor.node.VisorNodeEventsCollectorTask.VisorEventsCollectJob |
From |
To |