|
Change Parameter Type cancelledSegments : Set<Integer> to cancelledSegments : IntSet in method public cancelSegments(cancelledSegments IntSet) : void in class org.infinispan.statetransfer.OutboundTransferTask |
From |
To |
|
Change Parameter Type sources : Map<Address,Set<Integer>> to sources : Map<Address,IntSet> in method private requestTransactions(segments IntSet, sources Map<Address,IntSet>, excludedSources Set<Address>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type removedSegments : Set<Integer> to removedSegments : IntSet in method protected cancelTransfers(removedSegments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type allowedSegments : Set<Integer> to allowedSegments : IntSet in method public ReadOnlySegmentAwareCollection(set Collection<E>, ch ConsistentHash, allowedSegments IntSet) in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection |
From |
To |
|
Change Parameter Type cancelledSegments : Set<Integer> to cancelledSegments : IntSet in method public cancelSegments(cancelledSegments IntSet) : void in class org.infinispan.statetransfer.InboundTransferTask |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForPrimary(cmd WriteOnlyManyEntriesCommand, ch ConsistentHash, segments IntSet) : WriteOnlyManyEntriesCommand in class org.infinispan.interceptors.distribution.WriteOnlyManyEntriesHelper |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public StreamRequestCommand(cacheName ByteString, origin Address, id Object, parallelStream boolean, type Type, segments IntSet, keys Set<K>, excludedKeys Set<K>, includeLoader boolean, entryStream boolean, terminalOperation Object) in class org.infinispan.stream.impl.StreamRequestCommand |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public streamOperationRehashAware(requestId Object, origin Address, parallelStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,?>) : void in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private requestKeyTransfer(segments IntSet) : void in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForPrimary(cmd PutMapCommand, ch ConsistentHash, segments IntSet) : PutMapCommand in class org.infinispan.interceptors.distribution.PutMapHelper |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method package SegmentListener(segments IntSet, op SegmentAwareOperation) in class org.infinispan.stream.impl.LocalStreamManagerImpl.SegmentListener |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>, callback ResultsCallback<R>, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.tx.TxClusterStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public buildStateRequestCommand(subtype StateRequestCommand.Type, sender Address, topologyId int, segments IntSet) : StateRequestCommand in class org.infinispan.commands.CommandsFactoryImpl |
From |
To |
|
Change Parameter Type lostSegments : Set<Integer> to lostSegments : IntSet in method public buildStreamResponseCommand(identifier Object, complete boolean, lostSegments IntSet, response R) : StreamResponseCommand<R> in class org.infinispan.commands.CommandsFactory |
From |
To |
|
Change Parameter Type allowedSegments : Set<Integer> to allowedSegments : IntSet in method public ReadOnlySegmentAwareEntryIterator(iter Iterator<Entry<K,V>>, ch ConsistentHash, allowedSegments IntSet) in class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryIterator |
From |
To |
|
Change Parameter Type targets : Map<Address,Set<Integer>> to targets : Map<Address,IntSet> in method private submitAsyncTasks(id String, targets Map<Address,IntSet>, keysToExclude Map<Integer,Set<K>>, parallelStream boolean, keysToInclude Set<K>, includeLoader boolean, entryStream boolean, type StreamRequestCommand.Type, operation Object) : void in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public streamOperationRehashAware(requestId Object, origin Address, parallelStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,?>) : void in class org.infinispan.stream.impl.LocalStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private backupOwnersOfSegments(ch ConsistentHash, segments IntSet) : Map<Address,IntSet> in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForPrimary(cmd WriteOnlyManyCommand, ch ConsistentHash, segments IntSet) : WriteOnlyManyCommand in class org.infinispan.interceptors.distribution.WriteOnlyManyHelper |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private getTransactions(source Address, segments IntSet, topologyId int) : Response in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public buildStreamRequestCommand(id Object, parallelStream boolean, type StreamRequestCommand.Type, segments IntSet, keys Set<K>, excludedKeys Set<K>, includeLoader boolean, entryStream boolean, terminalOperation Object) : StreamRequestCommand<K> in class org.infinispan.commands.CommandsFactory |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private collectTransactionsToTransfer(destination Address, transactionsToTransfer List<TransactionInfo>, transactions Collection<? extends CacheTransaction>, segments IntSet, cacheTopology CacheTopology) : void in class org.infinispan.statetransfer.StateProviderImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private findSources(segments IntSet, sources Map<Address,IntSet>, excludedSources Set<Address>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type missedSegments : Set<Integer> to missedSegments : IntSet in method public StreamSegmentResponseCommand(cacheName ByteString, origin Address, id Object, complete boolean, response R, missedSegments IntSet) in class org.infinispan.stream.impl.StreamSegmentResponseCommand |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public buildStreamRequestCommand(id Object, parallelStream boolean, type StreamRequestCommand.Type, segments IntSet, keys Set<K>, excludedKeys Set<K>, includeLoader boolean, entryStream boolean, terminalOperation Object) : StreamRequestCommand<K> in class org.infinispan.commands.CommandsFactoryImpl |
From |
To |
|
Change Parameter Type completedSegments : Set<Integer> to completedSegments : IntSet in method public onCompletion(address Address, completedSegments IntSet, results R) : void in class org.infinispan.stream.impl.AbstractCacheStream.ResultsAccumulator |
From |
To |
|
Change Parameter Type status : Set<Integer> to status : IntSet in method public InDoubtTxInfoImpl(xid Xid, internalId long, status IntSet) in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public buildStateRequestCommand(subtype StateRequestCommand.Type, sender Address, topologyId int, segments IntSet) : StateRequestCommand in class org.infinispan.util.mocks.ControlledCommandFactory |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,R>, callback ResultsCallback<Collection<R>>) : Object in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : Supplier<PrimitiveIterator.OfInt> in method public accept(segments Supplier<PrimitiveIterator.OfInt>) : void in class org.infinispan.notifications.cachelistener.DistributedQueueingSegmentListener |
From |
To |
|
Change Parameter Type sources : Map<Address,Set<Integer>> to sources : Map<Address,IntSet> in method private findSources(segments IntSet, sources Map<Address,IntSet>, excludedSources Set<Address>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type completedSegments : Set<Integer> to completedSegments : IntSet in method public onCompletion(address Address, completedSegments IntSet, results R) : void in class org.infinispan.stream.impl.ClusterStreamManager.ResultsCallback |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public streamOperation(requestId Object, origin Address, parallelStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,R>) : void in class org.infinispan.stream.impl.LocalStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public OutboundTransferTask(destination Address, segments IntSet, segmentCount int, chunkSize int, topologyId int, keyPartitioner KeyPartitioner, onCompletion Consumer<OutboundTransferTask>, onChunkReplicated Consumer<List<StateChunk>>, mapEntryFromDataContainer BiFunction<InternalCacheEntry,InternalEntryFactory,InternalCacheEntry>, mapEntryFromStore BiFunction<MarshalledEntry,InternalEntryFactory,InternalCacheEntry>, dataContainer InternalDataContainer, persistenceManager PersistenceManager, rpcManager RpcManager, commandsFactory CommandsFactory, ef InternalEntryFactory, timeout long, cacheName String, applyState boolean, pushTransfer boolean) in class org.infinispan.statetransfer.OutboundTransferTask |
From |
To |
|
Change Parameter Type allowedSegments : Set<Integer> to allowedSegments : IntSet in method public ReadOnlySegmentAwareEntryCollection(set Set<Entry<K,V>>, ch ConsistentHash, allowedSegments IntSet) in class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryCollection |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>, callback ResultsCallback<R>, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager |
From |
To |
|
Change Parameter Type addedSegments : Set<Integer> to addedSegments : IntSet in method protected handleSegments(startRebalance boolean, addedSegments IntSet, removedSegments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,?>, callback ResultsCallback<Collection<K>>) : Object in class org.infinispan.stream.impl.tx.TxClusterStreamManager |
From |
To |
|
Change Parameter Type lostSegments : Set<Integer> to lostSegments : IntSet in method public buildStreamResponseCommand(identifier Object, complete boolean, lostSegments IntSet, response R) : StreamResponseCommand<R> in class org.infinispan.commands.CommandsFactoryImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public InboundTransferTask(segments IntSet, source Address, topologyId int, rpcManager RpcManager, commandsFactory CommandsFactory, timeout long, cacheName String, applyState boolean) in class org.infinispan.statetransfer.InboundTransferTask |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>, callback ResultsCallback<R>, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.tx.TxClusterStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method protected addTransfer(inboundTransfer InboundTransferTask, segments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public startOutboundTransfer(destination Address, topologyId int, segments IntSet, applyState boolean) : void in class org.infinispan.statetransfer.StateProvider |
From |
To |
|
Change Parameter Type removedSegments : Set<Integer> to removedSegments : IntSet in method protected handleSegments(startRebalance boolean, addedSegments IntSet, removedSegments IntSet) : void in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public buildStreamRequestCommand(id Object, parallelStream boolean, type StreamRequestCommand.Type, segments IntSet, keys Set<K>, excludedKeys Set<K>, includeLoader boolean, entryStream boolean, terminalOperation Object) : StreamRequestCommand<K> in class org.infinispan.util.mocks.ControlledCommandFactory |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private createLocalInvocationHandler(ch ConsistentHash, allFuture F, segments IntSet, helper WriteManyCommandHelper<C,?,Item>, returnValueConsumer BiConsumer<F,Object>) : InvocationFinallyAction in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>, callback ResultsCallback<R>, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Parameter Type staleL1Segments : Set<Integer> to staleL1Segments : IntSet in method public beforeInvalidation(removedSegments IntSet, staleL1Segments IntSet) : void in class org.infinispan.statetransfer.ReadAfterLosingOwnershipTest.Listener |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>, callback ResultsCallback<R>, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager |
From |
To |
|
Change Parameter Type staleL1Segments : Set<Integer> to staleL1Segments : IntSet in method public beforeInvalidation(removedSegments IntSet, staleL1Segments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl.KeyInvalidationListener |
From |
To |
|
Change Parameter Type addedSegments : Set<Integer> to addedSegments : IntSet in method protected handleSegments(startRebalance boolean, addedSegments IntSet, removedSegments IntSet) : void in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public receiveResponse(id Object, origin Address, complete boolean, segments IntSet, response R1) : boolean in class org.infinispan.stream.impl.tx.TxClusterStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public streamOperation(requestId Object, origin Address, parallelStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>) : void in class org.infinispan.stream.impl.LocalStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public getTransactionsForSegments(destination Address, requestTopologyId int, segments IntSet) : List<TransactionInfo> in class org.infinispan.statetransfer.StateProviderImpl |
From |
To |
|
Change Parameter Type removedSegments : Set<Integer> to removedSegments : IntSet in method protected handleSegments(startRebalance boolean, addedSegments IntSet, removedSegments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private requestTransactions(segments IntSet, sources Map<Address,IntSet>, excludedSources Set<Address>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segmentsFromSource : Set<Integer> to segmentsFromSource : IntSet in method private addTransfer(source Address, segmentsFromSource IntSet) : InboundTransferTask in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private commonRemoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation SegmentAwareOperation, callback ResultsCallback<R>, type StreamRequestCommand.Type, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForBackup(cmd ReadWriteManyEntriesCommand, ch ConsistentHash, segments IntSet) : ReadWriteManyEntriesCommand in class org.infinispan.interceptors.distribution.ReadWriteManyEntriesHelper |
From |
To |
|
Change Parameter Type mySegments : Set<Integer> to mySegments : IntSet in method private applyChunk(sender Address, mySegments IntSet, stateChunk StateChunk) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private addTransfers(segments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,?>, callback ResultsCallback<Collection<K>>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private filterAndWrap(ctx InvocationContext, command C, segments IntSet, helper WriteManyCommandHelper<C,Container,Item>) : Container in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForBackup(cmd ReadWriteManyCommand, ch ConsistentHash, segments IntSet) : ReadWriteManyCommand in class org.infinispan.interceptors.distribution.ReadWriteManyHelper |
From |
To |
|
Change Parameter Type removedSegments : Set<Integer> to removedSegments : IntSet in method public beforeInvalidation(removedSegments IntSet, staleL1Segments IntSet) : void in class org.infinispan.statetransfer.ReadAfterLosingOwnershipTest.Listener |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public streamOperation(requestId Object, origin Address, parallelStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>) : void in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public startKeyTransfer(segments IntSet) : void in class org.infinispan.scattered.ScatteredVersionManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,?>, callback ResultsCallback<Collection<K>>) : Object in class org.infinispan.stream.impl.ClusterStreamManager |
From |
To |
|
Change Parameter Type removedSegments : Set<Integer> to removedSegments : IntSet in method public beforeInvalidation(removedSegments IntSet, staleL1Segments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl.KeyInvalidationListener |
From |
To |
|
Change Parameter Type addedSegments : Set<Integer> to addedSegments : IntSet in method private restartBrokenTransfers(cacheTopology CacheTopology, addedSegments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public cancelOutboundTransfer(destination Address, topologyId int, segments IntSet) : void in class org.infinispan.statetransfer.StateProviderImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public streamOperationRehashAware(requestId Object, origin Address, parallelStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>) : void in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,R>, callback ResultsCallback<Collection<R>>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public startKeysTransfer(segments IntSet, origin Address) : void in class org.infinispan.scattered.ScatteredStateProvider |
From |
To |
|
Change Parameter Type cancelledSegments : Set<Integer> to cancelledSegments : IntSet in method private sendCancelCommand(cancelledSegments IntSet) : void in class org.infinispan.statetransfer.InboundTransferTask |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private handleLocalSegmentsForReadWriteManyCommand(ctx InvocationContext, command C, helper WriteManyCommandHelper<C,Container,Item>, ch ConsistentHash, allFuture MergingCompletableFuture<Object>, offset MutableInt, segments IntSet) : void in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public missingSegments(segments IntSet) : void in class org.infinispan.stream.impl.ClusterStreamManagerImpl.RequestTracker |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>, callback ResultsCallback<R>, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.ClusterStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public streamOperation(requestId Object, origin Address, parallelStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,R>) : void in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Parameter Type sources : Map<Address,Set<Integer>> to sources : Map<Address,IntSet> in method private requestSegments(segments IntSet, sources Map<Address,IntSet>, excludedSources Set<Address>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public revokeLocalBiasForSegments(segments IntSet) : void in class org.infinispan.scattered.BiasManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public startKeysTransfer(segments IntSet, origin Address) : void in class org.infinispan.scattered.impl.ScatteredStateProviderImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForBackup(cmd WriteOnlyManyEntriesCommand, ch ConsistentHash, segments IntSet) : WriteOnlyManyEntriesCommand in class org.infinispan.interceptors.distribution.WriteOnlyManyEntriesHelper |
From |
To |
|
Change Parameter Type lostSegments : Set<Integer> to lostSegments : IntSet in method public lostSegments(lostSegments IntSet) : void in class org.infinispan.stream.impl.LocalStreamManagerImpl.SegmentListener |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public revokeLocalBiasForSegments(segments IntSet) : void in class org.infinispan.scattered.impl.BiasManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public startKeyTransfer(segments IntSet) : void in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForBackup(cmd WriteOnlyManyCommand, ch ConsistentHash, segments IntSet) : WriteOnlyManyCommand in class org.infinispan.interceptors.distribution.WriteOnlyManyHelper |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForPrimary(cmd ReadWriteManyEntriesCommand, ch ConsistentHash, segments IntSet) : ReadWriteManyEntriesCommand in class org.infinispan.interceptors.distribution.ReadWriteManyEntriesHelper |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public setOwnedSegments(segments IntSet) : void in class org.infinispan.scattered.ScatteredVersionManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public cancelOutboundTransfer(destination Address, topologyId int, segments IntSet) : void in class org.infinispan.statetransfer.StateProvider |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,R>, callback ResultsCallback<Collection<R>>) : Object in class org.infinispan.stream.impl.tx.TxClusterStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public getTransactionsForSegments(destination Address, topologyId int, segments IntSet) : List<TransactionInfo> in class org.infinispan.statetransfer.StateProvider |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForBackup(cmd PutMapCommand, ch ConsistentHash, segments IntSet) : PutMapCommand in class org.infinispan.interceptors.distribution.PutMapHelper |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public StateRequestCommand(cacheName ByteString, type Type, origin Address, topologyId int, segments IntSet) in class org.infinispan.statetransfer.StateRequestCommand |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private handleSegmentsForWriteOnlyManyCommand(ctx InvocationContext, command C, helper WriteManyCommandHelper<C,Container,Item>, ch ConsistentHash, allFuture CountDownCompletableFuture, member Address, segments IntSet) : void in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>, callback ResultsCallback<R>, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.ClusterStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public startOutboundTransfer(destination Address, requestTopologyId int, segments IntSet, applyState boolean) : void in class org.infinispan.statetransfer.StateProviderImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private getRehashStream(cacheEntrySet CacheSet<Original>, requestId Object, listener SegmentListener, parallelStream boolean, entryStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>) : Stream<Original> in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Parameter Type lostSegments : Set<Integer> to lostSegments : IntSet in method public buildStreamResponseCommand(identifier Object, complete boolean, lostSegments IntSet, response R) : StreamResponseCommand<R> in class org.infinispan.util.mocks.ControlledCommandFactory |
From |
To |
|
Change Parameter Type completedSegments : Set<Integer> to completedSegments : IntSet in method public onCompletion(address Address, completedSegments IntSet, results Collection<K>) : void in class org.infinispan.stream.impl.AbstractCacheStream.KeyTrackingConsumer |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private getStream(cacheEntrySet CacheSet<Original>, parallelStream boolean, entryStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>) : Stream<Original> in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public setOwnedSegments(segments IntSet) : void in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private requestSegments(segments IntSet, sources Map<Address,IntSet>, excludedSources Set<Address>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,R>, callback ResultsCallback<Collection<R>>) : Object in class org.infinispan.stream.impl.ClusterStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public receiveResponse(id Object, origin Address, complete boolean, segments IntSet, response R1) : boolean in class org.infinispan.stream.impl.ClusterStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public copyForPrimary(cmd ReadWriteManyCommand, ch ConsistentHash, segments IntSet) : ReadWriteManyCommand in class org.infinispan.interceptors.distribution.ReadWriteManyHelper |
From |
To |
|
Change Parameter Type awaitingResponse : Map<Address,Set<Integer>> to awaitingResponse : Map<Address,IntSet> in method package RequestTracker(callback ResultsCallback<R>, awaitingResponse Map<Address,IntSet>, earlyTerminatePredicate Predicate<? super R>) in class org.infinispan.stream.impl.ClusterStreamManagerImpl.RequestTracker |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>, callback ResultsCallback<R>, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public streamOperationRehashAware(requestId Object, origin Address, parallelStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>, includeLoader boolean, entryStream boolean, operation TerminalOperation<Original,R>) : void in class org.infinispan.stream.impl.LocalStreamManager |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public buildStateRequestCommand(subtype StateRequestCommand.Type, sender Address, topologyId int, segments IntSet) : StateRequestCommand in class org.infinispan.commands.CommandsFactory |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,?>, callback ResultsCallback<Collection<K>>) : Object in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager |
From |
To |
|
Change Parameter Type allowedSegments : Set<Integer> to allowedSegments : IntSet in method public ReadOnlySegmentAwareIterator(iter Iterator<E>, ch ConsistentHash, allowedSegments IntSet) in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator |
From |
To |
|
Change Parameter Type segments : Set<Integer> to segments : IntSet in method private handleRemoteSegmentsForReadWriteManyCommand(command C, helper WriteManyCommandHelper<C,?,Item>, ch ConsistentHash, allFuture MergingCompletableFuture<Object>, offset MutableInt, member Address, segments IntSet) : void in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Parameter Type allowedSegments : Set<Integer> to allowedSegments : IntSet in method public ReadOnlySegmentAwareMap(map Map<K,V>, ch ConsistentHash, allowedSegments IntSet) in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap |
From |
To |
|
Change Parameter Type suspectedSegments : Set<Integer> to suspectedSegments : IntSet in method package LastResponse(spliterator Spliterator<Object>, suspectedSegments IntSet) in class org.infinispan.stream.impl.IteratorResponses.LastResponse |
From |
To |
|
Change Parameter Type suspectedSegments : Set<Integer> to suspectedSegments : IntSet in method package RemoteResponse(iterator Iterator<Object>, suspectedSegments IntSet, batchSize long) in class org.infinispan.stream.impl.IteratorResponses.RemoteResponse |
From |
To |
|
Change Parameter Type missingSegments : Set<Integer> to missingSegments : IntSet in method public receiveResponse(id Object, origin Address, complete boolean, missingSegments IntSet, response R1) : boolean in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Variable Type ownedSegments : Set<Integer> to ownedSegments : IntSet in method package nonRehashRemoteIterator(ch ConsistentHash, segmentsToFilter IntSet, keysToExclude IntFunction<Set<Object>>, publisherFunction PublisherDecorator<S>, intermediateOperations Iterable<IntermediateOperation>) : CloseableIterator<S> in class org.infinispan.stream.impl.DistributedCacheStream |
From |
To |
|
Change Variable Type addedSegments : Set<Integer> to addedSegments : IntSet in method public onTopologyUpdate(cacheTopology CacheTopology, isRebalance boolean) : CompletableFuture<Void> in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type ourSegments : Set<Integer> to ourSegments : IntSet in method private getRehashStream(cacheEntrySet CacheSet<Original>, requestId Object, listener SegmentListener, parallelStream boolean, entryStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>) : Stream<Original> in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Variable Type metadata : Metadata to metadata : InternalMetadata in method public startKeysTransfer(segments IntSet, origin Address) : void in class org.infinispan.scattered.impl.ScatteredStateProviderImpl |
From |
To |
|
Change Variable Type pair : Entry<Address,Set<Integer>> to pair : Entry<Address,IntSet> in method private handleReadWriteManyCommand(ctx InvocationContext, command C, helper WriteManyCommandHelper<C,Item,Container>) : Object in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type lostSegments : Set<Integer> to lostSegments : IntSet in method private sendRequest(batchAmount long) : void in class org.infinispan.stream.impl.ClusterStreamManagerImpl.ClusterStreamSubscription |
From |
To |
|
Change Variable Type finalCompletedSegments : Set<Integer> to finalCompletedSegments : IntSet in method protected onTaskCompletion(inboundTransfer InboundTransferTask) : void in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl |
From |
To |
|
Change Variable Type targets : Map<Address,Set<Integer>> to targets : Map<Address,IntSet> in method private commonRemoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation SegmentAwareOperation, callback ResultsCallback<R>, type StreamRequestCommand.Type, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Variable Type segmentsCopy : Set<Integer> to segmentsCopy : IntSet in method public cancel() : void in class org.infinispan.statetransfer.InboundTransferTask |
From |
To |
|
Change Variable Type unfinishedSegments : SmallIntSet to unfinishedSegments : IntSet in method private restartBrokenTransfers(cacheTopology CacheTopology, addedSegments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type mySegments : Set<Integer> to mySegments : IntSet in method public applyState(sender Address, topologyId int, pushTransfer boolean, stateChunks Collection<StateChunk>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type addedSegments : Set<Integer> to addedSegments : IntSet in method protected beforeTopologyInstalled(topologyId int, startRebalance boolean, previousWriteCh ConsistentHash, newWriteCh ConsistentHash) : void in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl |
From |
To |
|
Change Variable Type segments : Set<Integer> to segments : IntSet in method package performRehashKeyTrackingOperation(function Function<Supplier<Stream<Original>>,KeyTrackingTerminalOperation<Original,Object,? extends T>>) : void in class org.infinispan.stream.impl.AbstractCacheStream |
From |
To |
|
Change Variable Type segments : Set<Integer> to segments : IntSet in method private submitAsyncTasks(id String, targets Map<Address,IntSet>, keysToExclude Map<Integer,Set<K>>, parallelStream boolean, keysToInclude Set<K>, includeLoader boolean, entryStream boolean, type StreamRequestCommand.Type, operation Object) : void in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Variable Type map : Map<Address,Set<Integer>> to map : Map<Address,IntSet> in method private primaryOwnersOfSegments(ch ConsistentHash) : Map<Address,IntSet> in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type backup : Entry<Address,Set<Integer>> to backup : Entry<Address,IntSet> in method private writeManyRemoteCallback(helper WriteManyCommandHelper<C,?,?>, ctx InvocationContext, command C, rv Object) : Object in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type segments : Set<Integer> to segments : IntSet in method private handleReadWriteManyCommand(ctx InvocationContext, command C, helper WriteManyCommandHelper<C,Item,Container>) : Object in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type targets : Map<Address,Set<Integer>> to targets : Map<Address,IntSet> in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,?>, callback ResultsCallback<Collection<K>>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Variable Type previousSegments : Set<Integer> to previousSegments : IntSet in method public onTopologyUpdate(cacheTopology CacheTopology, isRebalance boolean) : CompletableFuture<Void> in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type completedSegments : Set<Integer> to completedSegments : IntSet in method public lastResult(origin Address, result R) : boolean in class org.infinispan.stream.impl.ClusterStreamManagerImpl.RequestTracker |
From |
To |
|
Change Variable Type metadata : InternalMetadata to metadata : Metadata in method public startKeysTransfer(segments IntSet, origin Address) : void in class org.infinispan.scattered.impl.ScatteredStateProviderImpl |
From |
To |
|
Change Variable Type targetInfo : Map.Entry<Address,Set<Integer>> to targetInfo : Map.Entry<Address,IntSet> in method private commonRemoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation SegmentAwareOperation, callback ResultsCallback<R>, type StreamRequestCommand.Type, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Variable Type ownedSegments : Set<Integer> to ownedSegments : IntSet in method public getTransactionsForSegments(destination Address, requestTopologyId int, segments IntSet) : List<TransactionInfo> in class org.infinispan.statetransfer.StateProviderImpl |
From |
To |
|
Change Variable Type segmentMap : Map<Address,Set<Integer>> to segmentMap : Map<Address,IntSet> in method private handleWriteOnlyManyCommand(ctx InvocationContext, command C, helper WriteManyCommandHelper<C,Container,Item>) : Object in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type targetSegments : Set<Integer> to targetSegments : IntSet in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,?>, callback ResultsCallback<Collection<K>>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Variable Type segmentsFromSource : Set<Integer> to segmentsFromSource : IntSet in method private requestTransactions(segments IntSet, sources Map<Address,IntSet>, excludedSources Set<Address>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type segmentsCopy : Set<Integer> to segmentsCopy : IntSet in method private startTransfer(type StateRequestCommand.Type) : CompletableFuture<Void> in class org.infinispan.statetransfer.InboundTransferTask |
From |
To |
|
Change Variable Type sources : Map<Address,Set<Integer>> to sources : Map<Address,IntSet> in method private addTransfers(segments IntSet) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type targetSegments : Set<Integer> to targetSegments : IntSet in method private commonRemoteStreamOperation(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation SegmentAwareOperation, callback ResultsCallback<R>, type StreamRequestCommand.Type, earlyTerminatePredicate Predicate<? super R>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Variable Type targetInfo : Map.Entry<Address,Set<Integer>> to targetInfo : Map.Entry<Address,IntSet> in method private submitAsyncTasks(id String, targets Map<Address,IntSet>, keysToExclude Map<Integer,Set<K>>, parallelStream boolean, keysToInclude Set<K>, includeLoader boolean, entryStream boolean, type StreamRequestCommand.Type, operation Object) : void in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Variable Type targetInfo : Map.Entry<Address,Set<Integer>> to targetInfo : Map.Entry<Address,IntSet> in method public remoteStreamOperationRehashAware(parallelDistribution boolean, parallelStream boolean, ch ConsistentHash, segments IntSet, keysToInclude Set<K>, keysToExclude Map<Integer,Set<K>>, includeLoader boolean, entryStream boolean, operation KeyTrackingTerminalOperation<Original,K,?>, callback ResultsCallback<Collection<K>>) : Object in class org.infinispan.stream.impl.ClusterStreamManagerImpl |
From |
To |
|
Change Variable Type pair : Entry<Address,Set<Integer>> to pair : Entry<Address,IntSet> in method private handleWriteOnlyManyCommand(ctx InvocationContext, command C, helper WriteManyCommandHelper<C,Container,Item>) : Object in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type iterator : Iterator<Integer> to iterator : PrimitiveIterator.OfInt in method private getRehashStream(cacheEntrySet CacheSet<Original>, requestId Object, listener SegmentListener, parallelStream boolean, entryStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>) : Stream<Original> in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Variable Type backups : Map<Address,Set<Integer>> to backups : Map<Address,IntSet> in method private writeManyRemoteCallback(helper WriteManyCommandHelper<C,?,?>, ctx InvocationContext, command C, rv Object) : Object in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type sourceEntry : Map.Entry<Address,Set<Integer>> to sourceEntry : Map.Entry<Address,IntSet> in method private requestTransactions(segments IntSet, sources Map<Address,IntSet>, excludedSources Set<Address>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type e : Map.Entry<Address,Set<Integer>> to e : Map.Entry<Address,IntSet> in method private requestSegments(segments IntSet, sources Map<Address,IntSet>, excludedSources Set<Address>) : void in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type removedSegments : Set<Integer> to removedSegments : IntSet in method public onTopologyUpdate(cacheTopology CacheTopology, isRebalance boolean) : CompletableFuture<Void> in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type backup : Entry<Address,Set<Integer>> to backup : Entry<Address,IntSet> in method private createLocalInvocationHandler(ch ConsistentHash, allFuture F, segments IntSet, helper WriteManyCommandHelper<C,?,Item>, returnValueConsumer BiConsumer<F,Object>) : InvocationFinallyAction in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type backupOwners : Map<Address,Set<Integer>> to backupOwners : Map<Address,IntSet> in method private createLocalInvocationHandler(ch ConsistentHash, allFuture F, segments IntSet, helper WriteManyCommandHelper<C,?,Item>, returnValueConsumer BiConsumer<F,Object>) : InvocationFinallyAction in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type segmentsToRequest : Set<Integer> to segmentsToRequest : IntSet in method public test1() : void in class org.infinispan.statetransfer.StateProviderTest |
From |
To |
|
Change Variable Type newSegments : Set<Integer> to newSegments : IntSet in method public onTopologyUpdate(cacheTopology CacheTopology, isRebalance boolean) : CompletableFuture<Void> in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type segmentsToRequest : Set<Integer> to segmentsToRequest : IntSet in method public test2() : void in class org.infinispan.statetransfer.StateProviderTest |
From |
To |
|
Change Variable Type ourSegments : Set<Integer> to ourSegments : IntSet in method package performOperationRehashAware(function Function<? super S2,? extends R>, retryOnRehash boolean, remoteResults ResultsAccumulator<R>, earlyTerminatePredicate Predicate<? super R>) : R in class org.infinispan.stream.impl.AbstractCacheStream |
From |
To |
|
Change Variable Type segmentInfoCH : ConsistentHash to numSegments : int in method package performRehashKeyTrackingOperation(function Function<Supplier<Stream<Original>>,KeyTrackingTerminalOperation<Original,Object,? extends T>>) : void in class org.infinispan.stream.impl.AbstractCacheStream |
From |
To |
|
Change Variable Type segments : Set<Integer> to segments : IntSet in method private handleWriteOnlyManyCommand(ctx InvocationContext, command C, helper WriteManyCommandHelper<C,Container,Item>) : Object in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type map : Map<Address,Set<Integer>> to map : Map<Address,IntSet> in method private backupOwnersOfSegments(ch ConsistentHash, segments IntSet) : Map<Address,IntSet> in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |
|
Change Variable Type segment : Integer to segment : int in method private getRehashStream(cacheEntrySet CacheSet<Original>, requestId Object, listener SegmentListener, parallelStream boolean, entryStream boolean, segments IntSet, keysToInclude Set<K>, keysToExclude Set<K>) : Stream<Original> in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Variable Type segment : int to segment : Integer in method protected removeTransfer(inboundTransfer InboundTransferTask) : boolean in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Variable Type segmentMap : Map<Address,Set<Integer>> to segmentMap : Map<Address,IntSet> in method private handleReadWriteManyCommand(ctx InvocationContext, command C, helper WriteManyCommandHelper<C,Item,Container>) : Object in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor |
From |
To |