|
Change Parameter Type command : FlagAffectedCommand to command : WriteCommand in method protected handleWriteManyCommand(ctx InvocationContext, command WriteCommand, keys Collection<K>, forwarded boolean) : Object in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor |
From |
To |
|
Change Parameter Type responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.test.concurrent.OutboundRpcSequencerAction.SequencerRpcManager |
From |
To |
|
Change Parameter Type rpcFuture : CompletableFuture<?> to rpcFuture : CompletionStage<?> in method protected completeSingleWriteOnPrimaryOriginator(command DataWriteCommand, backup Address, rpcFuture CompletionStage<?>) : CompletionStage<?> in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor |
From |
To |
|
Change Parameter Type rpcFuture : CompletableFuture<?> to rpcFuture : CompletionStage<?> in method protected completeSingleWriteOnPrimaryOriginator(command DataWriteCommand, backup Address, rpcFuture CompletionStage<?>) : CompletionStage<?> in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor |
From |
To |
|
Change Parameter Type delay : CompletableFuture<?> to delay : CompletionStage<?> in method public asyncInvokeNext(ctx InvocationContext, command VisitableCommand, delay CompletionStage<?>) : Object in class org.infinispan.interceptors.BaseAsyncInterceptor |
From |
To |
|
Change Parameter Type valueFuture : CompletableFuture<?> to valueFuture : CompletionStage<?> in method public asyncValue(valueFuture CompletionStage<?>) : InvocationStage in class org.infinispan.interceptors.BaseAsyncInterceptor |
From |
To |
|
Change Parameter Type responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.statetransfer.TxReplay3Test.UnsureResponseRpcManager |
From |
To |
|
Change Parameter Type responseMap : Map<Address,Response> to response : Response in method private applyValues(address Address, keys List<Object>, response Response) : void in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl |
From |
To |
|
Change Parameter Type responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.lock.PessimistTxFailureAfterLockingTest.TestControllerRpcManager |
From |
To |
|
Change Parameter Type responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.tx.EntryWrappingInterceptorDoesNotBlockTest.CountingBlockingRpcManager |
From |
To |
|
Change Parameter Type recipients : Collection<Address> to target : Address in method public invokeCommand(target Address, command ReplicableCommand, collector ResponseCollector<T>, rpcOptions RpcOptions) : CompletionStage<T> in class org.infinispan.commands.GetAllCacheNotFoundResponseTest.FakeRpcManager |
From |
To |
|
Change Parameter Type responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.container.versioning.WriteSkewConsistencyTest.ReorderResponsesRpcManager |
From |
To |
|
Change Parameter Type checker : Consumer<Map<Address,Response>> to checker : BiConsumer<ReplicableCommand,T> in method public checkResponses(checker BiConsumer<ReplicableCommand,T>) : void in class org.infinispan.tx.dld.ControlledRpcManager |
From |
To |
|
Change Parameter Type delays : Collection<CompletableFuture<?>> to delays : Collection<? extends CompletionStage<?>> in method public asyncInvokeNext(ctx InvocationContext, command VisitableCommand, delays Collection<? extends CompletionStage<?>>) : Object in class org.infinispan.interceptors.BaseAsyncInterceptor |
From |
To |
|
Change Parameter Type responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.util.AbstractControlledRpcManager |
From |
To |
|
Change Parameter Type command : FlagAffectedCommand to command : WriteCommand in method protected abstract handleWriteManyCommand(ctx InvocationContext, command WriteCommand, keys Collection<K>, forwarded boolean) : Object in class org.infinispan.interceptors.locking.AbstractLockingInterceptor |
From |
To |
|
Change Parameter Type command : FlagAffectedCommand to command : WriteCommand in method protected handleWriteManyCommand(ctx InvocationContext, command WriteCommand, keys Collection<K>, forwarded boolean) : Object in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor |
From |
To |
|
Change Parameter Type responses : Map<Address,Response> to response : Response in method protected handleMissingSuccessfulResponse(response Response) : CacheException in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Parameter Type command : FlagAffectedCommand to command : WriteCommand in method protected handleWriteManyCommand(ctx InvocationContext, command WriteCommand, keys Collection<K>, forwarded boolean) : Object in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor |
From |
To |
|
Change Parameter Type completableFuture : CompletableFuture<Map<Address,Response>> to rpcFuture : CompletionStage<ValidResponse> in method private handleResponseError(rpcFuture CompletionStage<ValidResponse>, requestId Object, origin Address) : void in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Change Parameter Type e : Exception to t : Throwable in method private errorReplicating(t Throwable) : T in class org.infinispan.remoting.rpc.RpcManagerImpl |
From |
To |
|
Change Variable Type remotePrepare : CompletableFuture<Object> to remotePrepare : CompletionStage<Object> in method public visitPrepareCommand(ctx TxInvocationContext, command PrepareCommand) : Object in class org.infinispan.interceptors.distribution.TxDistributionInterceptor |
From |
To |
|
Change Variable Type remoteCommand : ReplicableCommand to remoteCommand : ReadOnlyManyCommand in method private handleMissingResponse(response Response) : void in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyHandler |
From |
To |
|
Change Variable Type command : ReplicableCommand to command : TopologyAffectedCommand in method private invalidateAcrossCluster(synchronous boolean, keys Object[], ctx InvocationContext) : CompletionStage<Void> in class org.infinispan.interceptors.impl.InvalidationInterceptor |
From |
To |
|
Change Variable Type future : CompletableFuture<InternalCacheValue> to future : CompletionStage<InternalCacheValue> in method private handleLocallyLookedUpEntry(ctx1 InvocationContext, command1 VisitableCommand, rv Object) : Object in class org.infinispan.interceptors.impl.PrefetchInterceptor |
From |
To |
|
Change Variable Type cmd : VisitableCommand to cmd : LockControlCommand in method public visitPutKeyValueCommand(ctx InvocationContext, command PutKeyValueCommand) : Object in class org.infinispan.query.remote.impl.ProtobufMetadataManagerInterceptor |
From |
To |
|
Change Variable Type result : Map<Address,Response> to result : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.statetransfer.TxReplay3Test.UnsureResponseRpcManager |
From |
To |
|
Change Variable Type revokeFuture : CompletableFuture<?> to revokeFuture : CompletionStage<?> in method protected completeSingleWriteOnPrimaryOriginator(command DataWriteCommand, backup Address, rpcFuture CompletionStage<?>) : CompletionStage<?> in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor |
From |
To |
|
Change Variable Type remoteInvocation : CompletableFuture<Map<Address,Response>> to remoteInvocation : CompletionStage<Void> in method public visitPrepareCommand(ctx TxInvocationContext, command PrepareCommand) : Object in class org.infinispan.interceptors.impl.InvalidationInterceptor |
From |
To |
|
Change Variable Type remoteCommand : ReplicableCommand to remoteCommand : ReadOnlyManyCommand in method protected handleFunctionalReadManyCommand(ctx InvocationContext, command C, helper ReadManyCommandHelper<C>) : Object in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Variable Type getFuture : CompletableFuture<?> to getFuture : CompletionStage<?> in method protected handleNonTxWriteCommand(ctx InvocationContext, command AbstractDataWriteCommand) : Object in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Variable Type rpcFuture : CompletableFuture<Map<Address,Response>> to rpcFuture : CompletionStage<Map<Address,Response>> in method private handleWriteCommand(ctx InvocationContext, command DataWriteCommand) : Object in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor |
From |
To |
|
Change Variable Type cmd : VisitableCommand to cmd : LockControlCommand in method public visitReplaceCommand(ctx InvocationContext, command ReplaceCommand) : Object in class org.infinispan.query.remote.impl.ProtobufMetadataManagerInterceptor |
From |
To |
|
Change Variable Type remoteInvocation : CompletableFuture<Map<Address,Response>> to remoteInvocation : CompletionStage<ValidResponse> in method private invokeRemotely(ctx InvocationContext, command DataWriteCommand, primaryOwner Address) : Object in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Variable Type remoteInvocation : CompletableFuture<Map<Address,Response>> to remoteInvocation : CompletionStage<Void> in method public visitCommitCommand(ctx TxInvocationContext, command CommitCommand) : Object in class org.infinispan.interceptors.impl.InvalidationInterceptor |
From |
To |
|
Change Variable Type writeCH : ConsistentHash to cacheTopology : LocalizedCacheTopology in method public visitPutKeyValueCommand(ctx InvocationContext, command PutKeyValueCommand) : Object in class org.infinispan.hibernate.cache.access.UnorderedDistributionInterceptor |
From |
To |
|
Change Variable Type revokeFuture : CompletableFuture<?> to revokeFuture : CompletionStage<?> in method private revokeManyKeys(backup Address, future CountDownCompletableFuture, keys Collection<?>, topologyId int) : void in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor |
From |
To |
|
Change Variable Type cf : CompletableFuture<Void> to cf : CompletionStage<Void> in method protected remoteGet(ctx InvocationContext, command C, key Object, isWrite boolean) : CompletionStage<Void> in class org.infinispan.interceptors.distribution.TxDistributionInterceptor |
From |
To |
|
Change Variable Type future : CompletableFuture<Map<Address,Response>> to request : CompletionStage<Map<Address,Response>> in method public flushCache(keys Collection<Object>, origin Address, assumeOriginKeptEntryInL1 boolean) : CompletableFuture<?> in class org.infinispan.distribution.impl.L1ManagerImpl |
From |
To |
|
Change Variable Type rpcFuture : CompletableFuture<Map<Address,Response>> to rpcFuture : CompletionStage<Map<Address,Response>> in method private handleWriteManyOnOrigin(ctx InvocationContext, command C, helper WriteManyCommandHelper<C,Container,Item>) : Object in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor |
From |
To |
|
Change Variable Type revocationRequest : CompletableFuture<?> to revocationRequest : CompletionStage<Map<Address,Response>> in method private revokeBiasSync(key Object, backup Address, topologyId int) : CompletionStage<?> in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor |
From |
To |
|
Change Variable Type remoteInvocation : CompletableFuture<Map<Address,Response>> to remoteInvocation : CompletionStage<Void> in method private handleInvalidate(ctx InvocationContext, command WriteCommand, keys Object...) : Object in class org.infinispan.interceptors.impl.InvalidationInterceptor |
From |
To |
|
Change Return Type Map<Address,Response> to T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.test.concurrent.OutboundRpcSequencerAction.SequencerRpcManager |
From |
To |
|
Change Return Type Map<Address,Response> to Void in method protected addException(sender Address, exception Exception) : Void in class org.infinispan.remoting.transport.impl.VoidResponseCollector |
From |
To |
|
Change Return Type ReplicableCommand to TransactionBoundaryCommand in method public buildCommand(commandsFactory CommandsFactory, isVersioned boolean) : TransactionBoundaryCommand in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl.RollbackTransactionInfo |
From |
To |
|
Change Return Type ReplicableCommand to ReadOnlyManyCommand in method public copyForRemote(command ReadOnlyManyCommand, keys List<Object>, ctx InvocationContext) : ReadOnlyManyCommand in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper |
From |
To |
|
Change Return Type Map<Address,Response> to Void in method protected addTargetNotFound(sender Address) : Void in class org.infinispan.remoting.transport.impl.VoidResponseCollector |
From |
To |
|
Change Return Type Map<Address,Response> to T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.lock.PessimistTxFailureAfterLockingTest.TestControllerRpcManager |
From |
To |
|
Change Return Type CompletableFuture<?> to CompletionStage<Map<Address,Response>> in method private sendRevokeBias(targets Collection<Address>, keys Collection<Object>, topologyId int, commandInvocationId CommandInvocationId) : CompletionStage<Map<Address,Response>> in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor |
From |
To |
|
Change Return Type Map<Address,Response> to T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.container.versioning.WriteSkewConsistencyTest.ReorderResponsesRpcManager |
From |
To |
|
Change Return Type CompletableFuture<Map<Address,Response>> to CompletionStage<Map<Address,Response>> in method protected manyWriteOnRemotePrimary(target Address, command WriteCommand) : CompletionStage<Map<Address,Response>> in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor |
From |
To |
|
Change Return Type CompletableFuture<Void> to CompletionStage<Void> in method protected remoteGet(ctx InvocationContext, command C, key Object, isWrite boolean) : CompletionStage<Void> in class org.infinispan.interceptors.distribution.TxDistributionInterceptor |
From |
To |
|
Change Return Type void to T in method private errorReplicating(t Throwable) : T in class org.infinispan.remoting.rpc.RpcManagerImpl |
From |
To |
|
Change Return Type CompletableFuture<Map<Address,Response>> to CompletionStage<T> in method public invokeCommand(targets Collection<Address>, command ReplicableCommand, collector ResponseCollector<T>, rpcOptions RpcOptions) : CompletionStage<T> in class org.infinispan.scattered.BiasRevocationTest.FailingRpcManager |
From |
To |
|
Change Return Type ReplicableCommand to TransactionBoundaryCommand in method public buildCommand(commandsFactory CommandsFactory, isVersioned boolean) : TransactionBoundaryCommand in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl.TransactionInfo |
From |
To |
|
Change Return Type CompletableFuture<Map<Address,Response>> to CompletionStage<Map<Address,Response>> in method protected singleWriteOnRemotePrimary(target Address, command DataWriteCommand) : CompletionStage<Map<Address,Response>> in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor |
From |
To |
|
Change Return Type CompletableFuture<Map<Address,Response>> to CompletionStage<Map<Address,Response>> in method protected singleWriteOnRemotePrimary(target Address, command DataWriteCommand) : CompletionStage<Map<Address,Response>> in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor |
From |
To |
|
Change Return Type CompletableFuture<Map<Address,Response>> to CompletionStage<Map<Address,Response>> in method protected manyWriteOnRemotePrimary(target Address, command WriteCommand) : CompletionStage<Map<Address,Response>> in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor |
From |
To |
|
Change Return Type CompletableFuture<Object> to CompletionStage<Object> in method protected prepareOnAffectedNodes(ctx TxInvocationContext<?>, command PrepareCommand, recipients Collection<Address>) : CompletionStage<Object> in class org.infinispan.interceptors.distribution.TxDistributionInterceptor |
From |
To |
|
Change Return Type CompletableFuture<Map<Address,Response>> to CompletionStage<Void> in method private invalidateAcrossCluster(synchronous boolean, keys Object[], ctx InvocationContext) : CompletionStage<Void> in class org.infinispan.interceptors.impl.InvalidationInterceptor |
From |
To |
|
Change Return Type void to boolean in method protected notifyEndOfStateTransferIfNeeded() : boolean in class org.infinispan.statetransfer.StateConsumerImpl |
From |
To |
|
Change Return Type CompletableFuture<InternalCacheValue> to CompletionStage<InternalCacheValue> in method private retrieveRemoteValue(targets Collection<Address>, key Object, topologyId int) : CompletionStage<InternalCacheValue> in class org.infinispan.interceptors.impl.PrefetchInterceptor |
From |
To |
|
Change Return Type ReplicableCommand to TransactionBoundaryCommand in method public buildCommand(commandsFactory CommandsFactory, isVersioned boolean) : TransactionBoundaryCommand in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl.Commit1PCTransactionInfo |
From |
To |
|
Change Return Type Map<Address,Response> to T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.statetransfer.TxReplay3Test.UnsureResponseRpcManager |
From |
To |
|
Change Return Type Map<Address,Response> to Void in method protected addValidResponse(sender Address, response ValidResponse) : Void in class org.infinispan.remoting.transport.impl.VoidResponseCollector |
From |
To |
|
Change Return Type CompletableFuture<?> to CompletionStage<?> in method protected completeSingleWriteOnPrimaryOriginator(command DataWriteCommand, backup Address, rpcFuture CompletionStage<?>) : CompletionStage<?> in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor |
From |
To |
|
Change Return Type CompletableFuture<Void> to CompletionStage<Void> in method protected remoteGet(ctx InvocationContext, command C, key Object, isWrite boolean) : CompletionStage<Void> in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Change Return Type ReplicableCommand to TransactionBoundaryCommand in method public buildCommand(commandsFactory CommandsFactory, isVersioned boolean) : TransactionBoundaryCommand in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl.Commit2PCTransactionInfo |
From |
To |
|
Change Return Type ReplicableCommand to StreamIteratorNextCommand in method package getCommand(segments IntSet, batchAmount long) : StreamIteratorNextCommand in class org.infinispan.stream.impl.ClusterStreamManagerImpl.ClusterStreamSubscription |
From |
To |
|
Change Return Type ReplicableCommand to ReadOnlyManyCommand<?,?,?> in method public copyForRemote(command C, keys List<Object>, ctx InvocationContext) : ReadOnlyManyCommand<?,?,?> in class org.infinispan.interceptors.distribution.TxDistributionInterceptor.BaseFunctionalWriteHelper |
From |
To |
|
Change Return Type Map<Address,Response> to T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.tx.EntryWrappingInterceptorDoesNotBlockTest.CountingBlockingRpcManager |
From |
To |
|
Change Return Type CompletableFuture<Object> to CompletionStage<Object> in method protected totalOrderPrepare(ctx TxInvocationContext<?>, command PrepareCommand, recipients Collection<Address>) : CompletionStage<Object> in class org.infinispan.interceptors.impl.BaseRpcInterceptor |
From |
To |
|
Change Return Type CompletableFuture<Map<Address,Response>> to CompletionStage<T> in method public invokeCommand(target Address, command ReplicableCommand, collector ResponseCollector<T>, rpcOptions RpcOptions) : CompletionStage<T> in class org.infinispan.commands.GetAllCacheNotFoundResponseTest.FakeRpcManager |
From |
To |
|
Change Return Type CompletableFuture<?> to CompletionStage<?> in method protected completeSingleWriteOnPrimaryOriginator(command DataWriteCommand, backup Address, rpcFuture CompletionStage<?>) : CompletionStage<?> in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor |
From |
To |
|
Change Return Type Map<Address,Response> to Void in method public finish() : Void in class org.infinispan.remoting.transport.impl.VoidResponseCollector |
From |
To |
|
Change Return Type CompletableFuture<Object> to CompletionStage<Object> in method protected prepareOnAffectedNodes(ctx TxInvocationContext<?>, command PrepareCommand, recipients Collection<Address>) : CompletionStage<Object> in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor |
From |
To |
|
Change Return Type ReplicableCommand to ReadOnlyManyCommand in method public copyForRemote(command C, keys List<Object>, ctx InvocationContext) : ReadOnlyManyCommand in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper |
From |
To |
|
Change Return Type Map<Address,Response> to T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.util.AbstractControlledRpcManager |
From |
To |
|
Change Return Type CompletableFuture<?> to CompletionStage<?> in method private revokeBiasSync(key Object, backup Address, topologyId int) : CompletionStage<?> in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor |
From |
To |
|
Change Return Type CompletableFuture<Object> to CompletionStage<Object> in method protected prepareOnAffectedNodes(ctx TxInvocationContext<?>, command PrepareCommand, recipients Collection<Address>) : CompletionStage<Object> in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor |
From |
To |
|
Change Return Type CompletableFuture<Object> to CompletionStage<Object> in method protected prepareOnAffectedNodes(ctx TxInvocationContext<?>, command PrepareCommand, recipients Collection<Address>) : CompletionStage<Object> in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor |
From |
To |
|
Change Return Type ReplicableCommand to ReadOnlyManyCommand in method public copyForRemote(command ReadOnlyManyCommand, keys List<Object>, ctx InvocationContext) : ReadOnlyManyCommand in class org.infinispan.interceptors.distribution.TxDistributionInterceptor.TxReadOnlyManyHelper |
From |
To |
|
Rename Parameter options : RpcOptions to rpcOptions : RpcOptions in method public invokeCommand(target Address, command ReplicableCommand, collector ResponseCollector<T>, rpcOptions RpcOptions) : CompletionStage<T> in class org.infinispan.commands.GetAllCacheNotFoundResponseTest.FakeRpcManager |
From |
To |
|
Rename Parameter rpc : ReplicableCommand to command : ReplicableCommand in method public invokeCommand(target Address, command ReplicableCommand, collector ResponseCollector<T>, rpcOptions RpcOptions) : CompletionStage<T> in class org.infinispan.commands.GetAllCacheNotFoundResponseTest.FakeRpcManager |
From |
To |
|
Rename Parameter responseCollector : ResponseCollector<T> to collector : ResponseCollector<T> in method public invokeCommands(targets Collection<Address>, commandGenerator Function<Address,ReplicableCommand>, collector ResponseCollector<T>, deliverOrder DeliverOrder, timeout long, timeUnit TimeUnit) : CompletionStage<T> in class org.infinispan.remoting.transport.Transport |
From |
To |
|
Rename Parameter recipients : Collection<Address> to targets : Collection<Address> in method public invokeCommand(targets Collection<Address>, command ReplicableCommand, collector ResponseCollector<T>, rpcOptions RpcOptions) : CompletionStage<T> in class org.infinispan.scattered.BiasRevocationTest.FailingRpcManager |
From |
To |
|
Rename Parameter responses : Map<Address,Response> to response : Response in method protected handleMissingSuccessfulResponse(response Response) : CacheException in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor |
From |
To |
|
Rename Parameter completableFuture : CompletableFuture<Map<Address,Response>> to rpcFuture : CompletionStage<ValidResponse> in method private handleResponseError(rpcFuture CompletionStage<ValidResponse>, requestId Object, origin Address) : void in class org.infinispan.stream.impl.LocalStreamManagerImpl |
From |
To |
|
Rename Parameter e : Exception to t : Throwable in method private errorReplicating(t Throwable) : T in class org.infinispan.remoting.rpc.RpcManagerImpl |
From |
To |
|
Rename Parameter options : RpcOptions to rpcOptions : RpcOptions in method public invokeCommand(targets Collection<Address>, command ReplicableCommand, collector ResponseCollector<T>, rpcOptions RpcOptions) : CompletionStage<T> in class org.infinispan.scattered.BiasRevocationTest.FailingRpcManager |
From |
To |
|
Rename Parameter responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.test.concurrent.OutboundRpcSequencerAction.SequencerRpcManager |
From |
To |
|
Rename Parameter rCommand : WriteCommand to writeCmd : WriteCommand in method public invokeRemotelyAsync(finalOwners List<Address>, rCtx InvocationContext, writeCmd WriteCommand) : Object in class org.infinispan.hibernate.cache.access.UnorderedDistributionInterceptor |
From |
To |
|
Rename Parameter responseCollector : ResponseCollector<T> to collector : ResponseCollector<T> in method public invokeCommands(targets Collection<Address>, commandGenerator Function<Address,ReplicableCommand>, collector ResponseCollector<T>, deliverOrder DeliverOrder, timeout long, timeUnit TimeUnit) : CompletableFuture<T> in class org.infinispan.remoting.transport.jgroups.JGroupsTransport |
From |
To |
|
Rename Parameter responseCollector : ResponseCollector<T> to collector : ResponseCollector<T> in method public invokeCommands(targets Collection<Address>, commandGenerator Function<Address,ReplicableCommand>, collector ResponseCollector<T>, deliverOrder DeliverOrder, timeout long, timeUnit TimeUnit) : CompletionStage<T> in class org.infinispan.remoting.transport.AbstractDelegatingTransport |
From |
To |
|
Rename Parameter responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.util.AbstractControlledRpcManager |
From |
To |
|
Rename Parameter responseMap : Map<Address,Response> to response : Response in method private applyValues(address Address, keys List<Object>, response Response) : void in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl |
From |
To |
|
Rename Parameter responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.statetransfer.TxReplay3Test.UnsureResponseRpcManager |
From |
To |
|
Rename Parameter rpc : ReplicableCommand to command : ReplicableCommand in method public invokeCommand(targets Collection<Address>, command ReplicableCommand, collector ResponseCollector<T>, rpcOptions RpcOptions) : CompletionStage<T> in class org.infinispan.scattered.BiasRevocationTest.FailingRpcManager |
From |
To |
|
Rename Parameter responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.lock.PessimistTxFailureAfterLockingTest.TestControllerRpcManager |
From |
To |
|
Rename Parameter recipients : Collection<Address> to target : Address in method public invokeCommand(target Address, command ReplicableCommand, collector ResponseCollector<T>, rpcOptions RpcOptions) : CompletionStage<T> in class org.infinispan.commands.GetAllCacheNotFoundResponseTest.FakeRpcManager |
From |
To |
|
Rename Parameter responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.tx.EntryWrappingInterceptorDoesNotBlockTest.CountingBlockingRpcManager |
From |
To |
|
Rename Parameter commands : Map<Address,ReplicableCommand> to rpcCommands : Map<Address,ReplicableCommand> in method public invokeRemotely(rpcCommands Map<Address,ReplicableCommand>, mode ResponseMode, timeout long, usePriorityQueue boolean, responseFilter ResponseFilter, totalOrder boolean, anycast boolean) : Map<Address,Response> in class org.infinispan.remoting.transport.Transport |
From |
To |
|
Rename Parameter command : ReplicableCommand to rpcCommand : ReplicableCommand in method public invokeRemotely(recipients Collection<Address>, rpcCommand ReplicableCommand, mode ResponseMode, timeout long, responseFilter ResponseFilter, deliverOrder DeliverOrder, anycast boolean) : Map<Address,Response> in class org.infinispan.remoting.transport.Transport |
From |
To |
|
Rename Parameter responseMap : Map<Address,Response> to responseObject : T in method protected afterInvokeRemotely(command ReplicableCommand, responseObject T, argument Object) : T in class org.infinispan.container.versioning.WriteSkewConsistencyTest.ReorderResponsesRpcManager |
From |
To |