|
Change Parameter Type groupManager : GroupManager to distributionManager : DistributionManager in method public init(stateTransferLock StateTransferLock, configuration Configuration, stateTransferManager StateTransferManager, distributionManager DistributionManager, timeoutExecutor ScheduledExecutorService, remoteExecutor Executor) : void in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor |
From |
To |
|
Change Parameter Type ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private sendToBackups(command PutMapCommand, entries Map<Object,Object>, cacheTopology LocalizedCacheTopology) : void in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor |
From |
To |
|
Change Parameter Type cacheManager : EmbeddedCacheManager to transport : Transport in method public init(transport Transport) : void in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic |
From |
To |
|
Change Parameter Type consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private BackupOwnerClassifier(cacheTopology LocalizedCacheTopology, entryCount int) in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor.BackupOwnerClassifier |
From |
To |
|
Change Parameter Type clusteringDependentLogic : ClusteringDependentLogic to distributionManager : DistributionManager in method public injectDependencies(distributionManager DistributionManager) : void in class org.infinispan.distribution.group.impl.GroupManagerImpl |
From |
To |
|
Change Parameter Type consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private PrimaryOwnerClassifier(cacheTopology LocalizedCacheTopology, entryCount int) in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor.PrimaryOwnerClassifier |
From |
To |
|
Change Parameter Type ch : ConsistentHash to keyPartitioner : KeyPartitioner in method private findMismatchedSegments(keyPartitioner KeyPartitioner, masterValues Map<Integer,Integer>, seenValues Map<Integer,Integer>, iteration int) : void in class org.infinispan.stream.stress.DistributedStreamRehashStressTest |
From |
To |
|
Change Parameter Type hash : ConsistentHash to keyPartitioner : KeyPartitioner in method private generateEntriesPerSegment(keyPartitioner KeyPartitioner, entries Iterable<Map.Entry<K,V>>) : Map<Integer,Set<Map.Entry<K,V>>> in class org.infinispan.stream.stress.DistributedStreamRehashStressTest |
From |
To |
|
Change Parameter Type consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private checkRemoteGetIfNeeded(ctx InvocationContext, command C, keys Set<Object>, cacheTopology LocalizedCacheTopology, needsPreviousValue boolean) : CompletableFuture<?> in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor |
From |
To |
|
Change Parameter Type ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private getHashCodeForSegment(cacheTopology LocalizedCacheTopology, segment int) : int in class org.infinispan.distribution.MagicKey |
From |
To |
|
Change Parameter Type hash : ConsistentHash to keyPartitioner : KeyPartitioner in method private generateEntriesPerSegment(keyPartitioner KeyPartitioner, entries Iterable<Map.Entry<Object,String>>) : Map<Integer,Set<Map.Entry<Object,String>>> in class org.infinispan.stream.DistributedStreamIteratorTest |
From |
To |
|
Change Parameter Type rpcManager : RpcManager to transport : Transport in method public init(transport Transport, configuration Configuration, keyPartitioner KeyPartitioner) : void in class org.infinispan.distribution.impl.DistributionManagerImpl |
From |
To |
|
Change Parameter Type members : List<Address> to members : Collection<Address> in method private filterMembers(policy DistributedTaskExecutionPolicy, members Collection<Address>) : List<Address> in class org.infinispan.distexec.DefaultExecutorService |
From |
To |
|
Change Parameter Type hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private findKeyBasedOnOwnership(keyPrefix String, cacheTopology LocalizedCacheTopology, shouldBePrimaryOwner boolean) : String in class org.infinispan.notifications.cachelistener.CacheNotifierImplInitialTransferDistTest |
From |
To |
|
Change Parameter Type ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private getKeysByOwner(ctx InvocationContext, keys Collection<?>, cacheTopology LocalizedCacheTopology, availableKeys List<Object>) : Map<Address,List<Object>> in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Parameter Type readCh : ConsistentHash to keyPartitioner : KeyPartitioner in method public OutboundTransferTask(destination Address, segments Set<Integer>, chunkSize int, topologyId int, keyPartitioner KeyPartitioner, stateProvider StateProviderImpl, dataContainer DataContainer, persistenceManager PersistenceManager, rpcManager RpcManager, commandsFactory CommandsFactory, ef InternalEntryFactory, timeout long, cacheName String) in class org.infinispan.statetransfer.OutboundTransferTask |
From |
To |
|
Change Variable Type hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method public testConsistency() : void in class org.infinispan.distribution.rehash.ConsistencyStressTest |
From |
To |
|
Change Variable Type hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method public testCollocatedKey() : void in class org.infinispan.affinity.impl.KeyAffinityServiceTest |
From |
To |
|
Change Variable Type consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method public testFilteredIteration() : void in class org.infinispan.client.hotrod.impl.iteration.ProtobufRemoteIteratorTest |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method protected remoteGet(ctx InvocationContext, command C, key Object, isWrite boolean) : CompletableFuture<Void> in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Variable Type readCh : ConsistentHash to keyPartitioner : KeyPartitioner in method private collectTransactionsToTransfer(destination Address, transactionsToTransfer List<TransactionInfo>, transactions Collection<? extends CacheTransaction>, segments Set<Integer>, cacheTopology CacheTopology) : void in class org.infinispan.statetransfer.StateProviderImpl |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method public visitGetAllCommand(ctx InvocationContext, command GetAllCommand) : Object in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Variable Type hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method protected assertMapsToAddress(o Object, addr Address) : void in class org.infinispan.affinity.impl.BaseKeyAffinityServiceTest |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method public visitReadOnlyKeyCommand(ctx InvocationContext, command ReadOnlyKeyCommand) : Object in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Variable Type consistentHash : ConsistentHash to keyPartitioner : KeyPartitioner in method public testFilterBySegment() : void in class org.infinispan.client.hotrod.impl.iteration.BaseMultiServerRemoteIteratorTest |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method protected checkTopologyId(command TopologyAffectedCommand) : LocalizedCacheTopology in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method private handleLocalPutMapCommand(ctx InvocationContext, command PutMapCommand) : Object in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor |
From |
To |
|
Change Variable Type serverCH : ConsistentHash to serverTopology : LocalizedCacheTopology in method private runTest(cacheIndex int) : void in class org.infinispan.client.hotrod.ConsistentHashV2IntegrationTest |
From |
To |
|
Change Variable Type dummy : Integer to dummy : int in method private getHashCodeForSegment(cacheTopology LocalizedCacheTopology, segment int) : int in class org.infinispan.distribution.MagicKey |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method protected handleFunctionalReadManyCommand(ctx InvocationContext, command C, helper ReadManyCommandHelper<C>) : Object in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method private primaryReturnHandler(ctx InvocationContext, visitableCommand VisitableCommand, localResult Object) : Object in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Variable Type consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private testLockMigration(nodeThatPuts int, commit boolean) : void in class org.infinispan.lock.singlelock.MainOwnerChangesPessimisticLockTest |
From |
To |
|
Change Variable Type ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private testLockMigration(nodeThatPuts int) : void in class org.infinispan.lock.singlelock.MainOwnerChangesLockTest |
From |
To |
|
Change Variable Type removedSegments : Set<Integer> to removedSegments : SmallIntSet in method public onTopologyUpdate(cacheTopology CacheTopology, isRebalance boolean) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method private handleRemotePutMapCommand(ctx InvocationContext, command PutMapCommand) : Object in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor |
From |
To |
|
Change Variable Type hash : ConsistentHash to keyPartitioner : KeyPartitioner in method public testNodeLeavesWhileIteratingOverContainerCausingRehashToLoseValues() : void in class org.infinispan.stream.DistributedStreamIteratorTest |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method private doTest(operation Operation, init boolean) : void in class org.infinispan.distribution.rehash.WriteOperationDuringLeaverTest |
From |
To |
|
Change Variable Type dm : DistributionManager to keyPartitioner : KeyPartitioner in method public testKeySegmentFilter() : void in class org.infinispan.stream.BaseStreamTest |
From |
To |
|
Change Variable Type ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method public testAffinityPartitioner() : void in class org.infinispan.distribution.ch.AffinityPartitionerTest |
From |
To |
|
Change Variable Type newTargets : Set<Address> to newTargets : Collection<Address> in method public forwardCommandIfNeeded(command TopologyAffectedCommand, affectedKeys Set<Object>, origin Address) : Map<Address,Response> in class org.infinispan.statetransfer.StateTransferManagerImpl |
From |
To |
|
Change Variable Type hash : ConsistentHash to keyPartitioner : KeyPartitioner in method public waitUntilProcessingResults() : void in class org.infinispan.stream.DistributedStreamIteratorTest |
From |
To |
|
Change Variable Type hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private assertExistence(key K) : void in class org.infinispan.distribution.topologyaware.TopologyAwareStateTransferTest |
From |
To |
|
Change Variable Type topology : CacheTopology to topology : LocalizedCacheTopology in method private handleDataWriteCommand(context InvocationContext, command AbstractDataWriteCommand) : Object in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor |
From |
To |
|
Change Variable Type cacheTopology : CacheTopology to cacheTopology : LocalizedCacheTopology in method public handleTxFunctionalCommand(ctx InvocationContext, command C) : Object in class org.infinispan.interceptors.distribution.TxDistributionInterceptor |
From |
To |
|
Rename Variable serverCH : ConsistentHash to serverTopology : LocalizedCacheTopology in method private runTest(cacheIndex int) : void in class org.infinispan.client.hotrod.ConsistentHashV2IntegrationTest |
From |
To |
|
Rename Variable hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private assertExistence(key K) : void in class org.infinispan.distribution.topologyaware.TopologyAwareStateTransferTest |
From |
To |
|
Rename Variable hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method public testCollocatedKey() : void in class org.infinispan.affinity.impl.KeyAffinityServiceTest |
From |
To |
|
Rename Variable hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method public testConsistency() : void in class org.infinispan.distribution.rehash.ConsistencyStressTest |
From |
To |
|
Rename Variable consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method public testFilteredIteration() : void in class org.infinispan.client.hotrod.impl.iteration.ProtobufRemoteIteratorTest |
From |
To |
|
Rename Variable consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private testLockMigration(nodeThatPuts int, commit boolean) : void in class org.infinispan.lock.singlelock.MainOwnerChangesPessimisticLockTest |
From |
To |
|
Rename Variable ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private testLockMigration(nodeThatPuts int) : void in class org.infinispan.lock.singlelock.MainOwnerChangesLockTest |
From |
To |
|
Rename Variable hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method protected assertMapsToAddress(o Object, addr Address) : void in class org.infinispan.affinity.impl.BaseKeyAffinityServiceTest |
From |
To |
|
Rename Variable hash : ConsistentHash to keyPartitioner : KeyPartitioner in method public testNodeLeavesWhileIteratingOverContainerCausingRehashToLoseValues() : void in class org.infinispan.stream.DistributedStreamIteratorTest |
From |
To |
|
Rename Variable dm : DistributionManager to keyPartitioner : KeyPartitioner in method public testKeySegmentFilter() : void in class org.infinispan.stream.BaseStreamTest |
From |
To |
|
Rename Variable consistentHash : ConsistentHash to keyPartitioner : KeyPartitioner in method public testFilterBySegment() : void in class org.infinispan.client.hotrod.impl.iteration.BaseMultiServerRemoteIteratorTest |
From |
To |
|
Rename Variable ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method public testAffinityPartitioner() : void in class org.infinispan.distribution.ch.AffinityPartitionerTest |
From |
To |
|
Rename Variable hash : ConsistentHash to keyPartitioner : KeyPartitioner in method public waitUntilProcessingResults() : void in class org.infinispan.stream.DistributedStreamIteratorTest |
From |
To |
|
Rename Attribute rpcManager : RpcManager to transport : Transport in class org.infinispan.distribution.impl.DistributionManagerImpl |
From |
To |
|
Rename Attribute consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor.BackupOwnerClassifier |
From |
To |
|
Rename Attribute owners : Collection<Address> to backupOwners : Collection<Address> in class org.infinispan.util.concurrent.CommandAckCollector.SingleKeyCollector |
From |
To |
|
Rename Attribute clusteringDependentLogic : ClusteringDependentLogic to distributionManager : DistributionManager in class org.infinispan.distribution.group.impl.GroupManagerImpl |
From |
To |
|
Rename Attribute groupManager : GroupManager to keyPartitioner : KeyPartitioner in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Rename Attribute readCh : ConsistentHash to keyPartitioner : KeyPartitioner in class org.infinispan.statetransfer.OutboundTransferTask |
From |
To |
|
Rename Attribute owners : List<Address> to writeOwners : List<Address> in class org.infinispan.distribution.DistributionInfo |
From |
To |
|
Rename Attribute groupManager : GroupManager to distributionManager : DistributionManager in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor |
From |
To |
|
Rename Attribute stateTransferChunkSize : int to chunkSize : int in class org.infinispan.statetransfer.OutboundTransferTask |
From |
To |
|
Rename Attribute cdl : ClusteringDependentLogic to distributionManager : DistributionManager in class org.infinispan.interceptors.impl.ClusteredCacheLoaderInterceptor |
From |
To |
|
Rename Attribute cacheManager : EmbeddedCacheManager to localTopology : LocalizedCacheTopology in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic |
From |
To |
|
Rename Attribute consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor.PrimaryOwnerClassifier |
From |
To |
|
Change Attribute Type groupManager : GroupManager to distributionManager : DistributionManager in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor |
From |
To |
|
Change Attribute Type finishedSegments : Set<Integer> to finishedSegments : SmallIntSet in class org.infinispan.statetransfer.InboundTransferTask |
From |
To |
|
Change Attribute Type cdl : ClusteringDependentLogic to distributionManager : DistributionManager in class org.infinispan.interceptors.impl.ClusteredCacheLoaderInterceptor |
From |
To |
|
Change Attribute Type status : Set<Integer> to status : SmallIntSet in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl |
From |
To |
|
Change Attribute Type cacheManager : EmbeddedCacheManager to localTopology : LocalizedCacheTopology in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic |
From |
To |
|
Change Attribute Type consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor.PrimaryOwnerClassifier |
From |
To |
|
Change Attribute Type rpcManager : RpcManager to transport : Transport in class org.infinispan.distribution.impl.DistributionManagerImpl |
From |
To |
|
Change Attribute Type hashCodes : WeakHashMap<ConsistentHash,int[]> to hashCodes : WeakHashMap<Integer,int[]> in class org.infinispan.distribution.MagicKey |
From |
To |
|
Change Attribute Type segments : Set<Integer> to segments : SmallIntSet in class org.infinispan.statetransfer.InboundTransferTask |
From |
To |
|
Change Attribute Type consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor.BackupOwnerClassifier |
From |
To |
|
Change Attribute Type clusteringDependentLogic : ClusteringDependentLogic to distributionManager : DistributionManager in class org.infinispan.distribution.group.impl.GroupManagerImpl |
From |
To |
|
Change Attribute Type groupManager : GroupManager to keyPartitioner : KeyPartitioner in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Attribute Type readCh : ConsistentHash to keyPartitioner : KeyPartitioner in class org.infinispan.statetransfer.OutboundTransferTask |
From |
To |
|
Rename Parameter consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private BackupOwnerClassifier(cacheTopology LocalizedCacheTopology, entryCount int) in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor.BackupOwnerClassifier |
From |
To |
|
Rename Parameter consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private PrimaryOwnerClassifier(cacheTopology LocalizedCacheTopology, entryCount int) in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor.PrimaryOwnerClassifier |
From |
To |
|
Rename Parameter clusteringDependentLogic : ClusteringDependentLogic to distributionManager : DistributionManager in method public injectDependencies(distributionManager DistributionManager) : void in class org.infinispan.distribution.group.impl.GroupManagerImpl |
From |
To |
|
Rename Parameter consistentHash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private checkRemoteGetIfNeeded(ctx InvocationContext, command C, keys Set<Object>, cacheTopology LocalizedCacheTopology, needsPreviousValue boolean) : CompletableFuture<?> in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor |
From |
To |
|
Rename Parameter hash : ConsistentHash to keyPartitioner : KeyPartitioner in method private generateEntriesPerSegment(keyPartitioner KeyPartitioner, entries Iterable<Map.Entry<Object,String>>) : Map<Integer,Set<Map.Entry<Object,String>>> in class org.infinispan.stream.DistributedStreamIteratorTest |
From |
To |
|
Rename Parameter owners : Collection<Address> to backupOwners : Collection<Address> in method private SingleKeyCollector(id long, backupOwners Collection<Address>, topologyId int) in class org.infinispan.util.concurrent.CommandAckCollector.SingleKeyCollector |
From |
To |
|
Rename Parameter hash : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private findKeyBasedOnOwnership(keyPrefix String, cacheTopology LocalizedCacheTopology, shouldBePrimaryOwner boolean) : String in class org.infinispan.notifications.cachelistener.CacheNotifierImplInitialTransferDistTest |
From |
To |
|
Rename Parameter ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private getKeysByOwner(ctx InvocationContext, keys Collection<?>, cacheTopology LocalizedCacheTopology, availableKeys List<Object>) : Map<Address,List<Object>> in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Rename Parameter readCh : ConsistentHash to keyPartitioner : KeyPartitioner in method public OutboundTransferTask(destination Address, segments Set<Integer>, chunkSize int, topologyId int, keyPartitioner KeyPartitioner, stateProvider StateProviderImpl, dataContainer DataContainer, persistenceManager PersistenceManager, rpcManager RpcManager, commandsFactory CommandsFactory, ef InternalEntryFactory, timeout long, cacheName String) in class org.infinispan.statetransfer.OutboundTransferTask |
From |
To |
|
Rename Parameter ch : ConsistentHash to keyPartitioner : KeyPartitioner in method private findMismatchedSegments(keyPartitioner KeyPartitioner, masterValues Map<Integer,Integer>, seenValues Map<Integer,Integer>, iteration int) : void in class org.infinispan.stream.stress.DistributedStreamRehashStressTest |
From |
To |
|
Rename Parameter stateTransferChunkSize : int to chunkSize : int in method public OutboundTransferTask(destination Address, segments Set<Integer>, chunkSize int, topologyId int, keyPartitioner KeyPartitioner, stateProvider StateProviderImpl, dataContainer DataContainer, persistenceManager PersistenceManager, rpcManager RpcManager, commandsFactory CommandsFactory, ef InternalEntryFactory, timeout long, cacheName String) in class org.infinispan.statetransfer.OutboundTransferTask |
From |
To |
|
Rename Parameter hash : ConsistentHash to keyPartitioner : KeyPartitioner in method private generateEntriesPerSegment(keyPartitioner KeyPartitioner, entries Iterable<Map.Entry<K,V>>) : Map<Integer,Set<Map.Entry<K,V>>> in class org.infinispan.stream.stress.DistributedStreamRehashStressTest |
From |
To |
|
Rename Parameter ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private getHashCodeForSegment(cacheTopology LocalizedCacheTopology, segment int) : int in class org.infinispan.distribution.MagicKey |
From |
To |
|
Rename Parameter groupManager : GroupManager to distributionManager : DistributionManager in method public init(stateTransferLock StateTransferLock, configuration Configuration, stateTransferManager StateTransferManager, distributionManager DistributionManager, timeoutExecutor ScheduledExecutorService, remoteExecutor Executor) : void in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor |
From |
To |
|
Rename Parameter rpcManager : RpcManager to transport : Transport in method public init(transport Transport, configuration Configuration, keyPartitioner KeyPartitioner) : void in class org.infinispan.distribution.impl.DistributionManagerImpl |
From |
To |
|
Rename Parameter cacheManager : EmbeddedCacheManager to transport : Transport in method public init(transport Transport) : void in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic |
From |
To |
|
Rename Parameter ch : ConsistentHash to cacheTopology : LocalizedCacheTopology in method private sendToBackups(command PutMapCommand, entries Map<Object,Object>, cacheTopology LocalizedCacheTopology) : void in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor |
From |
To |