|
Change Parameter Type desc : DynamicCacheDescriptor to desc : CacheGroupDescriptor in method private groupHolder(fut GridDhtPartitionsExchangeFuture, desc CacheGroupDescriptor) : CacheGroupHolder in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Parameter Type cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public GridDhtPartitionDemander(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionDemander |
From |
To |
|
Change Parameter Type flags : byte to flags : long in method package CacheData(cacheCfg CacheConfiguration, cacheId int, grpId int, cacheType CacheType, deploymentId IgniteUuid, schema QuerySchema, rcvdFrom UUID, staticCfg boolean, sql boolean, template boolean, flags long) in class org.apache.ignite.internal.processors.cache.CacheData |
From |
To |
|
Change Parameter Type ctx : GridCacheContext to grp : CacheGroupContext in method package GridCachePartitionedConcurrentMap(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedConcurrentMap |
From |
To |
|
Change Parameter Type cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public CacheDataRowStore(grp CacheGroupContext, freeList FreeList, partId int) in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.CacheDataRowStore |
From |
To |
|
Change Parameter Type ctx : GridCacheContext to ctx : GridCacheSharedContext in method protected marshalInfo(info GridCacheEntryInfo, ctx GridCacheSharedContext, cacheObjCtx CacheObjectContext) : void in class org.apache.ignite.internal.processors.cache.GridCacheMessage |
From |
To |
|
Change Parameter Type desc : DynamicCacheDescriptor to desc : CacheGroupDescriptor in method private canCalculateAffinity(desc CacheGroupDescriptor, aff GridAffinityAssignmentCache, fut GridDhtPartitionsExchangeFuture) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Parameter Type cctx : GridCacheContext to grp : CacheGroupContext in method package onCacheGroupCreated(grp CacheGroupContext) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Parameter Type cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method package GridDhtPartitionSupplier(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplier |
From |
To |
|
Change Parameter Type cacheDesc : DynamicCacheDescriptor to grpDesc : CacheGroupDescriptor in method public GridDhtAssignmentFetchFuture(ctx GridCacheSharedContext, grpDesc CacheGroupDescriptor, topVer AffinityTopologyVersion, discoCache DiscoCache) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtAssignmentFetchFuture |
From |
To |
|
Change Parameter Type cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public GridCachePreloaderAdapter(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.GridCachePreloaderAdapter |
From |
To |
|
Change Parameter Type cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public initFromLink(grp CacheGroupContext, rowData RowData) : void in class org.apache.ignite.internal.processors.cache.database.CacheDataRowAdapter |
From |
To |
|
Change Parameter Type ctx : GridCacheContext to ctx : GridCacheSharedContext in method protected marshalInfos(infos Iterable<? extends GridCacheEntryInfo>, ctx GridCacheSharedContext, cacheObjCtx CacheObjectContext) : void in class org.apache.ignite.internal.processors.cache.GridCacheMessage |
From |
To |
|
Change Parameter Type cctx : GridCacheContext to grp : CacheGroupContext in method public PendingEntriesTree(grp CacheGroupContext, name String, pageMem PageMemory, metaPageId long, reuseList ReuseList, initNew boolean) in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntriesTree |
From |
To |
|
Change Parameter Type cctx : GridCacheContext<?,?> to ctx : GridCacheSharedContext in method public GridDhtPartitionTopologyImpl(ctx GridCacheSharedContext, grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtPartitionTopologyImpl |
From |
To |
|
Change Parameter Type cancel : boolean to cacheId : int in method public stopCache(cacheId int, destroy boolean) : void in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Change Parameter Type cctx : GridCacheContext to cctx : GridCacheSharedContext in method package CacheGroupHolder2(rebalanceEnabled boolean, cctx GridCacheSharedContext, aff GridAffinityAssignmentCache, initAff GridAffinityAssignmentCache) in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.CacheGroupHolder2 |
From |
To |
|
Change Parameter Type cctx : GridCacheContext to grp : CacheGroupContext in method package initKey(grp CacheGroupContext) : PendingRow in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingRow |
From |
To |
|
Change Parameter Type desc : DynamicCacheDescriptor to desc : CacheGroupDescriptor in method private initAffinity(desc CacheGroupDescriptor, aff GridAffinityAssignmentCache, fut GridDhtPartitionsExchangeFuture) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Parameter Type ctx : GridCacheContext to ctx : CacheObjectContext in method public marshalledSize(ctx CacheObjectContext) : int in class org.apache.ignite.internal.processors.cache.GridCacheEntryInfo |
From |
To |
|
Change Parameter Type c : IgniteInClosureX<DynamicCacheDescriptor> to c : IgniteInClosureX<CacheGroupDescriptor> in method private forAllRegisteredCacheGroups(c IgniteInClosureX<CacheGroupDescriptor>) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Parameter Type cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public GridDhtPreloader(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloader |
From |
To |
|
Change Parameter Type cacheFilter : IgnitePredicate<ClusterNode> to aff : CacheGroupAffinity in method private CachePredicate(aff CacheGroupAffinity, nearEnabled boolean) in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.CachePredicate |
From |
To |
|
Change Parameter Type cacheId : Integer to grpDesc : CacheGroupDescriptor in method private initStartedGroupOnCoordinator(fut GridDhtPartitionsExchangeFuture, grpDesc CacheGroupDescriptor) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Parameter Type entryFactory : GridCacheMapEntryFactory to grp : CacheGroupContext in method public GridDhtPartitionTopologyImpl(ctx GridCacheSharedContext, grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtPartitionTopologyImpl |
From |
To |
|
Change Parameter Type cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public RowStore(grp CacheGroupContext, freeList FreeList) in class org.apache.ignite.internal.processors.cache.database.RowStore |
From |
To |
|
Change Parameter Type flags : byte to flags : long in method package CacheInfo(ccfg CacheConfiguration, cacheType CacheType, deploymentId IgniteUuid, nearCache boolean, flags long) in class org.apache.ignite.internal.processors.cache.CacheClientReconnectDiscoveryData.CacheInfo |
From |
To |
|
Change Parameter Type cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public initFromLink(grp CacheGroupContext, sharedCtx GridCacheSharedContext<?,?>, pageMem PageMemory, rowData RowData) : void in class org.apache.ignite.internal.processors.cache.database.CacheDataRowAdapter |
From |
To |
|
Change Parameter Type cacheName : String to grpId : int in method private dataNodes(grpId int, topVer AffinityTopologyVersion) : Collection<ClusterNode> in class org.apache.ignite.internal.processors.query.h2.twostep.GridReduceQueryExecutor |
From |
To |
|
Change Parameter Type ctx : GridCacheContext to ctx : GridCacheSharedContext in method package addEntry0(p int, info GridCacheEntryInfo, ctx GridCacheSharedContext, cacheObjCtx CacheObjectContext) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyMessage |
From |
To |
|
Change Parameter Type flags : byte to flags : long in method package CacheInfo(ccfg CacheConfiguration, cacheType CacheType, sql boolean, flags long) in class org.apache.ignite.internal.processors.cache.CacheJoinNodeDiscoveryData.CacheInfo |
From |
To |
|
Move Attribute private needsRecovery : boolean from class org.apache.ignite.internal.processors.cache.GridCacheContext to private needsRecovery : boolean from class org.apache.ignite.internal.processors.cache.CacheGroupContext |
From |
To |
|
Move Attribute private cacheId : int from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtAssignmentFetchFuture to private cacheId : int from class org.apache.ignite.internal.processors.cache.GridCacheLocalConcurrentMap |
From |
To |
|
Move Attribute protected preldr : GridCachePreloader from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter to private preldr : GridCachePreloader from class org.apache.ignite.internal.processors.cache.CacheGroupContext |
From |
To |
|
Move Attribute private cacheId : int from class org.apache.ignite.internal.processors.cache.distributed.dht.GridClientPartitionTopology to protected cacheId : int from class org.apache.ignite.internal.processors.cache.GridCacheIdMessage |
From |
To |
|
Move Attribute private idxClsHandlers : Map<Integer,IgniteBiInClosure[]> from class org.apache.ignite.internal.processors.cache.GridCacheIoManager to package idxClsHandlers : Map<Integer,IgniteBiInClosure[]> from class org.apache.ignite.internal.processors.cache.GridCacheIoManager.MessageHandlers |
From |
To |
|
Move Attribute private reuseList : ReuseList from class org.apache.ignite.internal.processors.cache.GridCacheContext to private reuseList : ReuseList from class org.apache.ignite.internal.processors.cache.CacheGroupContext |
From |
To |
|
Move Attribute private cacheId : int from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtAssignmentFetchFuture to private cacheId : int from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtLocalPartition.RemovedEntryHolder |
From |
To |
|
Move Attribute private map : ConcurrentMap<KeyCacheObject,GridCacheMapEntry> from class org.apache.ignite.internal.processors.cache.GridCacheConcurrentMapImpl to public map : ConcurrentMap<KeyCacheObject,GridCacheMapEntry> from class org.apache.ignite.internal.processors.cache.GridCacheConcurrentMap.CacheMapHolder |
From |
To |
|
Move Attribute private cacheId : int from class org.apache.ignite.internal.processors.cache.GridCacheIoManager.ListenerKey to private cacheId : int from class org.apache.ignite.internal.processors.cache.GridCacheLocalConcurrentMap |
From |
To |
|
Move Attribute private clsHandlers : ConcurrentMap<ListenerKey,IgniteBiInClosure<UUID,GridCacheMessage>> from class org.apache.ignite.internal.processors.cache.GridCacheIoManager to package clsHandlers : ConcurrentMap<ListenerKey,IgniteBiInClosure<UUID,GridCacheMessage>> from class org.apache.ignite.internal.processors.cache.GridCacheIoManager.MessageHandlers |
From |
To |
|
Move Attribute private forceKeyFuts : ConcurrentMap<IgniteUuid,GridDhtForceKeysFuture<?,?>> from class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloader to private forceKeyFuts : ConcurrentMap<IgniteUuid,GridDhtForceKeysFuture<?,?>> from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter |
From |
To |
|
Move Attribute private discoLsnr : GridLocalEventListener from class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloader to private discoLsnr : GridLocalEventListener from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter |
From |
To |
|
Move Attribute private cacheFilter : IgnitePredicate<ClusterNode> from class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.CachePredicate to private cacheFilter : IgnitePredicate<ClusterNode> from class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.CacheGroupAffinity |
From |
To |
|
Move Attribute private serialVersionUID : long from class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionDemander.RebalanceFuture to private serialVersionUID : long from class org.apache.ignite.internal.processors.cache.CacheGroupData |
From |
To |
|
Move Attribute private top : GridDhtPartitionTopologyImpl from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter to private top : GridDhtPartitionTopologyImpl from class org.apache.ignite.internal.processors.cache.CacheGroupContext |
From |
To |
|
Move Attribute private cacheId : int from class org.apache.ignite.internal.processors.cache.GridCacheIoManager.ListenerKey to protected cacheId : int from class org.apache.ignite.internal.processors.cache.GridCacheIdMessage |
From |
To |
|
Move Attribute private cacheId : int from class org.apache.ignite.internal.processors.cache.distributed.dht.GridClientPartitionTopology to private cacheId : int from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtLocalPartition.RemovedEntryHolder |
From |
To |
|
Move Attribute private freeList : FreeList from class org.apache.ignite.internal.processors.cache.GridCacheContext to private freeList : FreeList from class org.apache.ignite.internal.processors.cache.CacheGroupContext |
From |
To |
|
Move Attribute private cacheId : int from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtAssignmentFetchFuture to protected cacheId : int from class org.apache.ignite.internal.processors.cache.GridCacheIdMessage |
From |
To |
|
Move Attribute private rcvdFrom : UUID from class org.apache.ignite.internal.processors.cache.GridCacheContext to private rcvdFrom : UUID from class org.apache.ignite.internal.processors.cache.CacheGroupContext |
From |
To |
|
Move Attribute private cctx : GridCacheContext from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtLocalPartition to public cctx : GridCacheContext from class org.apache.ignite.internal.processors.cache.GridCacheConcurrentMap.CacheMapHolder |
From |
To |
|
Move Attribute private cacheId : int from class org.apache.ignite.internal.processors.cache.distributed.dht.GridClientPartitionTopology to private cacheId : int from class org.apache.ignite.internal.processors.cache.GridCacheLocalConcurrentMap |
From |
To |
|
Move Attribute private memPlc : MemoryPolicy from class org.apache.ignite.internal.processors.cache.GridCacheContext to private memPlc : MemoryPolicy from class org.apache.ignite.internal.processors.cache.CacheGroupContext |
From |
To |
|
Move Attribute private orderedHandlers : ConcurrentMap<Object,IgniteBiInClosure<UUID,? extends GridCacheMessage>> from class org.apache.ignite.internal.processors.cache.GridCacheIoManager to package orderedHandlers : ConcurrentMap<Object,IgniteBiInClosure<UUID,? extends GridCacheMessage>> from class org.apache.ignite.internal.processors.cache.GridCacheIoManager.MessageHandlers |
From |
To |
|
Move Attribute private offheapMgr : IgniteCacheOffheapManager from class org.apache.ignite.internal.processors.cache.GridCacheContext to private offheapMgr : IgniteCacheOffheapManager from class org.apache.ignite.internal.processors.cache.CacheGroupContext |
From |
To |
|
Move Attribute private cacheMode : CacheMode from class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.CachePredicate to private cacheMode : CacheMode from class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.CacheGroupAffinity |
From |
To |
|
Move Attribute private stopping : boolean from class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloader to private stopping : boolean from class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter |
From |
To |
|
Rename Method public keysIterator(part int) : GridCloseableIterator<KeyCacheObject> renamed to public cacheKeysIterator(cacheId int, part int) : GridCloseableIterator<KeyCacheObject> in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManager |
From |
To |
|
Rename Method private rowsIterator(primary boolean, backups boolean, topVer AffinityTopologyVersion) : GridIterator<CacheDataRow> renamed to public cacheEntriesIterator(cctx GridCacheContext, primary boolean, backup boolean, topVer AffinityTopologyVersion, keepBinary boolean) : GridCloseableIterator<Cache.Entry<K,V>> in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Method public iterator(part int) : GridIterator<CacheDataRow> renamed to public partitionIterator(part int) : GridIterator<CacheDataRow> in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManager |
From |
To |
|
Rename Method public cacheId() : int renamed to public groupId() : int in class org.apache.ignite.internal.processors.cache.distributed.dht.GridClientPartitionTopology |
From |
To |
|
Rename Method public cacheId() : int renamed to public groupId() : int in class org.apache.ignite.internal.processors.affinity.GridAffinityAssignmentCache |
From |
To |
|
Rename Method private cacheNames(cacheIds Collection<Integer>) : String renamed to private groupNames(grpIds Collection<Integer>) : String in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Method private initStartedCacheOnCoordinator(fut GridDhtPartitionsExchangeFuture, cacheId Integer) : void renamed to private initStartedGroupOnCoordinator(fut GridDhtPartitionsExchangeFuture, grpDesc CacheGroupDescriptor) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Method public iterator(part int) : GridIterator<CacheDataRow> renamed to public partitionIterator(part int) : GridIterator<CacheDataRow> in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Method protected start0() : void renamed to public start(ctx GridCacheSharedContext, grp CacheGroupContext) : void in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Method public cacheId() : int renamed to public groupId() : int in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtPartitionTopology |
From |
To |
|
Rename Method public onCacheCreated(cctx GridCacheContext) : void renamed to package onCacheGroupCreated(grp CacheGroupContext) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Method protected nextPartCounter() : long renamed to protected nextPartitionCounter(topVer AffinityTopologyVersion, primary boolean, primaryCntr Long) : long in class org.apache.ignite.internal.processors.cache.GridCacheMapEntry |
From |
To |
|
Rename Method public clear(readers boolean) : void renamed to public clearCache(cctx GridCacheContext, readers boolean) : void in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Method public cacheId() : int renamed to public groupId() : int in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtAssignmentFetchFuture |
From |
To |
|
Rename Method protected stop0(cancel boolean, destroy boolean) : void renamed to public stopCache(cacheId int, destroy boolean) : void in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Method public stopping(cacheId int) : boolean renamed to private cacheStopping(cacheId int) : boolean in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Method public cacheAffinityNodes(cacheId int) : List<ClusterNode> renamed to public cacheGroupAffinityNodes(grpId int) : List<ClusterNode> in class org.apache.ignite.internal.managers.discovery.DiscoCache |
From |
To |
|
Rename Method public clear(readers boolean) : void renamed to public clearCache(cctx GridCacheContext, readers boolean) : void in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManager |
From |
To |
|
Rename Method public size() : int renamed to public fullSize() : int in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManager.CacheDataStore |
From |
To |
|
Rename Method protected initDataStructures() : void renamed to public onCacheStarted(cctx GridCacheContext) : void in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Method public keysIterator(part int) : GridCloseableIterator<KeyCacheObject> renamed to public cacheKeysIterator(cacheId int, part int) : GridCloseableIterator<KeyCacheObject> in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Method public size() : int renamed to public fullSize() : int in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.CacheDataStoreImpl |
From |
To |
|
Rename Method protected destroyCacheDataStructures(destroy boolean) : void renamed to public stop() : void in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Method public entriesCount() : long renamed to public cacheEntriesCount(cacheId int) : long in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManager |
From |
To |
|
Rename Method public cacheName() : String renamed to public cacheOrGroupName() : String in class org.apache.ignite.internal.processors.affinity.GridAffinityAssignmentCache |
From |
To |
|
Rename Method public addAssignments(assignments GridDhtPreloaderAssignments, forcePreload boolean, caches Collection<String>, cnt int, next Runnable, forcedRebFut GridFutureAdapter<Boolean>) : Runnable renamed to public request(cctx GridCacheContext, keys Collection<KeyCacheObject>, topVer AffinityTopologyVersion) : GridDhtFuture<Object> in class org.apache.ignite.internal.processors.cache.GridCachePreloader |
From |
To |
|
Rename Method public containsCache(cacheId int) : boolean renamed to public containsGroup(grpId int) : boolean in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsFullMessage |
From |
To |
|
Rename Method public entriesCount() : long renamed to public cacheEntriesCount(cacheId int) : long in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Method private onCacheStopped(topVer AffinityTopologyVersion) : void renamed to private onCacheGroupStopped(topVer AffinityTopologyVersion) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Method protected nextPartCounter() : long renamed to protected nextPartitionCounter(topVer AffinityTopologyVersion, primary boolean, primaryCntr Long) : long in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheEntry |
From |
To |
|
Rename Method private cache(fut GridDhtPartitionsExchangeFuture, desc DynamicCacheDescriptor) : CacheHolder renamed to private groupHolder(fut GridDhtPartitionsExchangeFuture, desc CacheGroupDescriptor) : CacheGroupHolder in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Method private forAllCaches(crd boolean, c IgniteInClosureX<GridAffinityAssignmentCache>) : void renamed to private forAllCacheGroups(crd boolean, c IgniteInClosureX<GridAffinityAssignmentCache>) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Method package cacheId() : int renamed to package groupId() : int in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.CacheGroupHolder |
From |
To |
|
Rename Method public addAssignments(assignments GridDhtPreloaderAssignments, forcePreload boolean, caches Collection<String>, cnt int, next Runnable, forcedRebFut GridFutureAdapter<Boolean>) : Runnable renamed to public request(ctx GridCacheContext, keys Collection<KeyCacheObject>, topVer AffinityTopologyVersion) : GridDhtFuture<Object> in class org.apache.ignite.internal.processors.cache.GridCachePreloaderAdapter |
From |
To |
|
Rename Method package createRowWithKey(cctx GridCacheContext, expireTime long, link long) : PendingRow renamed to package initKey(grp CacheGroupContext) : PendingRow in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingRow |
From |
To |
|
Rename Method private forAllRegisteredCaches(c IgniteInClosureX<DynamicCacheDescriptor>) : void renamed to private forAllRegisteredCacheGroups(c IgniteInClosureX<CacheGroupDescriptor>) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private initAffinityOnNodeJoin(fut GridDhtPartitionsExchangeFuture, crd boolean) : WaitRebalanceInfo in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method public run() : void in class org.apache.ignite.internal.processors.cache.GridCacheProcessor.RemovedItemsCleanupTask.onTimeout.runLocalSafe |
From |
To |
|
Change Variable Type desc : DynamicCacheDescriptor to desc : CacheGroupDescriptor in method private resolveDiscoCache(grpId int, topVer AffinityTopologyVersion) : DiscoCache in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager |
From |
To |
|
Change Variable Type req : DynamicCacheChangeRequest to req : ExchangeActions.ActionData in method public onExchangeDone(topVer AffinityTopologyVersion, exchActions ExchangeActions, err Throwable, forceClose boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheProcessor |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private initAffinityNoLateAssignment(fut GridDhtPartitionsExchangeFuture) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type desc : DynamicCacheDescriptor to desc : CacheGroupDescriptor in method package onDiscoveryEvent(type int, node ClusterNode, topVer AffinityTopologyVersion) : void in class org.apache.ignite.internal.processors.cache.ClusterCachesInfo |
From |
To |
|
Change Variable Type cacheDesc : DynamicCacheDescriptor to grpDesc : CacheGroupDescriptor in method private fetchAffinityOnJoin(fut GridDhtPartitionsExchangeFuture) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type old : DynamicCacheDescriptor to old : CacheGroupDescriptor in method private updateCachesInfo(exchActions ExchangeActions) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method public apply(fut IgniteInternalFuture<AffinityTopologyVersion>) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.onKernalStart0.listen |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext<K,V> to grp : CacheGroupContext in method protected body() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.ExchangeWorker |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private refreshPartitions() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Variable Type cache : CacheHolder to cacheGrp : CacheGroupHolder in method private groupHolder(fut GridDhtPartitionsExchangeFuture, desc CacheGroupDescriptor) : CacheGroupHolder in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private fetchAffinityOnJoin(fut GridDhtPartitionsExchangeFuture) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private updatePartitionSingleMap(node ClusterNode, msg GridDhtPartitionsSingleMessage) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type stopFut : GridCompoundFuture<?,?> to stopFut : IgniteInternalFuture<?> in method public onReconnected(clusterRestarted boolean) : IgniteInternalFuture<?> in class org.apache.ignite.internal.processors.cache.GridCacheProcessor |
From |
To |
|
Change Variable Type old : CacheHolder to old : CacheGroupHolder in method private initStartedGroupOnCoordinator(fut GridDhtPartitionsExchangeFuture, grpDesc CacheGroupDescriptor) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type desc : DynamicCacheDescriptor to grpId : Integer in method public onCacheChangeRequest(fut GridDhtPartitionsExchangeFuture, crd boolean, exchActions ExchangeActions) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type name : String to cacheDesc : DynamicCacheDescriptor in method private warnNoAffinityNodes() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type cache : CacheHolder to grpHolder : CacheGroupHolder in method package checkRebalanceState(top GridDhtPartitionTopology, checkGrpId Integer) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private initStartedGroupOnCoordinator(fut GridDhtPartitionsExchangeFuture, grpDesc CacheGroupDescriptor) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheDesc : DynamicCacheDescriptor to cacheDesc : CacheGroupDescriptor in method private forAllRegisteredCacheGroups(c IgniteInClosureX<CacheGroupDescriptor>) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method public onServerLeft(fut GridDhtPartitionsExchangeFuture) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private updatePartitionFullMap(msg GridDhtPartitionsFullMessage) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private onAllReceived() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type part : int to retry : Integer in method private map0() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtGetSingleFuture |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private initTopologies() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method public createPartitionsSingleMessage(targetNode ClusterNode, exchangeId GridDhtPartitionExchangeId, clientOnlyExchange boolean, sndCounters boolean) : GridDhtPartitionsSingleMessage in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Variable Type clientCache : IgniteCache to cache : IgniteCache<Object,Object> in method private concurrentUpdatePartition(atomicityMode CacheAtomicityMode, cacheGrp boolean) : void in class org.apache.ignite.internal.processors.cache.query.continuous.CacheContinuousQueryConcurrentPartitionUpdateTest |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private groupHolder(fut GridDhtPartitionsExchangeFuture, desc CacheGroupDescriptor) : CacheGroupHolder in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cache : CacheHolder to grp : CacheGroupHolder in method private forAllCacheGroups(crd boolean, c IgniteInClosureX<GridAffinityAssignmentCache>) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cache : GridCacheAdapter<?,?> to grp : CacheGroupContext in method public onKernalStopCaches(cancel boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheProcessor |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private assignPartitionsStates() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type desc : DynamicCacheDescriptor to rmvd : CacheGroupDescriptor in method private updateCachesInfo(exchActions ExchangeActions) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private onLeft() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type desc : DynamicCacheDescriptor to desc : CacheGroupDescriptor in method package onDiscoveryEvent(type int, node ClusterNode, topVer AffinityTopologyVersion) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type res : CacheDataRow to ret : CacheEntryImplEx in method protected onNext() : Cache.Entry<K,V> in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.cacheEntriesIterator |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method public dumpDebugInfo(exchTopVer AffinityTopologyVersion) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method public run() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.onNodeLeft.onDiscoveryEvent |
From |
To |
|
Change Variable Type desc : DynamicCacheDescriptor to grpDesc : CacheGroupDescriptor in method public clientTopology(grpId int, exchFut GridDhtPartitionsExchangeFuture) : GridDhtPartitionTopology in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method protected body() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.ExchangeWorker |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext<K,V> to grp : CacheGroupContext in method private processFullPartitionUpdate(node ClusterNode, msg GridDhtPartitionsFullMessage) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method public onCacheChangeRequest(fut GridDhtPartitionsExchangeFuture, crd boolean, exchActions ExchangeActions) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext<K,V> to grp : CacheGroupContext in method private processSinglePartitionUpdate(node ClusterNode, msg GridDhtPartitionsSingleMessage) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Variable Type req : DynamicCacheChangeRequest to grpDesc : CacheGroupDescriptor in method public onCacheChangeRequest(fut GridDhtPartitionsExchangeFuture, crd boolean, exchActions ExchangeActions) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private detectLostPartitions() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type stopFut : GridCompoundFuture<?,?> to stoppedCaches : List<GridCacheAdapter> in method private stopCacheOnReconnect(cctx GridCacheContext, stoppedCaches List<GridCacheAdapter>) : void in class org.apache.ignite.internal.processors.cache.GridCacheProcessor |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private clientOnlyExchange() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type map : GridCacheConcurrentMap to map : GridCacheLocalConcurrentMap in method public testExpirationOnClient() : void in class org.apache.ignite.internal.processors.cache.expiry.IgniteCacheClientNearCacheExpiryTest |
From |
To |
|
Change Variable Type action : ExchangeActions.ActionData to stopDesc : CacheGroupDescriptor in method private updateCachesInfo(exchActions ExchangeActions) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type aff : GridCacheAffinityManager to aff : GridAffinityAssignmentCache in method public onKernalStopCaches(cancel boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheProcessor |
From |
To |
|
Change Variable Type res : List<DynamicCacheChangeRequest> to res : List<ActionData> in method package closeRequests(nodeId UUID) : List<ActionData> in class org.apache.ignite.internal.processors.cache.ExchangeActions |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private updateTopologies(crd boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Change Variable Type old : CacheHolder to old : CacheGroupHolder in method private groupHolder(fut GridDhtPartitionsExchangeFuture, desc CacheGroupDescriptor) : CacheGroupHolder in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method protected onKernalStart0(reconnect boolean) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Variable Type affMgr : GridCacheAffinityManager to aff : GridAffinityAssignmentCache in method private dumpPendingObjects(exchTopVer AffinityTopologyVersion) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Variable Type cacheCtx : GridCacheContext to grp : CacheGroupContext in method private forAllCacheGroups(crd boolean, c IgniteInClosureX<GridAffinityAssignmentCache>) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Pull Up Method public getLink(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryInnerIO to public getLink(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryInnerIO |
From |
To |
|
Pull Up Method public getLookupRow(tree BPlusTree<CacheSearchRow,?>, pageAddr long, idx int) : CacheSearchRow from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataInnerIO to public getLookupRow(tree BPlusTree<CacheSearchRow,?>, pageAddr long, idx int) : CacheSearchRow from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataInnerIO |
From |
To |
|
Pull Up Method public store(dstPageAddr long, dstIdx int, srcIo BPlusIO<PendingRow>, srcPageAddr long, srcIdx int) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryInnerIO to public store(dstPageAddr long, dstIdx int, srcIo BPlusIO<PendingRow>, srcPageAddr long, srcIdx int) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryInnerIO |
From |
To |
|
Pull Up Method public getHash(pageAddr long, idx int) : int from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataInnerIO to public getHash(pageAddr long, idx int) : int from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataInnerIO |
From |
To |
|
Pull Up Method public store(dstPageAddr long, dstIdx int, srcIo BPlusIO<CacheSearchRow>, srcPageAddr long, srcIdx int) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataLeafIO to public store(dstPageAddr long, dstIdx int, srcIo BPlusIO<CacheSearchRow>, srcPageAddr long, srcIdx int) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataLeafIO |
From |
To |
|
Pull Up Method public getLink(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryLeafIO to public getLink(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryLeafIO |
From |
To |
|
Pull Up Method public getLink(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataLeafIO to public getLink(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataLeafIO |
From |
To |
|
Pull Up Method public getLookupRow(tree BPlusTree<PendingRow,?>, pageAddr long, idx int) : PendingRow from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryLeafIO to public getLookupRow(tree BPlusTree<PendingRow,?>, pageAddr long, idx int) : PendingRow from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryLeafIO |
From |
To |
|
Pull Up Method public getLookupRow(tree BPlusTree<CacheSearchRow,?>, buf long, idx int) : CacheSearchRow from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataLeafIO to public getLookupRow(tree BPlusTree<CacheSearchRow,?>, buf long, idx int) : CacheSearchRow from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataLeafIO |
From |
To |
|
Pull Up Method public storeByOffset(pageAddr long, off int, row CacheSearchRow) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataInnerIO to public storeByOffset(pageAddr long, off int, row CacheSearchRow) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataInnerIO |
From |
To |
|
Pull Up Method public storeByOffset(pageAddr long, off int, row PendingRow) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryLeafIO to public storeByOffset(pageAddr long, off int, row PendingRow) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryLeafIO |
From |
To |
|
Pull Up Method public storeByOffset(pageAddr long, off int, row CacheSearchRow) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataLeafIO to public storeByOffset(pageAddr long, off int, row CacheSearchRow) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataLeafIO |
From |
To |
|
Pull Up Method public storeByOffset(pageAddr long, off int, row PendingRow) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryInnerIO to public storeByOffset(pageAddr long, off int, row PendingRow) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryInnerIO |
From |
To |
|
Pull Up Method public store(dstPageAddr long, dstIdx int, srcIo BPlusIO<CacheSearchRow>, srcPageAddr long, srcIdx int) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataInnerIO to public store(dstPageAddr long, dstIdx int, srcIo BPlusIO<CacheSearchRow>, srcPageAddr long, srcIdx int) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataInnerIO |
From |
To |
|
Pull Up Method public getHash(pageAddr long, idx int) : int from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataLeafIO to public getHash(pageAddr long, idx int) : int from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataLeafIO |
From |
To |
|
Pull Up Method public store(dstPageAddr long, dstIdx int, srcIo BPlusIO<PendingRow>, srcPageAddr long, srcIdx int) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryLeafIO to public store(dstPageAddr long, dstIdx int, srcIo BPlusIO<PendingRow>, srcPageAddr long, srcIdx int) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryLeafIO |
From |
To |
|
Pull Up Method public visit(pageAddr long, c IgniteInClosure<CacheSearchRow>) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataInnerIO to public visit(pageAddr long, c IgniteInClosure<CacheSearchRow>) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataInnerIO |
From |
To |
|
Pull Up Method public getLink(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataInnerIO to public getLink(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataInnerIO |
From |
To |
|
Pull Up Method public getExpireTime(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryInnerIO to public getExpireTime(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryInnerIO |
From |
To |
|
Pull Up Method public getExpireTime(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryLeafIO to public getExpireTime(pageAddr long, idx int) : long from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryLeafIO |
From |
To |
|
Pull Up Method public getLookupRow(tree BPlusTree<PendingRow,?>, pageAddr long, idx int) : PendingRow from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntryInnerIO to public getLookupRow(tree BPlusTree<PendingRow,?>, pageAddr long, idx int) : PendingRow from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractPendingEntryInnerIO |
From |
To |
|
Pull Up Method public visit(pageAddr long, c IgniteInClosure<CacheSearchRow>) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.DataLeafIO to public visit(pageAddr long, c IgniteInClosure<CacheSearchRow>) : void from class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.AbstractDataLeafIO |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private updatePartitionSingleMap(node ClusterNode, msg GridDhtPartitionsSingleMessage) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method protected onKernalStart0(reconnect boolean) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable dupCacheId : Integer to dupGrpId : Integer in method private checkSingleMessage(cache1 String, cache2 String, dupPartsData Map<Integer,Integer>, msg GridDhtPartitionsSingleMessage) : void in class org.apache.ignite.internal.processors.cache.CacheExchangeMessageDuplicatedStateTest |
From |
To |
|
Rename Variable name : String to cacheDesc : DynamicCacheDescriptor in method private warnNoAffinityNodes() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private onAllReceived() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable customMessage : DiscoveryCustomMessage to customMsg : DiscoveryCustomMessage in method private distributedExchange() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable res : CacheDataRow to ret : CacheEntryImplEx in method protected onNext() : Cache.Entry<K,V> in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.cacheEntriesIterator |
From |
To |
|
Rename Variable clientCache : IgniteCache to cache : IgniteCache in method private concurrentUpdatesAndQueryStart(atomicityMode CacheAtomicityMode, cacheGrp boolean) : void in class org.apache.ignite.internal.processors.cache.query.continuous.CacheContinuousQueryConcurrentPartitionUpdateTest |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private clientOnlyExchange() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method public createPartitionsSingleMessage(targetNode ClusterNode, exchangeId GridDhtPartitionExchangeId, clientOnlyExchange boolean, sndCounters boolean) : GridDhtPartitionsSingleMessage in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable cacheDesc : DynamicCacheDescriptor to grpDesc : CacheGroupDescriptor in method private fetchAffinityOnJoin(fut GridDhtPartitionsExchangeFuture) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private refreshPartitions() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private processFullPartitionUpdate(node ClusterNode, msg GridDhtPartitionsFullMessage) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private fetchAffinityOnJoin(fut GridDhtPartitionsExchangeFuture) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable removed : boolean to rmv : boolean in method public removeEntry(entry GridCacheEntryEx) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheConcurrentMapImpl |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method public onCacheChangeRequest(fut GridDhtPartitionsExchangeFuture, crd boolean, exchActions ExchangeActions) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private forAllCacheGroups(crd boolean, c IgniteInClosureX<GridAffinityAssignmentCache>) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable req : DynamicCacheChangeRequest to grpDesc : CacheGroupDescriptor in method public onCacheChangeRequest(fut GridDhtPartitionsExchangeFuture, crd boolean, exchActions ExchangeActions) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method protected body() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.ExchangeWorker |
From |
To |
|
Rename Variable cache : CacheHolder to grpHolder : CacheGroupHolder in method package checkRebalanceState(top GridDhtPartitionTopology, checkGrpId Integer) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private checkSingleMessage(cache1 String, cache2 String, dupPartsData Map<Integer,Integer>, msg GridDhtPartitionsSingleMessage) : void in class org.apache.ignite.internal.processors.cache.CacheExchangeMessageDuplicatedStateTest |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private updatePartitionSingleMap(node ClusterNode, msg GridDhtPartitionsSingleMessage) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method public run() : void in class org.apache.ignite.internal.processors.cache.GridCacheProcessor.RemovedItemsCleanupTask.onTimeout.runLocalSafe |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private updatePartitionFullMap(msg GridDhtPartitionsFullMessage) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable desc : DynamicCacheDescriptor to grpDesc : CacheGroupDescriptor in method public clientTopology(grpId int, exchFut GridDhtPartitionsExchangeFuture) : GridDhtPartitionTopology in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private onAllReceived() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method public onCacheChangeRequest(fut GridDhtPartitionsExchangeFuture, crd boolean, exchActions ExchangeActions) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext<K,V> to grp : CacheGroupContext in method protected body() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.ExchangeWorker |
From |
To |
|
Rename Variable cache : CacheHolder to cacheGrp : CacheGroupHolder in method private groupHolder(fut GridDhtPartitionsExchangeFuture, desc CacheGroupDescriptor) : CacheGroupHolder in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method package onCacheGroupCreated(grp CacheGroupContext) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private groupNames(grpIds Collection<Integer>) : String in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private updateTopologies(crd boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable clientCache : IgniteCache to cache : IgniteCache<Object,Object> in method private concurrentUpdatePartition(atomicityMode CacheAtomicityMode, cacheGrp boolean) : void in class org.apache.ignite.internal.processors.cache.query.continuous.CacheContinuousQueryConcurrentPartitionUpdateTest |
From |
To |
|
Rename Variable cacheId : int to grpId : int in method protected body() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.ExchangeWorker |
From |
To |
|
Rename Variable cache : CacheHolder to grp : CacheGroupHolder in method private forAllCacheGroups(crd boolean, c IgniteInClosureX<GridAffinityAssignmentCache>) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable affCacheNodes : Map<Integer,List<ClusterNode>> to cacheGrpAffNodes : Map<Integer,List<ClusterNode>> in method private createDiscoCache(loc ClusterNode, topSnapshot Collection<ClusterNode>) : DiscoCache in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private affinityChangeMessage(waitInfo WaitRebalanceInfo) : CacheAffinityChangeMessage in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private detectLostPartitions() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable desc : DynamicCacheDescriptor to grpId : Integer in method public onCacheChangeRequest(fut GridDhtPartitionsExchangeFuture, crd boolean, exchActions ExchangeActions) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method public onServerLeft(fut GridDhtPartitionsExchangeFuture) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private updatePartitionFullMap(msg GridDhtPartitionsFullMessage) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private initTopologies() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method protected body() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.ExchangeWorker |
From |
To |
|
Rename Variable action : ExchangeActions.ActionData to stopDesc : CacheGroupDescriptor in method private updateCachesInfo(exchActions ExchangeActions) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext<K,V> to grp : CacheGroupContext in method private processFullPartitionUpdate(node ClusterNode, msg GridDhtPartitionsFullMessage) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method public apply(fut IgniteInternalFuture<AffinityTopologyVersion>) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.onKernalStart0.listen |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext<K,V> to grp : CacheGroupContext in method private processSinglePartitionUpdate(node ClusterNode, msg GridDhtPartitionsSingleMessage) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private fetchAffinityOnJoin(fut GridDhtPartitionsExchangeFuture) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable dupCacheId : Integer to dupGrpId : Integer in method private checkFullMessage(cache1 String, cache2 String, dupPartsData Map<Integer,Integer>, msg GridDhtPartitionsFullMessage) : void in class org.apache.ignite.internal.processors.cache.CacheExchangeMessageDuplicatedStateTest |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private groupHolder(fut GridDhtPartitionsExchangeFuture, desc CacheGroupDescriptor) : CacheGroupHolder in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cache : GridCacheAdapter<?,?> to grp : CacheGroupContext in method public onKernalStopCaches(cancel boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheProcessor |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private assignPartitionsStates() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable affMgr : GridCacheAffinityManager to aff : GridAffinityAssignmentCache in method private dumpPendingObjects(exchTopVer AffinityTopologyVersion) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private checkFullMessage(cache1 String, cache2 String, dupPartsData Map<Integer,Integer>, msg GridDhtPartitionsFullMessage) : void in class org.apache.ignite.internal.processors.cache.CacheExchangeMessageDuplicatedStateTest |
From |
To |
|
Rename Variable desc : DynamicCacheDescriptor to rmvd : CacheGroupDescriptor in method private updateCachesInfo(exchActions ExchangeActions) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private onLeft() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private initAffinityOnNodeJoin(fut GridDhtPartitionsExchangeFuture, crd boolean) : WaitRebalanceInfo in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheId : Integer to grpId : Integer in method private processSinglePartitionUpdate(node ClusterNode, msg GridDhtPartitionsSingleMessage) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private initStartedGroupOnCoordinator(fut GridDhtPartitionsExchangeFuture, grpDesc CacheGroupDescriptor) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable stoppedCaches : Set<Integer> to stoppedGrps : Set<Integer> in method public onCacheChangeRequest(fut GridDhtPartitionsExchangeFuture, crd boolean, exchActions ExchangeActions) : boolean in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method public dumpDebugInfo(exchTopVer AffinityTopologyVersion) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method public run() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.onNodeLeft.onDiscoveryEvent |
From |
To |
|
Rename Variable cacheCtx : GridCacheContext to grp : CacheGroupContext in method private initAffinityNoLateAssignment(fut GridDhtPartitionsExchangeFuture) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Return Type Integer to int in method public cacheId() : int in class org.apache.ignite.internal.processors.cache.CacheData |
From |
To |
|
Change Return Type boolean to void in method private sendAllPartitions(nodes Collection<ClusterNode>) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Change Return Type void to String in method private processJoiningNode(joinData CacheJoinNodeDiscoveryData, nodeId UUID, locJoin boolean) : String in class org.apache.ignite.internal.processors.cache.ClusterCachesInfo |
From |
To |
|
Change Return Type Collection<DynamicCacheDescriptor> to Map<String,DynamicCacheDescriptor> in method public cacheDescriptors() : Map<String,DynamicCacheDescriptor> in class org.apache.ignite.internal.processors.cache.GridCacheProcessor |
From |
To |
|
Change Return Type Set<String> to ClusterCachesReconnectResult in method package onReconnected() : ClusterCachesReconnectResult in class org.apache.ignite.internal.processors.cache.ClusterCachesInfo |
From |
To |
|
Change Return Type Runnable to GridDhtFuture<Object> in method public request(cctx GridCacheContext, keys Collection<KeyCacheObject>, topVer AffinityTopologyVersion) : GridDhtFuture<Object> in class org.apache.ignite.internal.processors.cache.GridCachePreloader |
From |
To |
|
Change Return Type void to CacheGroupContext in method private prepareCacheStop(req DynamicCacheChangeRequest, forceClose boolean) : CacheGroupContext in class org.apache.ignite.internal.processors.cache.GridCacheProcessor |
From |
To |
|
Change Return Type IgniteInternalFuture<Object> to GridDhtFuture<Object> in method public request(cctx GridCacheContext, req GridNearAtomicAbstractUpdateRequest, topVer AffinityTopologyVersion) : GridDhtFuture<Object> in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloader |
From |
To |
|
Change Return Type Runnable to GridDhtFuture<Object> in method public request(ctx GridCacheContext, keys Collection<KeyCacheObject>, topVer AffinityTopologyVersion) : GridDhtFuture<Object> in class org.apache.ignite.internal.processors.cache.GridCachePreloaderAdapter |
From |
To |
|
Change Return Type IgniteInternalFuture<Object> to GridDhtFuture<Object> in method public request(cctx GridCacheContext, req GridNearAtomicAbstractUpdateRequest, topVer AffinityTopologyVersion) : GridDhtFuture<Object> in class org.apache.ignite.internal.processors.cache.GridCachePreloader |
From |
To |
|
Change Return Type CacheHolder to CacheGroupHolder in method private groupHolder(fut GridDhtPartitionsExchangeFuture, desc CacheGroupDescriptor) : CacheGroupHolder in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Change Return Type GridIterator<CacheDataRow> to GridCloseableIterator<Cache.Entry<K,V>> in method public cacheEntriesIterator(cctx GridCacheContext, primary boolean, backup boolean, topVer AffinityTopologyVersion, keepBinary boolean) : GridCloseableIterator<Cache.Entry<K,V>> in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Change Return Type List<DynamicCacheChangeRequest> to List<ActionData> in method package closeRequests(nodeId UUID) : List<ActionData> in class org.apache.ignite.internal.processors.cache.ExchangeActions |
From |
To |
|
Rename Attribute memPlc : MemoryPolicy to grp : CacheGroupContext in class org.apache.ignite.internal.processors.cache.GridCacheContext |
From |
To |
|
Rename Attribute registeredCaches : Map<Integer,DynamicCacheDescriptor> to registeredGrps : Map<Integer,CacheGroupDescriptor> in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Attribute cacheId : int to grpId : int in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtAssignmentFetchFuture |
From |
To |
|
Rename Attribute reuseList : ReuseList to cacheIdBoxed : Integer in class org.apache.ignite.internal.processors.cache.GridCacheContext |
From |
To |
|
Rename Attribute cacheName : String to cacheOrGrpName : String in class org.apache.ignite.internal.processors.affinity.GridAffinityAssignmentCache |
From |
To |
|
Rename Attribute ctx : GridCacheContext to grp : CacheGroupContext in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedConcurrentMap |
From |
To |
|
Rename Attribute cctx : GridCacheContext<?,?> to ctx : GridCacheSharedContext in class org.apache.ignite.internal.processors.cache.GridCachePreloaderAdapter |
From |
To |
|
Rename Attribute localNodeInitLsnrs : Collection<IgniteInClosure<ClusterNode>> to locNodeInitLsnrs : Collection<IgniteInClosure<ClusterNode>> in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager |
From |
To |
|
Rename Attribute waitCaches : Map<Integer,Map<Integer,UUID>> to waitGrps : Map<Integer,Map<Integer,UUID>> in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.WaitRebalanceInfo |
From |
To |
|
Rename Attribute affCacheNodes : Map<Integer,List<ClusterNode>> to cacheGrpAffNodes : Map<Integer,List<ClusterNode>> in class org.apache.ignite.internal.managers.discovery.DiscoCache |
From |
To |
|
Rename Attribute cctx : GridCacheContext to grp : CacheGroupContext in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.CacheDataTree |
From |
To |
|
Rename Attribute cacheId : int to grpId : int in class org.apache.ignite.internal.processors.cache.distributed.dht.GridClientPartitionTopology |
From |
To |
|
Rename Attribute cctx : GridCacheContext<?,?> to grp : CacheGroupContext in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplier |
From |
To |
|
Rename Attribute cacheId : int to grpId : int in class org.apache.ignite.internal.processors.affinity.GridAffinityAssignmentCache |
From |
To |
|
Rename Attribute cacheId : int to hndId : int in class org.apache.ignite.internal.processors.cache.GridCacheIoManager.ListenerKey |
From |
To |
|
Rename Attribute cctx : GridCacheContext<?,?> to grp : CacheGroupContext in class org.apache.ignite.internal.processors.cache.GridCachePreloaderAdapter |
From |
To |
|
Rename Attribute aff : AffinityFunction to ctx : GridCacheSharedContext in class org.apache.ignite.internal.processors.cache.GridCachePreloaderAdapter |
From |
To |
|
Rename Attribute cacheValidRes : Map<Integer,CacheValidation> to grpValidRes : Map<Integer,CacheValidation> in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture |
From |
To |
|
Rename Attribute caches : ConcurrentMap<Integer,CacheHolder> to grpHolders : ConcurrentMap<Integer,CacheGroupHolder> in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public containsGroup(grpId int) : boolean in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsFullMessage |
From |
To |
|
Rename Parameter event : CacheRebalancingEvent to evt : CacheRebalancingEvent in method public apply(evt CacheRebalancingEvent) : boolean in class org.apache.ignite.internal.processors.cache.GridCacheOrderedPreloadingSelfTest.getConfiguration.put |
From |
To |
|
Rename Parameter cacheId : int to hndId : int in method private addHandler(hndId int, type Class<? extends GridCacheMessage>, c IgniteBiInClosure<UUID,? extends GridCacheMessage>, msgHandlers MessageHandlers) : void in class org.apache.ignite.internal.processors.cache.GridCacheIoManager |
From |
To |
|
Rename Parameter io : BPlusIO<PendingRow> to iox : BPlusIO<PendingRow> in method protected compare(iox BPlusIO<PendingRow>, pageAddr long, idx int, row PendingRow) : int in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntriesTree |
From |
To |
|
Rename Parameter ctx : GridCacheContext to grp : CacheGroupContext in method package GridCachePartitionedConcurrentMap(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedConcurrentMap |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public cacheGroupAffinityNodes(grpId int) : List<ClusterNode> in class org.apache.ignite.internal.managers.discovery.DiscoCache |
From |
To |
|
Rename Parameter cacheId : Integer to grpDesc : CacheGroupDescriptor in method private initStartedGroupOnCoordinator(fut GridDhtPartitionsExchangeFuture, grpDesc CacheGroupDescriptor) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method protected H2Tree(name String, reuseList ReuseList, grpId int, pageMem PageMemory, wal IgniteWriteAheadLogManager, globalRmvId AtomicLong, rowStore H2RowFactory, metaPageId long, initNew boolean, cols IndexColumn[], inlineIdxs List<InlineIndexHelper>, inlineSize int) in class org.apache.ignite.internal.processors.query.h2.database.H2Tree |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public clearClientTopology(grpId int) : GridClientPartitionTopology in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Parameter cctx : GridCacheContext to grp : CacheGroupContext in method package initKey(grp CacheGroupContext) : PendingRow in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingRow |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method package GridDhtPartitionDemandMessage(updateSeq long, topVer AffinityTopologyVersion, grpId int) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionDemandMessage |
From |
To |
|
Rename Parameter cctx : GridCacheContext to grp : CacheGroupContext in method public PendingEntriesTree(grp CacheGroupContext, name String, pageMem PageMemory, metaPageId long, reuseList ReuseList, initNew boolean) in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntriesTree |
From |
To |
|
Rename Parameter cacheIds : Collection<Integer> to grpIds : Collection<Integer> in method private groupNames(grpIds Collection<Integer>) : String in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Parameter cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public RowStore(grp CacheGroupContext, freeList FreeList) in class org.apache.ignite.internal.processors.cache.database.RowStore |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method package GridDhtPartitionSupplyMessage(updateSeq long, grpId int, topVer AffinityTopologyVersion, addDepInfo boolean) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyMessage |
From |
To |
|
Rename Parameter cacheName : String to grpId : int in method private dataNodes(grpId int, topVer AffinityTopologyVersion) : Collection<ClusterNode> in class org.apache.ignite.internal.processors.query.h2.twostep.GridReduceQueryExecutor |
From |
To |
|
Rename Parameter cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public CacheDataRowStore(grp CacheGroupContext, freeList FreeList, partId int) in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.CacheDataRowStore |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public addPartitionUpdateCounters(grpId int, cntrMap Map<Integer,T2<Long,Long>>) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsFullMessage |
From |
To |
|
Rename Parameter cancel : boolean to cacheId : int in method public stopCache(cacheId int, destroy boolean) : void in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl |
From |
To |
|
Rename Parameter cacheFilter : IgnitePredicate<ClusterNode> to aff : CacheGroupAffinity in method private CachePredicate(aff CacheGroupAffinity, nearEnabled boolean) in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.CachePredicate |
From |
To |
|
Rename Parameter cacheId : int to hndId : int in method private removeHandlers(msgHandlers MessageHandlers, hndId int) : void in class org.apache.ignite.internal.processors.cache.GridCacheIoManager |
From |
To |
|
Rename Parameter cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method package GridDhtPartitionSupplier(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplier |
From |
To |
|
Rename Parameter affCacheNodes : Map<Integer,List<ClusterNode>> to cacheGrpAffNodes : Map<Integer,List<ClusterNode>> in method package DiscoCache(loc ClusterNode, rmtNodes List<ClusterNode>, allNodes List<ClusterNode>, srvNodes List<ClusterNode>, daemonNodes List<ClusterNode>, srvNodesWithCaches List<ClusterNode>, allNodesWithCaches List<ClusterNode>, rmtNodesWithCaches List<ClusterNode>, allCacheNodes Map<Integer,List<ClusterNode>>, cacheGrpAffNodes Map<Integer,List<ClusterNode>>, nodeMap Map<UUID,ClusterNode>, nearEnabledCaches Set<Integer>, alives Set<UUID>) in class org.apache.ignite.internal.managers.discovery.DiscoCache |
From |
To |
|
Rename Parameter cacheDesc : DynamicCacheDescriptor to grpDesc : CacheGroupDescriptor in method public GridDhtAssignmentFetchFuture(ctx GridCacheSharedContext, grpDesc CacheGroupDescriptor, topVer AffinityTopologyVersion, discoCache DiscoCache) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtAssignmentFetchFuture |
From |
To |
|
Rename Parameter cacheName : String to cacheOrGrpName : String in method public GridAffinityAssignmentCache(ctx GridKernalContext, cacheOrGrpName String, grpId int, aff AffinityFunction, nodeFilter IgnitePredicate<ClusterNode>, backups int, locCache boolean) in class org.apache.ignite.internal.processors.affinity.GridAffinityAssignmentCache |
From |
To |
|
Rename Parameter ignore : Object to flag : Object in method protected getRow(io BPlusIO<PendingRow>, pageAddr long, idx int, flag Object) : PendingRow in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.PendingEntriesTree |
From |
To |
|
Rename Parameter cacheId : Integer to grpId : Integer in method private addFullPartitionsMap(m GridDhtPartitionsFullMessage, dupData Map<Object,T2<Integer,GridDhtPartitionFullMap>>, compress boolean, grpId Integer, map GridDhtPartitionFullMap, affKey Object) : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method private resolveDiscoCache(grpId int, topVer AffinityTopologyVersion) : DiscoCache in class org.apache.ignite.internal.managers.discovery.GridDiscoveryManager |
From |
To |
|
Rename Parameter cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public GridDhtPreloader(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloader |
From |
To |
|
Rename Parameter checkCacheId : Integer to checkGrpId : Integer in method package checkRebalanceState(top GridDhtPartitionTopology, checkGrpId Integer) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public clientTopology(grpId int, exchFut GridDhtPartitionsExchangeFuture) : GridDhtPartitionTopology in class org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public GridDhtAffinityAssignmentResponse(futId long, grpId int, topVer AffinityTopologyVersion, affAssignment List<List<ClusterNode>>) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtAffinityAssignmentResponse |
From |
To |
|
Rename Parameter cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public initFromLink(grp CacheGroupContext, rowData RowData) : void in class org.apache.ignite.internal.processors.cache.database.CacheDataRowAdapter |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public partitionUpdateCounters(grpId int) : Map<Integer,T2<Long,Long>> in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsFullMessage |
From |
To |
|
Rename Parameter cacheId : Integer to grpId : Integer in method package add(grpId Integer, part Integer, waitNode UUID, assignment List<ClusterNode>) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.WaitRebalanceInfo |
From |
To |
|
Rename Parameter entryFactory : GridCacheMapEntryFactory to grp : CacheGroupContext in method public GridDhtPartitionTopologyImpl(ctx GridCacheSharedContext, grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtPartitionTopologyImpl |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public addFullPartitionsMap(grpId int, fullMap GridDhtPartitionFullMap, dupDataCache Integer) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsFullMessage |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public GridDhtAffinityAssignmentRequest(futId long, grpId int, topVer AffinityTopologyVersion) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtAffinityAssignmentRequest |
From |
To |
|
Rename Parameter io : BPlusIO<CacheSearchRow> to iox : BPlusIO<CacheSearchRow> in method protected compare(iox BPlusIO<CacheSearchRow>, pageAddr long, idx int, row CacheSearchRow) : int in class org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.CacheDataTree |
From |
To |
|
Rename Parameter cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public initFromLink(grp CacheGroupContext, sharedCtx GridCacheSharedContext<?,?>, pageMem PageMemory, rowData RowData) : void in class org.apache.ignite.internal.processors.cache.database.CacheDataRowAdapter |
From |
To |
|
Rename Parameter cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public GridDhtPartitionDemander(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionDemander |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public partitionUpdateCounters(grpId int) : Map<Integer,T2<Long,Long>> in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsSingleMessage |
From |
To |
|
Rename Parameter cctx : GridCacheContext<?,?> to ctx : GridCacheSharedContext in method public GridDhtPartitionTopologyImpl(ctx GridCacheSharedContext, grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtPartitionTopologyImpl |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public GridClientPartitionTopology(cctx GridCacheSharedContext, grpId int, exchFut GridDhtPartitionsExchangeFuture, similarAffKey Object) in class org.apache.ignite.internal.processors.cache.distributed.dht.GridClientPartitionTopology |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public partitionUpdateCounters(grpId int, cntrMap Map<Integer,T2<Long,Long>>) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsSingleMessage |
From |
To |
|
Rename Parameter event : Event to evt : Event in method private gridIdx(evt Event) : int in class org.apache.ignite.internal.processors.cache.GridCacheOrderedPreloadingSelfTest |
From |
To |
|
Rename Parameter cacheId : int to grpId : int in method public abstract partitionUpdateCounters(grpId int) : Map<Integer,T2<Long,Long>> in class org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsAbstractMessage |
From |
To |
|
Rename Parameter cctx : GridCacheContext<?,?> to grp : CacheGroupContext in method public GridCachePreloaderAdapter(grp CacheGroupContext) in class org.apache.ignite.internal.processors.cache.GridCachePreloaderAdapter |
From |
To |
|
Rename Parameter ctx : GridCacheContext to cctx : GridCacheContext in method public GridCacheLocalConcurrentMap(cctx GridCacheContext, factory GridCacheMapEntryFactory, initCap int) in class org.apache.ignite.internal.processors.cache.GridCacheLocalConcurrentMap |
From |
To |
|
Rename Parameter initialCapacity : int to initCap : int in method public GridCacheLocalConcurrentMap(cctx GridCacheContext, factory GridCacheMapEntryFactory, initCap int) in class org.apache.ignite.internal.processors.cache.GridCacheLocalConcurrentMap |
From |
To |
|
Rename Parameter partition : int to part : int in method public localSizeLong(part int, peekModes CachePeekMode[]) : long in class org.apache.ignite.internal.processors.cache.distributed.GridDistributedCacheAdapter |
From |
To |
|
Rename Parameter cacheId : int to hndId : int in method private ListenerKey(hndId int, msgCls Class<? extends GridCacheMessage>) in class org.apache.ignite.internal.processors.cache.GridCacheIoManager.ListenerKey |
From |
To |
|
Rename Parameter cctx : GridCacheContext to grp : CacheGroupContext in method package onCacheGroupCreated(grp CacheGroupContext) : void in class org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager |
From |
To |