|
Change Parameter Type RFuture : Future<V> to RFuture : RFuture<V> in method public convertException(RFuture RFuture<V>) : RedisException in class org.redisson.command.CommandAsyncExecutor |
From |
To |
|
Change Parameter Type future : Future<?> to future : RFuture<?> in method public await(future RFuture<?>, timeout long, timeoutUnit TimeUnit) : boolean in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Parameter Type index : int to index : long in method public fastRemoveAsync(index long) : RFuture<Void> in class org.redisson.RedissonListMultimapValues |
From |
To |
|
Change Parameter Type mainPromise : Promise<Void> to mainPromise : RPromise<Void> in method public execute(entry Entry, source NodeSource, mainPromise RPromise<Void>, slots AtomicInteger, attempt int) : void in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Parameter Type result : Promise<Void> to result : RPromise<Void> in method private acquireAsync(permits int, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Void>) : void in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Parameter Type fromIndex : int to fromIndex : long in method public trimAsync(fromIndex long, toIndex long) : RFuture<Void> in class org.redisson.RedissonList |
From |
To |
|
Change Parameter Type future : Future<R> to future : RFuture<R> in method public reactive(future RFuture<R>) : Publisher<R> in class org.redisson.reactive.RedissonObjectReactive |
From |
To |
|
Change Parameter Type promise : Promise<T> to promise : RPromise<T> in method public RemotePromise(promise RPromise<T>) in class org.redisson.executor.RemotePromise |
From |
To |
|
Change Parameter Type attemptPromise : Promise<R> to attemptPromise : RPromise<R> in method public init(connectionFuture RFuture<RedisConnection>, attemptPromise RPromise<R>, readOnlyMode boolean, source NodeSource, codec Codec, command RedisCommand<V>, params Object[], mainPromise RPromise<R>, attempt int) : void in class org.redisson.command.AsyncDetails |
From |
To |
|
Change Parameter Type fromIndex : int to fromIndex : long in method public trimAsync(fromIndex long, toIndex long) : RFuture<Void> in class org.redisson.api.RListAsync |
From |
To |
|
Change Parameter Type addFuture : Future<Boolean> to addFuture : RFuture<Boolean> in method public setAddFuture(addFuture RFuture<Boolean>) : void in class org.redisson.executor.RemotePromise |
From |
To |
|
Change Parameter Type connectionFuture : Future<RedisConnection> to connectionFuture : RFuture<RedisConnection> in method public init(connectionFuture RFuture<RedisConnection>, attemptPromise RPromise<R>, readOnlyMode boolean, source NodeSource, codec Codec, command RedisCommand<V>, params Object[], mainPromise RPromise<R>, attempt int) : void in class org.redisson.command.AsyncDetails |
From |
To |
|
Change Parameter Type result : Promise<Boolean> to result : RPromise<Boolean> in method private tryLockAsync(time AtomicLong, leaseTime long, unit TimeUnit, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Boolean>, currentThreadId long) : void in class org.redisson.RedissonLock |
From |
To |
|
Change Parameter Type RFuture : Future<?> to RFuture : RFuture<?> in method public await(RFuture RFuture<?>, timeout long, timeoutUnit TimeUnit) : boolean in class org.redisson.command.CommandAsyncExecutor |
From |
To |
|
Change Parameter Type promise : Promise<RedissonCountDownLatchEntry> to promise : RPromise<RedissonCountDownLatchEntry> in method public RedissonCountDownLatchEntry(promise RPromise<RedissonCountDownLatchEntry>) in class org.redisson.RedissonCountDownLatchEntry |
From |
To |
|
Change Parameter Type future : Future<R> to future : RFuture<R> in method public reactive(future RFuture<R>) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Parameter Type listener : GenericFutureListener<? extends Future<? super T>> to listener : FutureListener<? super T> in method public addListener(listener FutureListener<? super T>) : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Parameter Type promise : Promise<T> to promise : RPromise<T> in method public PromiseDelegator(promise RPromise<T>) in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Parameter Type connectionFuture : Promise<T> to connectionFuture : RPromise<T> in method private addFireEventListener(conn T, connectionFuture RPromise<T>) : void in class org.redisson.connection.ClientConnectionsEntry |
From |
To |
|
Change Parameter Type promise : Promise<R> to promise : RPromise<R> in method public CommandData(promise RPromise<R>, codec Codec, command RedisCommand<T>, params Object[]) in class org.redisson.client.protocol.CommandData |
From |
To |
|
Change Parameter Type cancelRequestFuture : Future<RemoteServiceCancelRequest> to cancelRequestFuture : RFuture<RemoteServiceCancelRequest> in method private invokeMethod(remoteInterface Class<T>, requestQueue RBlockingQueue<RemoteServiceRequest>, request RemoteServiceRequest, method RemoteServiceMethod, responseName String, executor ExecutorService, cancelRequestFuture RFuture<RemoteServiceCancelRequest>, responseHolder AtomicReference<RRemoteServiceResponse>) : void in class org.redisson.RedissonRemoteService |
From |
To |
|
Change Parameter Type subscribeFuture : Future<RedissonLockEntry> to subscribeFuture : RFuture<RedissonLockEntry> in method private lockAsync(leaseTime long, unit TimeUnit, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Void>, currentThreadId long) : void in class org.redisson.RedissonLock |
From |
To |
|
Change Parameter Type promise : Promise<R> to promise : RPromise<R> in method public CommandData(promise RPromise<R>, messageDecoder MultiDecoder<Object>, codec Codec, command RedisCommand<T>, params Object[]) in class org.redisson.client.protocol.CommandData |
From |
To |
|
Change Parameter Type toIndex : int to toIndex : long in method public trimAsync(fromIndex long, toIndex long) : RFuture<Void> in class org.redisson.api.RListAsync |
From |
To |
|
Change Parameter Type newPromise : Promise<RedissonLockEntry> to newPromise : RPromise<RedissonLockEntry> in method protected createEntry(newPromise RPromise<RedissonLockEntry>) : RedissonLockEntry in class org.redisson.pubsub.LockPubSub |
From |
To |
|
Change Parameter Type toIndex : int to toIndex : long in method public trimAsync(fromIndex long, toIndex long) : RFuture<Void> in class org.redisson.RedissonListMultimapValues |
From |
To |
|
Change Parameter Type that : Future<? extends T> to that : RFuture<? extends T> in method public NettyFuturePublisher(that RFuture<? extends T>) in class org.redisson.reactive.NettyFuturePublisher |
From |
To |
|
Change Parameter Type future : Future<?> to future : RFuture<?> in method protected await(future RFuture<?>, timeout long, timeoutUnit TimeUnit) : boolean in class org.redisson.RedissonObject |
From |
To |
|
Change Parameter Type attemptPromise : Promise<Void> to attemptPromise : RPromise<Void> in method private checkConnectionFuture(entry Entry, source NodeSource, mainPromise RPromise<Void>, attemptPromise RPromise<Void>, details AsyncDetails, connFuture RFuture<RedisConnection>) : void in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Parameter Type listener : GenericFutureListener<? extends Future<? super T>> to listener : FutureListener<? super T> in method public removeListener(listener FutureListener<? super T>) : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Parameter Type listeners : GenericFutureListener<? extends Future<? super T>>... to listeners : FutureListener<? super T>... in method public addListeners(listeners FutureListener<? super T>...) : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Parameter Type connectionFuture : Promise<T> to connectionFuture : RPromise<T> in method private addReconnectListener(connectionFuture RPromise<T>, conn T) : void in class org.redisson.connection.ClientConnectionsEntry |
From |
To |
|
Change Parameter Type future : Future<RedissonLockEntry> to future : RFuture<RedissonLockEntry> in method private unsubscribe(future RFuture<RedissonLockEntry>) : void in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Parameter Type promise : Promise<T> to promise : RPromise<T> in method private promiseSuccessful(entry ClientConnectionsEntry, promise RPromise<T>, conn T) : void in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Parameter Type promise : Promise<Void> to promise : RPromise<Void> in method private lock(promise RPromise<Void>, waitTime long, leaseTime long, unit TimeUnit, locks List<RLock>, currentThreadId long, lockedLocks Queue<RLock>) : void in class org.redisson.RedissonMultiLock |
From |
To |
|
Change Parameter Type result : Promise<Void> to result : RPromise<Void> in method private lockAsync(leaseTime long, unit TimeUnit, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Void>, currentThreadId long) : void in class org.redisson.RedissonLock |
From |
To |
|
Change Parameter Type tryLockFutures : Map<RLock,Future<Boolean>> to tryLockFutures : Map<RLock,RFuture<Boolean>> in method protected sync(tryLockFutures Map<RLock,RFuture<Boolean>>) : boolean in class org.redisson.RedissonMultiLock |
From |
To |
|
Change Parameter Type subscribeFuture : Future<RedissonLockEntry> to subscribeFuture : RFuture<RedissonLockEntry> in method private tryLockAsync(time AtomicLong, leaseTime long, unit TimeUnit, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Boolean>, currentThreadId long) : void in class org.redisson.RedissonLock |
From |
To |
|
Change Parameter Type promise : Promise<R> to promise : RPromise<R> in method public BatchCommandData(promise RPromise<R>, codec Codec, command RedisCommand<T>, params Object[], index int) in class org.redisson.client.protocol.BatchCommandData |
From |
To |
|
Change Parameter Type future : Future<RedissonLockEntry> to future : RFuture<RedissonLockEntry> in method protected unsubscribe(future RFuture<RedissonLockEntry>, threadId long) : void in class org.redisson.RedissonLock |
From |
To |
|
Change Parameter Type result : Promise<Boolean> to result : RPromise<Boolean> in method private tryAcquireAsync(time AtomicLong, permits int, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Boolean>) : void in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Parameter Type mainPromise : Promise<R> to mainPromise : RPromise<R> in method public init(connectionFuture RFuture<RedisConnection>, attemptPromise RPromise<R>, readOnlyMode boolean, source NodeSource, codec Codec, command RedisCommand<V>, params Object[], mainPromise RPromise<R>, attempt int) : void in class org.redisson.command.AsyncDetails |
From |
To |
|
Change Parameter Type promise : Promise<Void> to promise : RPromise<Void> in method public CommandsData(promise RPromise<Void>, commands List<CommandData<?,?>>) in class org.redisson.client.protocol.CommandsData |
From |
To |
|
Change Parameter Type initPromise : Promise<Void> to initPromise : RPromise<Void> in method private initConnections(entry ClientConnectionsEntry, initPromise RPromise<Void>, checkFreezed boolean) : void in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Parameter Type listeners : GenericFutureListener<? extends Future<? super T>>... to listeners : FutureListener<? super T>... in method public addListeners(listeners FutureListener<? super T>...) : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Parameter Type connectionFuture : Future<RedisConnection> to connectionFuture : RFuture<RedisConnection> in method protected releaseConnection(source NodeSource, connectionFuture RFuture<RedisConnection>, isReadOnly boolean, attemptPromise RPromise<R>, details AsyncDetails<V,R>) : void in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Parameter Type attemptPromise : Promise<R> to attemptPromise : RPromise<R> in method protected releaseConnection(source NodeSource, connectionFuture RFuture<RedisConnection>, isReadOnly boolean, attemptPromise RPromise<R>, details AsyncDetails<V,R>) : void in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Parameter Type promise : Promise<RedissonLockEntry> to promise : RPromise<RedissonLockEntry> in method public RedissonLockEntry(promise RPromise<RedissonLockEntry>) in class org.redisson.RedissonLockEntry |
From |
To |
|
Change Parameter Type listener : GenericFutureListener<? extends Future<? super T>> to listener : FutureListener<? super T> in method public removeListener(listener FutureListener<? super T>) : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Parameter Type future : Future<R> to future : RFuture<R> in method public reactive(future RFuture<R>) : Publisher<R> in class org.redisson.command.CommandReactiveExecutor |
From |
To |
|
Change Parameter Type mainPromise : Promise<R> to mainPromise : RPromise<R> in method private retryReadRandomAsync(command RedisCommand<T>, mainPromise RPromise<R>, nodes List<MasterSlaveEntry>, params Object...) : void in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Parameter Type promise : Promise<Integer> to promise : RPromise<Integer> in method private addListener(pubSubListener RedisPubSubListener<M>, promise RPromise<Integer>) : void in class org.redisson.reactive.RedissonPatternTopicReactive |
From |
To |
|
Change Parameter Type connectionFuture : Promise<T> to connectionFuture : RPromise<T> in method public onConnect(connectionFuture RPromise<T>, conn T, nodeType NodeType, config MasterSlaveServersConfig) : void in class org.redisson.connection.DefaultConnectionListener |
From |
To |
|
Change Parameter Type promise : Promise<T> to promise : RPromise<T> in method public TransferListener(promise RPromise<T>) in class org.redisson.pubsub.TransferListener |
From |
To |
|
Change Parameter Type toIndex : int to toIndex : long in method public trimAsync(fromIndex long, toIndex long) : RFuture<Void> in class org.redisson.RedissonSubList |
From |
To |
|
Change Parameter Type initPromise : Promise<Void> to initPromise : RPromise<Void> in method private createConnection(checkFreezed boolean, requests AtomicInteger, entry ClientConnectionsEntry, initPromise RPromise<Void>, minimumIdleSize int, initializedConnections AtomicInteger) : void in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Parameter Type attemptPromise : Promise<Void> to attemptPromise : RPromise<Void> in method private checkWriteFuture(attemptPromise RPromise<Void>, details AsyncDetails, connection RedisConnection, future ChannelFuture) : void in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Parameter Type newPromise : Promise<RedissonCountDownLatchEntry> to newPromise : RPromise<RedissonCountDownLatchEntry> in method protected createEntry(newPromise RPromise<RedissonCountDownLatchEntry>) : RedissonCountDownLatchEntry in class org.redisson.pubsub.CountDownLatchPubSub |
From |
To |
|
Change Parameter Type future : Future<R> to future : RFuture<R> in method public await(future RFuture<R>) : R in class org.redisson.client.RedisConnection |
From |
To |
|
Change Parameter Type listeners : GenericFutureListener<? extends Future<? super T>>... to listeners : FutureListener<? super T>... in method public removeListeners(listeners FutureListener<? super T>...) : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Parameter Type index : int to index : long in method public fastRemoveAsync(index long) : RFuture<Void> in class org.redisson.api.RListAsync |
From |
To |
|
Change Parameter Type future : Future<V> to future : RFuture<V> in method public get(future RFuture<V>) : V in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Parameter Type future : Future<RedissonLockEntry> to future : RFuture<RedissonLockEntry> in method protected unsubscribe(future RFuture<RedissonLockEntry>, threadId long) : void in class org.redisson.RedissonFairLock |
From |
To |
|
Change Parameter Type mainPromise : Promise<R> to mainPromise : RPromise<R> in method protected async(readOnlyMode boolean, nodeSource NodeSource, codec Codec, command RedisCommand<V>, params Object[], mainPromise RPromise<R>, attempt int) : void in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Parameter Type connFuture : Future<RedisConnection> to connFuture : RFuture<RedisConnection> in method private checkConnectionFuture(entry Entry, source NodeSource, mainPromise RPromise<Void>, attemptPromise RPromise<Void>, details AsyncDetails, connFuture RFuture<RedisConnection>) : void in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Parameter Type future : Future<RedissonCountDownLatchEntry> to future : RFuture<RedissonCountDownLatchEntry> in method private unsubscribe(future RFuture<RedissonCountDownLatchEntry>) : void in class org.redisson.RedissonCountDownLatch |
From |
To |
|
Change Parameter Type connectionFuture : Promise<T> to connectionFuture : RPromise<T> in method public onConnect(connectionFuture RPromise<T>, conn T, nodeType NodeType, config MasterSlaveServersConfig) : void in class org.redisson.connection.ConnectionInitializer |
From |
To |
|
Change Parameter Type future : Future<V> to future : RFuture<V> in method public convertException(future RFuture<V>) : RedisException in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Parameter Type promise : Promise<T> to promise : RPromise<T> in method private promiseFailure(entry ClientConnectionsEntry, promise RPromise<T>, conn T) : void in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Parameter Type connectionFuture : Promise<T> to connectionFuture : RPromise<T> in method public FutureConnectionListener(connectionFuture RPromise<T>, connection T) in class org.redisson.connection.FutureConnectionListener |
From |
To |
|
Change Parameter Type subscribeFuture : Future<RedissonLockEntry> to subscribeFuture : RFuture<RedissonLockEntry> in method private tryAcquireAsync(time AtomicLong, permits int, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Boolean>) : void in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Parameter Type promise : Promise<PubSubConnectionEntry> to promise : RPromise<PubSubConnectionEntry> in method private connect(codec Codec, channelName String, listener RedisPubSubListener<?>, promise RPromise<PubSubConnectionEntry>, type PubSubType, lock AsyncSemaphore) : void in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Parameter Type listener : GenericFutureListener<? extends Future<? super T>> to listener : FutureListener<? super T> in method public addListener(listener FutureListener<? super T>) : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Parameter Type result : Promise<Long> to result : RPromise<Long> in method private checkExecution(result RPromise<Long>, failed AtomicReference<Throwable>, count AtomicLong, executed AtomicLong) : void in class org.redisson.RedissonKeys |
From |
To |
|
Change Parameter Type toIndex : int to toIndex : long in method public trimAsync(fromIndex long, toIndex long) : RFuture<Void> in class org.redisson.RedissonList |
From |
To |
|
Change Parameter Type RFuture : Future<V> to RFuture : RFuture<V> in method public get(RFuture RFuture<V>) : V in class org.redisson.command.CommandAsyncExecutor |
From |
To |
|
Change Parameter Type subscribeFuture : Future<RedissonLockEntry> to subscribeFuture : RFuture<RedissonLockEntry> in method private acquireAsync(permits int, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Void>) : void in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Parameter Type index : int to index : long in method public fastRemoveAsync(index long) : RFuture<Void> in class org.redisson.RedissonList |
From |
To |
|
Change Parameter Type fromIndex : int to fromIndex : long in method public trimAsync(fromIndex long, toIndex long) : RFuture<Void> in class org.redisson.RedissonListMultimapValues |
From |
To |
|
Change Parameter Type fromIndex : int to fromIndex : long in method public trimAsync(fromIndex long, toIndex long) : RFuture<Void> in class org.redisson.RedissonSubList |
From |
To |
|
Change Parameter Type mainPromise : Promise<R> to mainPromise : RPromise<R> in method protected async(readOnlyMode boolean, source NodeSource, codec Codec, command RedisCommand<V>, params Object[], mainPromise RPromise<R>, attempt int) : void in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Parameter Type future : Future<V> to future : RFuture<V> in method public get(future RFuture<V>) : V in class org.redisson.command.CommandSyncExecutor |
From |
To |
|
Change Parameter Type listeners : GenericFutureListener<? extends Future<? super T>>... to listeners : FutureListener<? super T>... in method public removeListeners(listeners FutureListener<? super T>...) : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Parameter Type promise : Promise<PubSubConnectionEntry> to promise : RPromise<PubSubConnectionEntry> in method private subscribe(codec Codec, channelName String, listener RedisPubSubListener<?>, promise RPromise<PubSubConnectionEntry>, type PubSubType, lock AsyncSemaphore) : void in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Parameter Type mainPromise : Promise<Void> to mainPromise : RPromise<Void> in method private checkConnectionFuture(entry Entry, source NodeSource, mainPromise RPromise<Void>, attemptPromise RPromise<Void>, details AsyncDetails, connFuture RFuture<RedisConnection>) : void in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Parameter Type newPromise : Promise<RedissonLockEntry> to newPromise : RPromise<RedissonLockEntry> in method protected createEntry(newPromise RPromise<RedissonLockEntry>) : RedissonLockEntry in class org.redisson.pubsub.SemaphorePubSub |
From |
To |
|
Change Parameter Type future : Future<V> to future : RFuture<V> in method protected get(future RFuture<V>) : V in class org.redisson.RedissonObject |
From |
To |
|
Change Parameter Type tryLockFutures : Map<RLock,Future<Boolean>> to tryLockFutures : Map<RLock,RFuture<Boolean>> in method protected sync(tryLockFutures Map<RLock,RFuture<Boolean>>) : boolean in class org.redisson.RedissonRedLock |
From |
To |
|
Change Return Type Future<RedissonLockEntry> to RFuture<RedissonLockEntry> in method protected subscribe(threadId long) : RFuture<RedissonLockEntry> in class org.redisson.RedissonLock |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public addListener(listener FutureListener<? super T>) : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public setSuccess(result T) : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type Future<RedissonLockEntry> to RFuture<RedissonLockEntry> in method private subscribe() : RFuture<RedissonLockEntry> in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connect() : RFuture<RedisConnection> in class org.redisson.connection.ClientConnectionsEntry |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectionReadOp(addr InetSocketAddress) : RFuture<RedisConnection> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public getConnectionFuture() : RFuture<RedisConnection> in class org.redisson.command.AsyncDetails |
From |
To |
|
Change Return Type Future<E> to RFuture<E> in method public subscribe(entryName String, channelName String, connectionManager ConnectionManager) : RFuture<E> in class org.redisson.pubsub.PublishSubscribe |
From |
To |
|
Change Return Type Future<RedisPubSubConnection> to RFuture<RedisPubSubConnection> in method public nextPubSubConnection() : RFuture<RedisPubSubConnection> in class org.redisson.connection.balancer.LoadBalancerManagerImpl |
From |
To |
|
Change Return Type Future<RedisPubSubConnection> to RFuture<RedisPubSubConnection> in method public connectPubSubAsync() : RFuture<RedisPubSubConnection> in class org.redisson.client.RedisClient |
From |
To |
|
Change Return Type Future<PubSubConnectionEntry> to RFuture<PubSubConnectionEntry> in method public subscribe(codec Codec, channelName String, listener RedisPubSubListener<?>) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Return Type Future<PubSubConnectionEntry> to RFuture<PubSubConnectionEntry> in method public subscribe(codec Codec, channelName String, listener RedisPubSubListener<?>) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.ConnectionManager |
From |
To |
|
Change Return Type Future<Boolean> to RFuture<Boolean> in method protected addAsync(requestQueue RBlockingQueue<RemoteServiceRequest>, request RemoteServiceRequest, result RemotePromise<Object>) : RFuture<Boolean> in class org.redisson.executor.ExecutorRemoteService |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public awaitUninterruptibly() : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public get(entry ClientConnectionsEntry) : RFuture<T> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method private connectTo(entry ClientConnectionsEntry) : RFuture<T> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Return Type Future<Void> to RFuture<Void> in method public setupMasterEntry(host String, port int) : RFuture<Void> in class org.redisson.connection.SingleEntry |
From |
To |
|
Change Return Type Future<?> to RFuture<?> in method public getAcquireFuture() : RFuture<?> in class org.redisson.client.RedisConnection |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public sync() : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public syncUninterruptibly() : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public getConnection(addr InetSocketAddress) : RFuture<RedisConnection> in class org.redisson.connection.balancer.LoadBalancerManager |
From |
To |
|
Change Return Type Future<Integer> to RFuture<Integer> in method private cleanupExpiredEntires(name String, timeoutSetName String, maxIdleSetName String, keysLimit int, multimap boolean) : RFuture<Integer> in class org.redisson.EvictionScheduler |
From |
To |
|
Change Return Type Future<Void> to RFuture<Void> in method public add(entry ClientConnectionsEntry) : RFuture<Void> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Return Type Promise<R> to RPromise<R> in method public getMainPromise() : RPromise<R> in class org.redisson.command.AsyncDetails |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectAsync() : RFuture<RedisConnection> in class org.redisson.client.RedisClient |
From |
To |
|
Change Return Type Future<R> to RFuture<R> in method public async(command RedisCommand<T>, params Object...) : RFuture<R> in class org.redisson.client.RedisConnection |
From |
To |
|
Change Return Type Future<PubSubConnectionEntry> to RFuture<PubSubConnectionEntry> in method public psubscribe(pattern String, codec Codec, listener RedisPubSubListener<?>, semaphore AsyncSemaphore) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.ConnectionManager |
From |
To |
|
Change Return Type Future<Void> to RFuture<Void> in method private addSlave(host String, port int, freezed boolean, mode NodeType) : RFuture<Void> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectionReadOp(addr InetSocketAddress) : RFuture<RedisConnection> in class org.redisson.connection.SingleEntry |
From |
To |
|
Change Return Type Future<R> to RFuture<R> in method public async(timeout long, command RedisCommand<T>, params Object...) : RFuture<R> in class org.redisson.client.RedisConnection |
From |
To |
|
Change Return Type Promise<E> to RPromise<E> in method public getPromise() : RPromise<E> in class org.redisson.PubSubEntry |
From |
To |
|
Change Return Type Future<PubSubConnectionEntry> to RFuture<PubSubConnectionEntry> in method public subscribe(codec Codec, channelName String, listener RedisPubSubListener<?>, semaphore AsyncSemaphore) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public removeListener(listener FutureListener<? super T>) : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public removeListener(listener FutureListener<? super T>) : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectionWriteOp(source NodeSource, command RedisCommand<?>) : RFuture<RedisConnection> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Return Type Future<PubSubConnectionEntry> to RFuture<PubSubConnectionEntry> in method public psubscribe(channelName String, codec Codec, listener RedisPubSubListener<?>) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Return Type Future<RemoteServiceAck> to RFuture<RemoteServiceAck> in method private tryPollAckAgainAsync(optionsCopy RemoteInvocationOptions, responseQueue RBlockingQueue<RemoteServiceAck>, ackName String) : RFuture<RemoteServiceAck> in class org.redisson.BaseRemoteService |
From |
To |
|
Change Return Type Future<PubSubConnectionEntry> to RFuture<PubSubConnectionEntry> in method public psubscribe(pattern String, codec Codec, listener RedisPubSubListener<?>) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.ConnectionManager |
From |
To |
|
Change Return Type Future<RedisPubSubConnection> to RFuture<RedisPubSubConnection> in method public connectPubSub() : RFuture<RedisPubSubConnection> in class org.redisson.connection.ClientConnectionsEntry |
From |
To |
|
Change Return Type Promise<R> to RPromise<R> in method public getAttemptPromise() : RPromise<R> in class org.redisson.command.AsyncDetails |
From |
To |
|
Change Return Type Future<Boolean> to RFuture<Boolean> in method public getAddFuture() : RFuture<Boolean> in class org.redisson.executor.RemotePromise |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public getInnerPromise() : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public addListener(listener FutureListener<? super T>) : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type Future<RedisPubSubConnection> to RFuture<RedisPubSubConnection> in method package nextPubSubConnection() : RFuture<RedisPubSubConnection> in class org.redisson.connection.SingleEntry |
From |
To |
|
Change Return Type Future<RedisPubSubConnection> to RFuture<RedisPubSubConnection> in method private registerSentinel(cfg SentinelServersConfig, addr URI, c MasterSlaveServersConfig) : RFuture<RedisPubSubConnection> in class org.redisson.connection.SentinelConnectionManager |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public removeListeners(listeners FutureListener<? super T>...) : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Return Type Future<Void> to RFuture<Void> in method public setupMasterEntry(host String, port int) : RFuture<Void> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Return Type Future<RedisPubSubConnection> to RFuture<RedisPubSubConnection> in method package nextPubSubConnection(slot int) : RFuture<RedisPubSubConnection> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Return Type Promise<R> to RPromise<R> in method public getPromise() : RPromise<R> in class org.redisson.client.protocol.CommandData |
From |
To |
|
Change Return Type Future<List<?>> to RFuture<List<?>> in method private send(timeout long, responseName String, response T) : RFuture<List<?>> in class org.redisson.RedissonRemoteService |
From |
To |
|
Change Return Type Promise<RedissonCountDownLatchEntry> to RPromise<RedissonCountDownLatchEntry> in method public getPromise() : RPromise<RedissonCountDownLatchEntry> in class org.redisson.RedissonCountDownLatchEntry |
From |
To |
|
Change Return Type Future<RedisPubSubConnection> to RFuture<RedisPubSubConnection> in method package nextPubSubConnection() : RFuture<RedisPubSubConnection> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Return Type Future<RedissonLockEntry> to RFuture<RedissonLockEntry> in method protected subscribe(threadId long) : RFuture<RedissonLockEntry> in class org.redisson.RedissonFairLock |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public addListeners(listeners FutureListener<? super T>...) : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type Future<Boolean> to RFuture<Boolean> in method public getShutdownPromise() : RFuture<Boolean> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Return Type Future<Collection<Future<Void>>> to RFuture<Collection<RFuture<Void>>> in method private addMasterEntry(partition ClusterPartition, cfg ClusterServersConfig) : RFuture<Collection<RFuture<Void>>> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Return Type Promise<Void> to RPromise<Void> in method public getPromise() : RPromise<Void> in class org.redisson.client.protocol.CommandsData |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public syncUninterruptibly() : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type Promise<RedissonLockEntry> to RPromise<RedissonLockEntry> in method public getPromise() : RPromise<RedissonLockEntry> in class org.redisson.RedissonLockEntry |
From |
To |
|
Change Return Type Publisher<R> to RFuture<R> in method public lastIndexOfAsync(o Object, convertor Convertor<R>) : RFuture<R> in class org.redisson.RedissonList |
From |
To |
|
Change Return Type Future<Boolean> to RFuture<Boolean> in method protected addAsync(requestQueue RBlockingQueue<RemoteServiceRequest>, request RemoteServiceRequest, result RemotePromise<Object>) : RFuture<Boolean> in class org.redisson.BaseRemoteService |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public removeListeners(listeners FutureListener<? super T>...) : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type List<Future<Void>> to List<RFuture<Void>> in method public initSlaveBalancer(disconnectedNodes Collection<URI>) : List<RFuture<Void>> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method private connect(cfg ClusterServersConfig, addr URI) : RFuture<RedisConnection> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectionReadOp(source NodeSource, command RedisCommand<?>) : RFuture<RedisConnection> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Return Type Future<Void> to RFuture<Void> in method private checkMasterNodesChange(cfg ClusterServersConfig, newPartitions Collection<ClusterPartition>) : RFuture<Void> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Return Type Future<R> to RFuture<R> in method public async(encoder Codec, command RedisCommand<T>, params Object...) : RFuture<R> in class org.redisson.client.RedisConnection |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public addListeners(listeners FutureListener<? super T>...) : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method private createConnection(entry ClientConnectionsEntry) : RFuture<T> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public get() : RFuture<T> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Return Type Future<Void> to RFuture<Void> in method public addSlave(host String, port int) : RFuture<Void> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Return Type Future<RedisPubSubConnection> to RFuture<RedisPubSubConnection> in method public nextPubSubConnection() : RFuture<RedisPubSubConnection> in class org.redisson.connection.balancer.LoadBalancerManager |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectionWriteOp(source NodeSource, command RedisCommand<?>) : RFuture<RedisConnection> in class org.redisson.connection.ConnectionManager |
From |
To |
|
Change Return Type Future<RedissonCountDownLatchEntry> to RFuture<RedissonCountDownLatchEntry> in method private subscribe() : RFuture<RedissonCountDownLatchEntry> in class org.redisson.RedissonCountDownLatch |
From |
To |
|
Change Return Type Future<R> to RFuture<R> in method public async(timeout long, encoder Codec, command RedisCommand<T>, params Object...) : RFuture<R> in class org.redisson.client.RedisConnection |
From |
To |
|
Change Return Type Future<Void> to RFuture<Void> in method public add(entry ClientConnectionsEntry) : RFuture<Void> in class org.redisson.connection.balancer.LoadBalancerManagerImpl |
From |
To |
|
Change Return Type Future<Boolean> to RFuture<Boolean> in method public getShutdownPromise() : RFuture<Boolean> in class org.redisson.connection.ConnectionManager |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public submit(task Runnable, result T) : RFuture<T> in class org.redisson.RedissonExecutorService |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public nextConnection() : RFuture<RedisConnection> in class org.redisson.connection.balancer.LoadBalancerManager |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectionReadOp() : RFuture<RedisConnection> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Return Type Future<PubSubConnectionEntry> to RFuture<PubSubConnectionEntry> in method public psubscribe(channelName String, codec Codec, listener RedisPubSubListener<?>, semaphore AsyncSemaphore) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Return Type Future<PubSubConnectionEntry> to RFuture<PubSubConnectionEntry> in method public subscribe(codec Codec, channelName String, listener RedisPubSubListener<?>, semaphore AsyncSemaphore) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.ConnectionManager |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public await() : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Return Type Future<Map<String,String>> to RFuture<Map<String,String>> in method public serverInfoAsync() : RFuture<Map<String,String>> in class org.redisson.client.RedisClient |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public awaitUninterruptibly() : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method protected connect(entry ClientConnectionsEntry) : RFuture<T> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method public sync() : RFuture<T> in class org.redisson.misc.RedissonFuture |
From |
To |
|
Change Return Type Future<Long> to RFuture<Long> in method private tryAcquireAsync(leaseTime long, unit TimeUnit, threadId long) : RFuture<Long> in class org.redisson.RedissonLock |
From |
To |
|
Change Return Type Future<Void> to RFuture<Void> in method public add(entry ClientConnectionsEntry) : RFuture<Void> in class org.redisson.connection.balancer.LoadBalancerManager |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectionWriteOp() : RFuture<RedisConnection> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectionReadOp() : RFuture<RedisConnection> in class org.redisson.connection.SingleEntry |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method private promiseSuccessful(entry ClientConnectionsEntry, conn T) : RFuture<T> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public connectionReadOp(source NodeSource, command RedisCommand<?>) : RFuture<RedisConnection> in class org.redisson.connection.ConnectionManager |
From |
To |
|
Change Return Type Future<RedisPubSubConnection> to RFuture<RedisPubSubConnection> in method protected connect(entry ClientConnectionsEntry) : RFuture<RedisPubSubConnection> in class org.redisson.connection.pool.PubSubConnectionPool |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public getConnection(addr InetSocketAddress) : RFuture<RedisConnection> in class org.redisson.connection.balancer.LoadBalancerManagerImpl |
From |
To |
|
Change Return Type Future<RedisConnection> to RFuture<RedisConnection> in method public nextConnection() : RFuture<RedisConnection> in class org.redisson.connection.balancer.LoadBalancerManagerImpl |
From |
To |
|
Change Return Type Promise<T> to RPromise<T> in method public await() : RPromise<T> in class org.redisson.misc.PromiseDelegator |
From |
To |
|
Change Return Type Future<T> to RFuture<T> in method private promiseFailure(entry ClientConnectionsEntry, conn T) : RFuture<T> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Variable Type f : Future<String> to f : RFuture<String> in method private ping(c RedisConnection, pingListener FutureListener<String>) : void in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Variable Type result : Promise<Void> to result : RPromise<Void> in method public add(entry ClientConnectionsEntry) : RFuture<Void> in class org.redisson.connection.balancer.LoadBalancerManagerImpl |
From |
To |
|
Change Variable Type ackClientsFuture : Future<Boolean> to ackClientsFuture : RFuture<Boolean> in method private tryPollAckAgainAsync(optionsCopy RemoteInvocationOptions, responseQueue RBlockingQueue<RemoteServiceAck>, ackName String) : RFuture<RemoteServiceAck> in class org.redisson.BaseRemoteService |
From |
To |
|
Change Variable Type future : Future<Collection<Future<Void>>> to future : RFuture<Collection<RFuture<Void>>> in method private checkMasterNodesChange(cfg ClusterServersConfig, newPartitions Collection<ClusterPartition>) : RFuture<Void> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type future : Future<Integer> to future : RFuture<Integer> in method public testPutAsyncTimeout() : void in class org.redisson.TimeoutTest |
From |
To |
|
Change Variable Type f : Future<MapCacheScanResult<ScanObjectEntry,ScanObjectEntry>> to f : RFuture<MapCacheScanResult<ScanObjectEntry,ScanObjectEntry>> in method package scanIterator(name String, client InetSocketAddress, startPos long) : MapScanResult<ScanObjectEntry,ScanObjectEntry> in class org.redisson.RedissonMapCache |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testPollAsyncCancel() : void in class org.redisson.RedissonBlockingQueueTest |
From |
To |
|
Change Variable Type res : Future<R> to res : RFuture<R> in method public write(key String, codec Codec, command RedisCommand<T>, params Object...) : R in class org.redisson.command.CommandSyncService |
From |
To |
|
Change Variable Type entry : Entry<RLock,Future<Boolean>> to entry : Entry<RLock,RFuture<Boolean>> in method protected sync(tryLockFutures Map<RLock,RFuture<Boolean>>) : boolean in class org.redisson.RedissonRedLock |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public readReactive(client InetSocketAddress, key String, codec Codec, command RedisCommand<T>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testPollAsyncReattach() : void in class org.redisson.RedissonBlockingQueueTest |
From |
To |
|
Change Variable Type initFuture : Promise<Void> to initFuture : RPromise<Void> in method public operationComplete(future Future<Map<String,String>>) : void in class org.redisson.cluster.ClusterConnectionManager.addMasterEntry.addListener.operationComplete.addListener |
From |
To |
|
Change Variable Type connectionFuture : Future<RedisConnection> to connectionFuture : RFuture<RedisConnection> in method private addMasterEntry(partition ClusterPartition, cfg ClusterServersConfig) : RFuture<Collection<RFuture<Void>>> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type fs : List<Future<Void>> to fs : List<RFuture<Void>> in method public operationComplete(future Future<Map<String,String>>) : void in class org.redisson.cluster.ClusterConnectionManager.addMasterEntry.addListener.operationComplete.addListener |
From |
To |
|
Change Variable Type tryAcquireFuture : Future<Boolean> to tryAcquireFuture : RFuture<Boolean> in method private tryAcquireAsync(time AtomicLong, permits int, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Boolean>) : void in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Variable Type future : Future<Boolean> to future : RFuture<Boolean> in method public run(timeout Timeout) : void in class org.redisson.RedissonLock.scheduleExpirationRenewal.task.newTimeout |
From |
To |
|
Change Variable Type r : Future<Collection<String>> to r : RFuture<Collection<String>> in method public findBuckets(pattern String) : List<RBucketReactive<V>> in class org.redisson.RedissonReactive |
From |
To |
|
Change Variable Type futures : List<Future<Collection<Future<Void>>>> to futures : List<RFuture<Collection<RFuture<Void>>>> in method public ClusterConnectionManager(cfg ClusterServersConfig, config Config) in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type future : Future<RedisConnection> to future : RFuture<RedisConnection> in method public connect() : RFuture<RedisConnection> in class org.redisson.connection.ClientConnectionsEntry |
From |
To |
|
Change Variable Type connectionFuture : Future<RedisConnection> to connectionFuture : RFuture<RedisConnection> in method private checkClusterState(cfg ClusterServersConfig, iterator Iterator<URI>, lastException AtomicReference<Throwable>) : void in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type promise : Promise<Void> to promise : RPromise<Void> in method public add(entry ClientConnectionsEntry) : RFuture<Void> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Variable Type ackClientsFuture : Future<Boolean> to ackClientsFuture : RFuture<Boolean> in method public operationComplete(future Future<RemoteServiceRequest>) : void in class org.redisson.RedissonRemoteService.subscribe.addListener |
From |
To |
|
Change Variable Type promise : Promise<Void> to promise : RPromise<Void> in method private decodeCommandBatch(ctx ChannelHandlerContext, in ByteBuf, data QueueCommand, commandBatch CommandsData) : void in class org.redisson.client.handler.CommandDecoder |
From |
To |
|
Change Variable Type promise : Promise<Boolean> to promise : RPromise<Boolean> in method protected addAsync(requestQueue RBlockingQueue<RemoteServiceRequest>, request RemoteServiceRequest, result RemotePromise<Object>) : RFuture<Boolean> in class org.redisson.executor.ExecutorRemoteService |
From |
To |
|
Change Variable Type promise : Promise<Integer> to promise : RPromise<Integer> in method public addListener(listener PatternMessageListener<M>) : Publisher<Integer> in class org.redisson.reactive.RedissonPatternTopicReactive |
From |
To |
|
Change Variable Type future : Future<PubSubConnectionEntry> to future : RFuture<PubSubConnectionEntry> in method private addListener(pubSubListener RedisPubSubListener<M>, promise RPromise<Integer>) : void in class org.redisson.reactive.RedissonPatternTopicReactive |
From |
To |
|
Change Variable Type nodeFuture : Future<Void> to nodeFuture : RFuture<Void> in method private checkMasterNodesChange(cfg ClusterServersConfig, newPartitions Collection<ClusterPartition>) : RFuture<Void> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type subscribeFuture : Future<RedissonLockEntry> to subscribeFuture : RFuture<RedissonLockEntry> in method public acquireAsync(permits int) : RFuture<Void> in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Variable Type promise : Promise<Void> to promise : RPromise<Void> in method public operationComplete(connFuture Future<RedisConnection>) : void in class org.redisson.command.CommandAsyncService.async.addListener |
From |
To |
|
Change Variable Type future : Future<Boolean> to future : RFuture<Boolean> in method protected addAsync(requestQueue RBlockingQueue<RemoteServiceRequest>, request RemoteServiceRequest, result RemotePromise<Object>) : RFuture<Boolean> in class org.redisson.executor.ExecutorRemoteService |
From |
To |
|
Change Variable Type future : Promise<RedisConnection> to future : RPromise<RedisConnection> in method private connect(cfg ElasticacheServersConfig, addr URI) : RedisConnection in class org.redisson.connection.ElasticacheConnectionManager |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method public testExecutorAsync() : void in class org.redisson.RedissonRemoteServiceTest |
From |
To |
|
Change Variable Type promise : Future<RedissonCountDownLatchEntry> to promise : RFuture<RedissonCountDownLatchEntry> in method public await() : void in class org.redisson.RedissonCountDownLatch |
From |
To |
|
Change Variable Type fs : List<Future<Void>> to fs : List<RFuture<Void>> in method protected createMasterSlaveEntry(config MasterSlaveServersConfig, slots HashSet<ClusterSlotRange>) : MasterSlaveEntry in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type result : List<Future<Void>> to result : List<RFuture<Void>> in method public initSlaveBalancer(disconnectedNodes Collection<URI>) : List<RFuture<Void>> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Variable Type future : Future<Integer> to future : RFuture<Integer> in method public testPutAsync() : void in class org.redisson.RedissonMapCacheTest |
From |
To |
|
Change Variable Type f : Future<Collection<R>> to f : RFuture<Collection<R>> in method public readAllReactive(command RedisCommand<T>, params Object...) : Publisher<Collection<R>> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type future : Future<RedissonLockEntry> to subscribeFuture : RFuture<RedissonLockEntry> in method public tryLock(waitTime long, leaseTime long, unit TimeUnit) : boolean in class org.redisson.RedissonLock |
From |
To |
|
Change Variable Type future : Future<PubSubConnectionEntry> to future : RFuture<PubSubConnectionEntry> in method private addListener(pubSubListener RedisPubSubListener<?>) : int in class org.redisson.RedissonTopic |
From |
To |
|
Change Variable Type connectionFuture : Future<RedisConnection> to connectionFuture : RFuture<RedisConnection> in method public ClusterConnectionManager(cfg ClusterServersConfig, config Config) in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type connFuture : Future<T> to connFuture : RFuture<T> in method private createConnection(entry ClientConnectionsEntry) : RFuture<T> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Variable Type tryAcquireFuture : Future<Boolean> to tryAcquireFuture : RFuture<Boolean> in method public acquireAsync(permits int) : RFuture<Void> in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testTakeReattach() : void in class org.redisson.RedissonBoundedBlockingQueueTest |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public evalWriteAllReactive(command RedisCommand<T>, callback SlotCallback<T,R>, script String, keys List<Object>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type future : Future<Boolean> to future : RFuture<Boolean> in method public testAddAsync() : void in class org.redisson.RedissonScoredSortedSetTest |
From |
To |
|
Change Variable Type temp : Future<Void> to temp : RFuture<Void> in method public operationComplete(future Future<RedisConnection>) : void in class org.redisson.connection.pool.ConnectionPool.scheduleCheck.newTimeout.run.addListener |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public readRandomReactive(command RedisCommand<T>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method public initSlaveBalancer(disconnectedNodes Collection<URI>) : List<RFuture<Void>> in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Variable Type result : Promise<PubSubConnectionEntry> to result : RPromise<PubSubConnectionEntry> in method public psubscribe(channelName String, codec Codec, listener RedisPubSubListener<?>) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type res : Future<R> to res : RFuture<R> in method public write(slot Integer, codec Codec, command RedisCommand<T>, params Object...) : R in class org.redisson.command.CommandSyncService |
From |
To |
|
Change Variable Type promise : Promise<R> to promise : RPromise<R> in method public readAllAsync(command RedisCommand<T>, params Object...) : RFuture<Collection<R>> in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Variable Type connectionFuture : Promise<RedisConnection> to connectionFuture : RPromise<RedisConnection> in method public operationComplete(future Future<RedisConnection>) : void in class org.redisson.RedisNodes.pingAll.addListener |
From |
To |
|
Change Variable Type r : Future<String> to r : RFuture<String> in method public operationComplete(future Future<RedisConnection>) : void in class org.redisson.RedisNodes.pingAll.addListener.operationComplete.addListener |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testPollAsyncReattach() : void in class org.redisson.RedissonBoundedBlockingQueueTest |
From |
To |
|
Change Variable Type result : Promise<RedisConnection> to result : RPromise<RedisConnection> in method private connect(cfg ClusterServersConfig, addr URI) : RFuture<RedisConnection> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type a : Future<Long> to a : RFuture<Long> in method public testOrdering() : void in class org.redisson.RedissonBatchTest |
From |
To |
|
Change Variable Type connectionFuture : Promise<RedisConnection> to connectionFuture : RPromise<RedisConnection> in method private addReconnectListener(connectionFuture RPromise<T>, conn T) : void in class org.redisson.connection.ClientConnectionsEntry |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method public writeAllReactive(command RedisCommand<T>, params Object...) : Publisher<Void> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type future : Future<Collection<Future<Void>>> to future : Future<Collection<RFuture<Void>>> in method private checkMasterNodesChange(cfg ClusterServersConfig, newPartitions Collection<ClusterPartition>) : RFuture<Void> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type future1 : Future<Integer> to future1 : RFuture<Integer> in method public testPutAsync() : void in class org.redisson.RedissonMapTest |
From |
To |
|
Change Variable Type futures : List<Future<Integer>> to futures : List<RFuture<Integer>> in method public testGetAsyncTimeout() : void in class org.redisson.TimeoutTest |
From |
To |
|
Change Variable Type val1 : Future<Object> to val1 : RFuture<Object> in method public testDifferentCodecs() : void in class org.redisson.RedissonBatchTest |
From |
To |
|
Change Variable Type f : Future<RedisConnection> to f : RFuture<RedisConnection> in method public testConnectAsync() : void in class org.redisson.RedisClientTest |
From |
To |
|
Change Variable Type future : Future<PubSubConnectionEntry> to future : RFuture<PubSubConnectionEntry> in method public subscribe(codec Codec, channelName String, listener RedisPubSubListener<?>) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type promise : Promise<T> to promise : RPromise<T> in method public evalAllAsync(readOnlyMode boolean, command RedisCommand<T>, callback SlotCallback<T,R>, script String, keys List<Object>, params Object...) : RFuture<R> in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Variable Type connectionFuture : Promise<RedisConnection> to connectionFuture : RPromise<RedisConnection> in method public connect() : RFuture<RedisConnection> in class org.redisson.connection.ClientConnectionsEntry |
From |
To |
|
Change Variable Type subscribeFuture : Future<RedissonLockEntry> to subscribeFuture : RFuture<RedissonLockEntry> in method public operationComplete(future Future<Boolean>) : void in class org.redisson.RedissonSemaphore.tryAcquireAsync.addListener |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testTakeReattach() : void in class org.redisson.RedissonBlockingQueueTest |
From |
To |
|
Change Variable Type promise : Future<T> to promise : RFuture<T> in method private createConnection(checkFreezed boolean, requests AtomicInteger, entry ClientConnectionsEntry, initPromise RPromise<Void>, minimumIdleSize int, initializedConnections AtomicInteger) : void in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testTakeAsyncCancel() : void in class org.redisson.RedissonBoundedBlockingQueueTest |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method public operationComplete(future Future<Map<String,String>>) : void in class org.redisson.cluster.ClusterConnectionManager.addMasterEntry.addListener.operationComplete.addListener |
From |
To |
|
Change Variable Type f1 : Future<Long> to f1 : RFuture<Long> in method public run() : void in class org.redisson.RedissonBatchTest.testOrdering.execute |
From |
To |
|
Change Variable Type promise : Promise<T> to promise : RPromise<T> in method private createConnection(entry ClientConnectionsEntry) : RFuture<T> in class org.redisson.connection.pool.ConnectionPool |
From |
To |
|
Change Variable Type r : Future<String> to r : RFuture<String> in method public testScriptLoadAsync() : void in class org.redisson.RedissonScriptTest |
From |
To |
|
Change Variable Type future : Future<Void> to future : RFuture<Void> in method protected createMasterSlaveEntry(config MasterSlaveServersConfig, slots HashSet<ClusterSlotRange>) : MasterSlaveEntry in class org.redisson.connection.SentinelConnectionManager |
From |
To |
|
Change Variable Type resFuture : Future<Long> to resFuture : RFuture<Long> in method public testAsync() : void in class org.redisson.RedissonRemoteServiceTest |
From |
To |
|
Change Variable Type future : Future<Boolean> to future : RFuture<Boolean> in method protected addAsync(requestQueue RBlockingQueue<RemoteServiceRequest>, request RemoteServiceRequest, result RemotePromise<Object>) : RFuture<Boolean> in class org.redisson.BaseRemoteService |
From |
To |
|
Change Variable Type connectionFuture : Future<RedisConnection> to connectionFuture : RFuture<RedisConnection> in method protected async(readOnlyMode boolean, source NodeSource, codec Codec, command RedisCommand<V>, params Object[], mainPromise RPromise<R>, attempt int) : void in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Variable Type unlockFuture : Future<Void> to unlockFuture : RFuture<Void> in method protected unlockInner(locks Collection<RLock>) : void in class org.redisson.RedissonMultiLock |
From |
To |
|
Change Variable Type result : Map<RedisConnection,Future<String>> to result : Map<RedisConnection,RFuture<String>> in method public pingAll() : boolean in class org.redisson.RedisNodes |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method protected createMasterSlaveEntry(config MasterSlaveServersConfig, slots HashSet<ClusterSlotRange>) : MasterSlaveEntry in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type future : Future<Map<String,V>> to future : RFuture<Map<String,V>> in method public get(keys String...) : Map<String,V> in class org.redisson.RedissonBuckets |
From |
To |
|
Change Variable Type future : Future<RedissonLockEntry> to future : RFuture<RedissonLockEntry> in method public acquire(permits int) : void in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Variable Type future : Promise<Map<String,String>> to future : Future<Map<String,String>> in method public serverInfoAsync() : RFuture<Map<String,String>> in class org.redisson.client.RedisClient |
From |
To |
|
Change Variable Type future : Future<Boolean> to future : RFuture<Boolean> in method public unlockAsync(threadId long) : RFuture<Void> in class org.redisson.RedissonLock |
From |
To |
|
Change Variable Type newConnection : Future<RedisConnection> to newConnection : RFuture<RedisConnection> in method private reattachBlockingQueue(connection RedisConnection) : void in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Variable Type cancelRequestFuture : Future<RemoteServiceCancelRequest> to cancelRequestFuture : RFuture<RemoteServiceCancelRequest> in method private executeMethod(remoteInterface Class<T>, requestQueue RBlockingQueue<RemoteServiceRequest>, executor ExecutorService, request RemoteServiceRequest) : void in class org.redisson.RedissonRemoteService |
From |
To |
|
Change Variable Type attemptPromise : Promise<R> to attemptPromise : RPromise<R> in method protected async(readOnlyMode boolean, source NodeSource, codec Codec, command RedisCommand<V>, params Object[], mainPromise RPromise<R>, attempt int) : void in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Variable Type f : Future<MapScanResult<ScanObjectEntry,ScanObjectEntry>> to f : RFuture<MapScanResult<ScanObjectEntry,ScanObjectEntry>> in method package scanIterator(client InetSocketAddress, startPos long) : MapScanResult<ScanObjectEntry,ScanObjectEntry> in class org.redisson.RedissonMultimap |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public writeReactive(key String, codec Codec, command RedisCommand<T>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type f : Future<String> to f : RFuture<String> in method public pingAll() : boolean in class org.redisson.RedisNodes |
From |
To |
|
Change Variable Type future : Future<Integer> to future : RFuture<Integer> in method public run() : void in class org.redisson.EvictionScheduler.RedissonCacheTask |
From |
To |
|
Change Variable Type attemptPromise : Promise<Void> to attemptPromise : RPromise<Void> in method public execute(entry Entry, source NodeSource, mainPromise RPromise<Void>, slots AtomicInteger, attempt int) : void in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Variable Type pollFuture : Future<RemoteServiceAck> to pollFuture : RFuture<RemoteServiceAck> in method private tryPollAckAgainAsync(optionsCopy RemoteInvocationOptions, responseQueue RBlockingQueue<RemoteServiceAck>, ackName String) : RFuture<RemoteServiceAck> in class org.redisson.BaseRemoteService |
From |
To |
|
Change Variable Type tryLockFutures : Map<RLock,Future<Boolean>> to tryLockFutures : Map<RLock,RFuture<Boolean>> in method public tryLock() : boolean in class org.redisson.RedissonMultiLock |
From |
To |
|
Change Variable Type futures : List<Future<Void>> to futures : List<RFuture<Void>> in method public operationComplete(future Future<Map<String,String>>) : void in class org.redisson.cluster.ClusterConnectionManager.addMasterEntry.addListener.operationComplete.addListener |
From |
To |
|
Change Variable Type result : Promise<PubSubConnectionEntry> to result : RPromise<PubSubConnectionEntry> in method public subscribe(codec Codec, channelName String, listener RedisPubSubListener<?>) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type ttlFuture : Future<Long> to ttlFuture : RFuture<Long> in method private tryLockAsync(time AtomicLong, leaseTime long, unit TimeUnit, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Boolean>, currentThreadId long) : void in class org.redisson.RedissonLock |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method public testCancelAsync() : void in class org.redisson.RedissonRemoteServiceTest |
From |
To |
|
Change Variable Type resFuture : Future<Long> to resFuture : RFuture<Long> in method public testExecutorAsync() : void in class org.redisson.RedissonRemoteServiceTest |
From |
To |
|
Change Variable Type future : Future<PubSubConnectionEntry> to future : RFuture<PubSubConnectionEntry> in method public psubscribe(channelName String, codec Codec, listener RedisPubSubListener<?>) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type future : Promise<RedisConnection> to future : RPromise<RedisConnection> in method private connect() : RedisConnection in class org.redisson.connection.RedisClientEntry |
From |
To |
|
Change Variable Type voidPromise : Promise<Void> to voidPromise : RPromise<Void> in method public executeAsync() : RFuture<List<?>> in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Variable Type result : Promise<Collection<Future<Void>>> to result : RPromise<Collection<RFuture<Void>>> in method private addMasterEntry(partition ClusterPartition, cfg ClusterServersConfig) : RFuture<Collection<RFuture<Void>>> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type f : Future<ListScanResult<V>> to f : RFuture<ListScanResult<V>> in method private scanIterator(client InetSocketAddress, startPos long) : ListScanResult<V> in class org.redisson.RedissonScoredSortedSet |
From |
To |
|
Change Variable Type connectionFutures : List<Future<RedisPubSubConnection>> to connectionFutures : List<RFuture<RedisPubSubConnection>> in method public SentinelConnectionManager(cfg SentinelServersConfig, config Config) in class org.redisson.connection.SentinelConnectionManager |
From |
To |
|
Change Variable Type writeFuture : Future<RedisConnection> to writeFuture : RFuture<RedisConnection> in method private retrieveAdresses() : void in class org.redisson.RedissonNode |
From |
To |
|
Change Variable Type newPromise : Promise<E> to newPromise : RPromise<E> in method public subscribe(entryName String, channelName String, connectionManager ConnectionManager) : RFuture<E> in class org.redisson.pubsub.PublishSubscribe |
From |
To |
|
Change Variable Type val2 : Future<Object> to val2 : RFuture<Object> in method public testDifferentCodecs() : void in class org.redisson.RedissonBatchTest |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testTakeAsyncCancel() : void in class org.redisson.RedissonBlockingQueueTest |
From |
To |
|
Change Variable Type slaveFuture : Future<Void> to slaveFuture : RFuture<Void> in method public add(entry ClientConnectionsEntry) : RFuture<Void> in class org.redisson.connection.balancer.LoadBalancerManagerImpl |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public evalWriteReactive(key String, codec Codec, evalCommandType RedisCommand<T>, script String, keys List<Object>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type promise : Promise<Void> to promise : RPromise<Void> in method public operationComplete(future Future<String>) : void in class org.redisson.connection.pool.ConnectionPool.scheduleCheck.newTimeout.run.addListener.operationComplete.pingListener |
From |
To |
|
Change Variable Type res : Future<V> to res : RFuture<V> in method public take() : V in class org.redisson.RedissonBlockingQueue |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public readReactive(key String, codec Codec, command RedisCommand<T>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type future : Future<RedissonLockEntry> to future : RFuture<RedissonLockEntry> in method public lockInterruptibly(leaseTime long, unit TimeUnit) : void in class org.redisson.RedissonLock |
From |
To |
|
Change Variable Type promise : Promise<T> to promise : RPromise<T> in method private allAsync(readOnlyMode boolean, command RedisCommand<T>, callback SlotCallback<T,R>, params Object...) : RFuture<R> in class org.redisson.command.CommandAsyncService |
From |
To |
|
Change Variable Type masterFuture : Future<Void> to masterFuture : RFuture<Void> in method public operationComplete(future Future<List<ClusterNodeInfo>>) : void in class org.redisson.cluster.ClusterConnectionManager.updateClusterState.addListener |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testPollWithBrokenConnection() : void in class org.redisson.RedissonBlockingQueueTest |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method public setupMasterEntry(host String, port int) : RFuture<Void> in class org.redisson.connection.SingleEntry |
From |
To |
|
Change Variable Type ttlFuture : Future<Long> to ttlFuture : RFuture<Long> in method public tryLockAsync(waitTime long, leaseTime long, unit TimeUnit, currentThreadId long) : RFuture<Boolean> in class org.redisson.RedissonLock |
From |
To |
|
Change Variable Type addFuture : Future<Boolean> to addFuture : RFuture<Boolean> in method public invoke(proxy Object, method Method, args Object[]) : Object in class org.redisson.BaseRemoteService.async.handler |
From |
To |
|
Change Variable Type promise : Promise<Integer> to promise : RPromise<Integer> in method private addListener(pubSubListener RedisPubSubListener<?>) : Publisher<Integer> in class org.redisson.reactive.RedissonTopicReactive |
From |
To |
|
Change Variable Type res : Future<R> to res : RFuture<R> in method public write(key String, command RedisCommand<T>, params Object...) : R in class org.redisson.command.CommandSyncService |
From |
To |
|
Change Variable Type take : Future<RemoteServiceRequest> to take : RFuture<RemoteServiceRequest> in method private subscribe(remoteInterface Class<T>, requestQueue RBlockingQueue<RemoteServiceRequest>, executor ExecutorService) : void in class org.redisson.RedissonRemoteService |
From |
To |
|
Change Variable Type readFuture : Future<RedisConnection> to readFuture : RFuture<RedisConnection> in method private retrieveAdresses() : void in class org.redisson.RedissonNode |
From |
To |
|
Change Variable Type ttlFuture : Future<Long> to ttlFuture : RFuture<Long> in method private lockAsync(leaseTime long, unit TimeUnit, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Void>, currentThreadId long) : void in class org.redisson.RedissonLock |
From |
To |
|
Change Variable Type promise : Promise<RedisConnection> to promise : RPromise<RedisConnection> in method public operationComplete(future Future<RedisConnection>) : void in class org.redisson.cluster.ClusterConnectionManager.connect.addListener |
From |
To |
|
Change Variable Type responseFuture : Future<RRemoteServiceResponse> to responseFuture : RFuture<RRemoteServiceResponse> in method protected awaitResultAsync(optionsCopy RemoteInvocationOptions, result RemotePromise<Object>, request RemoteServiceRequest, responseName String) : void in class org.redisson.BaseRemoteService |
From |
To |
|
Change Variable Type res : Promise<Void> to res : RPromise<Void> in method public setupMasterEntry(host String, port int) : RFuture<Void> in class org.redisson.connection.SingleEntry |
From |
To |
|
Change Variable Type future : Future<Boolean> to future : RFuture<Boolean> in method public testAddAsync() : void in class org.redisson.RedissonSortedSetTest |
From |
To |
|
Change Variable Type cardinalityFuture : Future<Long> to cardinalityFuture : RFuture<Long> in method public count() : int in class org.redisson.RedissonBloomFilter |
From |
To |
|
Change Variable Type future : Future<Integer> to future : RFuture<Integer> in method public testGetAsyncTimeout() : void in class org.redisson.TimeoutTest |
From |
To |
|
Change Variable Type res : Future<R> to res : RFuture<R> in method public read(key String, codec Codec, command RedisCommand<T>, params Object...) : R in class org.redisson.command.CommandSyncService |
From |
To |
|
Change Variable Type tryLockFutures : Map<RLock,Future<Boolean>> to tryLockFutures : Map<RLock,RFuture<Boolean>> in method public tryLock(waitTime long, leaseTime long, unit TimeUnit) : boolean in class org.redisson.RedissonMultiLock |
From |
To |
|
Change Variable Type promise : Promise<Integer> to promise : RPromise<Integer> in method public addListener(listener PatternStatusListener) : Publisher<Integer> in class org.redisson.reactive.RedissonPatternTopicReactive |
From |
To |
|
Change Variable Type future : Future<PubSubConnectionEntry> to future : RFuture<PubSubConnectionEntry> in method private reattachPatternPubSubListeners(channelName String, listeners Collection<RedisPubSubListener<?>>) : void in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public evalReadReactive(client InetSocketAddress, key String, codec Codec, evalCommandType RedisCommand<T>, script String, keys List<Object>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type tryAcquireFuture : Future<Boolean> to tryAcquireFuture : RFuture<Boolean> in method private acquireAsync(permits int, subscribeFuture RFuture<RedissonLockEntry>, result RPromise<Void>) : void in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Variable Type future : Future<Object> to future : RFuture<Object> in method public submit(task Runnable, result T) : RFuture<T> in class org.redisson.RedissonExecutorService |
From |
To |
|
Change Variable Type futures : List<Future<Void>> to futures : List<RFuture<Void>> in method public unlock() : void in class org.redisson.RedissonMultiLock |
From |
To |
|
Change Variable Type future : Future<Boolean> to future : RFuture<Boolean> in method public cancel(mayInterruptIfRunning boolean) : boolean in class org.redisson.BaseRemoteService.async.handler.invoke.result |
From |
To |
|
Change Variable Type entry : Entry<RedisConnection,Future<String>> to entry : Entry<RedisConnection,RFuture<String>> in method public pingAll() : boolean in class org.redisson.RedisNodes |
From |
To |
|
Change Variable Type result : Promise<Void> to result : RPromise<Void> in method private checkMasterNodesChange(cfg ClusterServersConfig, newPartitions Collection<ClusterPartition>) : RFuture<Void> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type future : Future<PubSubConnectionEntry> to future : RFuture<PubSubConnectionEntry> in method private addListener(pubSubListener RedisPubSubListener<?>) : int in class org.redisson.RedissonPatternTopic |
From |
To |
|
Change Variable Type r1 : Future<Object> to r1 : RFuture<Object> in method public testEvalshaAsync() : void in class org.redisson.RedissonScriptTest |
From |
To |
|
Change Variable Type promise : Promise<Void> to promise : RPromise<Void> in method private checkConnectionFuture(entry Entry, source NodeSource, mainPromise RPromise<Void>, attemptPromise RPromise<Void>, details AsyncDetails, connFuture RFuture<RedisConnection>) : void in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Variable Type f : Future<RedisConnection> to f : RFuture<RedisConnection> in method public pingAll() : boolean in class org.redisson.RedisNodes |
From |
To |
|
Change Variable Type future1 : Future<Integer> to future1 : RFuture<Integer> in method public testPutAsync() : void in class org.redisson.RedissonMapCacheTest |
From |
To |
|
Change Variable Type subscribeFuture : Future<PubSubConnectionEntry> to subscribeFuture : RFuture<PubSubConnectionEntry> in method private reattachPubSubListeners(channelName String, listeners Collection<RedisPubSubListener<?>>) : void in class org.redisson.connection.MasterSlaveEntry |
From |
To |
|
Change Variable Type res : Future<R> to res : RFuture<R> in method public read(client InetSocketAddress, key String, command RedisCommand<T>, params Object...) : R in class org.redisson.command.CommandSyncService |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method protected createMasterSlaveEntry(config MasterSlaveServersConfig, slots HashSet<ClusterSlotRange>) : MasterSlaveEntry in class org.redisson.connection.SentinelConnectionManager |
From |
To |
|
Change Variable Type ttlFuture : Future<Long> to ttlFuture : RFuture<Long> in method public lockAsync(leaseTime long, unit TimeUnit, currentThreadId long) : RFuture<Void> in class org.redisson.RedissonLock |
From |
To |
|
Change Variable Type future : Future<RedisPubSubConnection> to future : RFuture<RedisPubSubConnection> in method public connectPubSub() : RFuture<RedisPubSubConnection> in class org.redisson.connection.ClientConnectionsEntry |
From |
To |
|
Change Variable Type promise : Promise<PubSubConnectionEntry> to promise : RPromise<PubSubConnectionEntry> in method public subscribe(codec Codec, channelName String, listener RedisPubSubListener<?>, semaphore AsyncSemaphore) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type resultFuture : Promise<T> to resultFuture : RPromise<T> in method public submit(task Runnable, result T) : RFuture<T> in class org.redisson.RedissonExecutorService |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public evalReadReactive(key String, codec Codec, evalCommandType RedisCommand<T>, script String, keys List<Object>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type subscribeFuture : Future<RedissonLockEntry> to subscribeFuture : RFuture<RedissonLockEntry> in method public lockAsync(leaseTime long, unit TimeUnit, currentThreadId long) : RFuture<Void> in class org.redisson.RedissonLock |
From |
To |
|
Change Variable Type future : Future<RedissonLockEntry> to future : RFuture<RedissonLockEntry> in method public tryAcquire(permits int, waitTime long, unit TimeUnit) : boolean in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Variable Type res : Future<R> to res : RFuture<R> in method public evalWrite(key String, codec Codec, evalCommandType RedisCommand<T>, script String, keys List<Object>, params Object...) : R in class org.redisson.command.CommandSyncService |
From |
To |
|
Change Variable Type future : Future<PubSubConnectionEntry> to future : RFuture<PubSubConnectionEntry> in method private addListener(pubSubListener RedisPubSubListener<?>) : Publisher<Integer> in class org.redisson.reactive.RedissonTopicReactive |
From |
To |
|
Change Variable Type connectionFuture : Future<RedisConnection> to connectionFuture : RFuture<RedisConnection> in method public run(timeout Timeout) : void in class org.redisson.connection.pool.ConnectionPool.scheduleCheck.newTimeout |
From |
To |
|
Change Variable Type ackFutureAttempt : Future<RemoteServiceAck> to ackFutureAttempt : RFuture<RemoteServiceAck> in method public operationComplete(future Future<RemoteServiceAck>) : void in class org.redisson.BaseRemoteService.async.handler.invoke.addListener.operationComplete.addListener |
From |
To |
|
Change Variable Type res : Future<V> to res : RFuture<V> in method public pollLastAndOfferFirstTo(queueName String, timeout long, unit TimeUnit) : V in class org.redisson.RedissonBlockingQueue |
From |
To |
|
Change Variable Type future : Future<Boolean> to future : RFuture<Boolean> in method public testAddAsync() : void in class org.redisson.RedissonSetTest |
From |
To |
|
Change Variable Type connectionFuture : Promise<RedisPubSubConnection> to connectionFuture : RPromise<RedisPubSubConnection> in method public connectPubSub() : RFuture<RedisPubSubConnection> in class org.redisson.connection.ClientConnectionsEntry |
From |
To |
|
Change Variable Type futures : List<Future<Integer>> to futures : List<RFuture<Integer>> in method public testPutAsyncTimeout() : void in class org.redisson.TimeoutTest |
From |
To |
|
Change Variable Type futures : List<Future<Long>> to futures : List<RFuture<Long>> in method public testOrdering() : void in class org.redisson.RedissonBatchTest |
From |
To |
|
Change Variable Type tryAcquireFuture : Future<Boolean> to tryAcquireFuture : RFuture<Boolean> in method public tryAcquireAsync(permits int, waitTime long, unit TimeUnit) : RFuture<Boolean> in class org.redisson.RedissonSemaphore |
From |
To |
|
Change Variable Type future : Future<Void> to future : RFuture<Void> in method public ClusterConnectionManager(cfg ClusterServersConfig, config Config) in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type connFuture : Future<RedisPubSubConnection> to connFuture : RFuture<RedisPubSubConnection> in method private connect(codec Codec, channelName String, listener RedisPubSubListener<?>, promise RPromise<PubSubConnectionEntry>, type PubSubType, lock AsyncSemaphore) : void in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testPollAsyncCancel() : void in class org.redisson.RedissonBoundedBlockingQueueTest |
From |
To |
|
Change Variable Type future : Future<Void> to future : RFuture<Void> in method public unlock() : void in class org.redisson.RedissonMultiLock |
From |
To |
|
Change Variable Type promise : Future<RedissonCountDownLatchEntry> to promise : RFuture<RedissonCountDownLatchEntry> in method public await(time long, unit TimeUnit) : boolean in class org.redisson.RedissonCountDownLatch |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public writeReactive(entry MasterSlaveEntry, codec Codec, command RedisCommand<T>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type future : Future<Object> to future : RFuture<Object> in method public addCommand(command RedisCommand<?>, params Object...) : void in class org.redisson.connection.FutureConnectionListener |
From |
To |
|
Change Variable Type future : Future<List<?>> to future : RFuture<List<?>> in method public deleteAsync(keys String...) : RFuture<Long> in class org.redisson.RedissonKeys |
From |
To |
|
Change Variable Type future : Future<Void> to future : RFuture<Void> in method protected createMasterSlaveEntry(config MasterSlaveServersConfig, slots HashSet<ClusterSlotRange>) : MasterSlaveEntry in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type deleteFuture : Future<Boolean> to deleteFuture : RFuture<Boolean> in method private awaitResultAsync(optionsCopy RemoteInvocationOptions, result RemotePromise<Object>, request RemoteServiceRequest, responseName String, ackName String) : void in class org.redisson.BaseRemoteService |
From |
To |
|
Change Variable Type ackFuture : Future<RemoteServiceAck> to ackFuture : RFuture<RemoteServiceAck> in method public operationComplete(future Future<Boolean>) : void in class org.redisson.BaseRemoteService.async.handler.invoke.addListener |
From |
To |
|
Change Variable Type async : Promise<Map<String,String>> to async : RFuture<Map<String,String>> in method public serverInfoAsync() : RFuture<Map<String,String>> in class org.redisson.client.RedisClient |
From |
To |
|
Change Variable Type connectionFuture : Future<RedisConnection> to connectionFuture : RFuture<RedisConnection> in method public execute(entry Entry, source NodeSource, mainPromise RPromise<Void>, slots AtomicInteger, attempt int) : void in class org.redisson.command.CommandBatchService |
From |
To |
|
Change Variable Type future : Future<Map<String,String>> to future : RFuture<Map<String,String>> in method private readConfig() : void in class org.redisson.RedissonBloomFilter |
From |
To |
|
Change Variable Type futures : Queue<Future<Void>> to futures : Queue<RFuture<Void>> in method private checkMasterNodesChange(cfg ClusterServersConfig, newPartitions Collection<ClusterPartition>) : RFuture<Void> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type future : Future<RedisPubSubConnection> to future : RFuture<RedisPubSubConnection> in method public SentinelConnectionManager(cfg SentinelServersConfig, config Config) in class org.redisson.connection.SentinelConnectionManager |
From |
To |
|
Change Variable Type f : Future<Integer> to f : RFuture<Integer> in method public testPollWithBrokenConnection() : void in class org.redisson.RedissonBoundedBlockingQueueTest |
From |
To |
|
Change Variable Type promise : Promise<RemoteServiceAck> to promise : RPromise<RemoteServiceAck> in method private tryPollAckAgainAsync(optionsCopy RemoteInvocationOptions, responseQueue RBlockingQueue<RemoteServiceAck>, ackName String) : RFuture<RemoteServiceAck> in class org.redisson.BaseRemoteService |
From |
To |
|
Change Variable Type ttlRemainingFuture : Future<Long> to ttlRemainingFuture : RFuture<Long> in method private tryAcquireAsync(leaseTime long, unit TimeUnit, threadId long) : RFuture<Long> in class org.redisson.RedissonLock |
From |
To |
|
Change Variable Type subscribeFuture : Future<RedissonLockEntry> to subscribeFuture : RFuture<RedissonLockEntry> in method public operationComplete(future Future<Long>) : void in class org.redisson.RedissonLock.tryLockAsync.addListener |
From |
To |
|
Change Variable Type future : Future<Void> to future : RFuture<Void> in method private addRemoveSlaves(entry MasterSlaveEntry, currentPart ClusterPartition, newPart ClusterPartition) : void in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type futures : List<Future<Void>> to futures : List<RFuture<Void>> in method protected unlockInner(locks Collection<RLock>) : void in class org.redisson.RedissonMultiLock |
From |
To |
|
Change Variable Type f : Future<R> to f : RFuture<R> in method public writeAllReactive(command RedisCommand<T>, callback SlotCallback<T,R>, params Object...) : Publisher<R> in class org.redisson.command.CommandReactiveService |
From |
To |
|
Change Variable Type ackClientsFuture : Future<Boolean> to ackClientsFuture : RFuture<Boolean> in method private tryPollAckAgain(optionsCopy RemoteInvocationOptions, responseQueue RBlockingQueue<? extends RRemoteServiceResponse>, ackName String) : RemoteServiceAck in class org.redisson.BaseRemoteService |
From |
To |
|
Change Variable Type fs : List<Future<Void>> to fs : List<RFuture<Void>> in method protected createMasterSlaveEntry(config MasterSlaveServersConfig, slots HashSet<ClusterSlotRange>) : MasterSlaveEntry in class org.redisson.connection.SentinelConnectionManager |
From |
To |
|
Change Variable Type cancelledFuture : Promise<T> to cancelledFuture : RPromise<T> in method public invokeAll(tasks Collection<? extends Callable<T>>, timeout long, unit TimeUnit) : List<Future<T>> in class org.redisson.RedissonExecutorService |
From |
To |
|
Change Variable Type res : Future<List<Object>> to res : RFuture<List<Object>> in method public testEvalAsync() : void in class org.redisson.RedissonScriptTest |
From |
To |
|
Change Variable Type addFuture : Future<Boolean> to addFuture : RFuture<Boolean> in method private execute(promise RemotePromise<T>) : void in class org.redisson.RedissonExecutorService |
From |
To |
|
Change Variable Type entry : Entry<RLock,Future<Boolean>> to entry : Entry<RLock,RFuture<Boolean>> in method protected sync(tryLockFutures Map<RLock,RFuture<Boolean>>) : boolean in class org.redisson.RedissonMultiLock |
From |
To |
|
Change Variable Type res : Future<R> to res : RFuture<R> in method public read(client InetSocketAddress, key String, codec Codec, command RedisCommand<T>, params Object...) : R in class org.redisson.command.CommandSyncService |
From |
To |
|
Change Variable Type main : Promise<Void> to main : RPromise<Void> in method public operationComplete(connFuture Future<RedisConnection>) : void in class org.redisson.command.CommandAsyncService.async.addListener |
From |
To |
|
Change Variable Type pubSubFuture : Future<Void> to pubSubFuture : RFuture<Void> in method public add(entry ClientConnectionsEntry) : RFuture<Void> in class org.redisson.connection.balancer.LoadBalancerManagerImpl |
From |
To |
|
Change Variable Type clientsFuture : Future<List<?>> to clientsFuture : RFuture<List<?>> in method private invokeMethod(remoteInterface Class<T>, requestQueue RBlockingQueue<RemoteServiceRequest>, request RemoteServiceRequest, method RemoteServiceMethod, responseName String, executor ExecutorService, cancelRequestFuture RFuture<RemoteServiceCancelRequest>, responseHolder AtomicReference<RRemoteServiceResponse>) : void in class org.redisson.RedissonRemoteService |
From |
To |
|
Change Variable Type future : Future<RedisConnection> to future : RFuture<RedisConnection> in method private connect(cfg ClusterServersConfig, addr URI) : RFuture<RedisConnection> in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type masterFuture : Future<Collection<Future<Void>>> to masterFuture : RFuture<Collection<RFuture<Void>>> in method public ClusterConnectionManager(cfg ClusterServersConfig, config Config) in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type pubsubFuture : Future<RedisPubSubConnection> to pubsubFuture : RFuture<RedisPubSubConnection> in method private registerSentinel(cfg SentinelServersConfig, addr URI, c MasterSlaveServersConfig) : RFuture<RedisPubSubConnection> in class org.redisson.connection.SentinelConnectionManager |
From |
To |
|
Change Variable Type future : Future<Void> to future : RFuture<Void> in method protected onSlaveAdded(addr URI, msg String) : void in class org.redisson.connection.SentinelConnectionManager |
From |
To |
|
Change Variable Type res : Future<V> to res : RFuture<V> in method public pollFromAny(timeout long, unit TimeUnit, queueNames String...) : V in class org.redisson.RedissonBlockingQueue |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method public testAsync() : void in class org.redisson.RedissonRemoteServiceTest |
From |
To |
|
Change Variable Type clusterFuture : Future<Map<String,String>> to clusterFuture : RFuture<Map<String,String>> in method public operationComplete(future Future<RedisConnection>) : void in class org.redisson.cluster.ClusterConnectionManager.addMasterEntry.addListener |
From |
To |
|
Change Variable Type future : Future<List<ClusterNodeInfo>> to future : RFuture<List<ClusterNodeInfo>> in method private updateClusterState(cfg ClusterServersConfig, connection RedisConnection, iterator Iterator<URI>, uri URI) : void in class org.redisson.cluster.ClusterConnectionManager |
From |
To |
|
Change Variable Type future : Future<Integer> to future : RFuture<Integer> in method public runCleanTask(name String, timeoutSetName String, currentDate long) : void in class org.redisson.EvictionScheduler |
From |
To |
|
Change Variable Type res : Future<V> to res : RFuture<V> in method public poll(timeout long, unit TimeUnit) : V in class org.redisson.RedissonBlockingQueue |
From |
To |
|
Change Variable Type future : Future<Integer> to future : RFuture<Integer> in method public testPutAsync() : void in class org.redisson.RedissonMapTest |
From |
To |
|
Change Variable Type res : Future<R> to res : RFuture<R> in method public evalRead(key String, codec Codec, evalCommandType RedisCommand<T>, script String, keys List<Object>, params Object...) : R in class org.redisson.command.CommandSyncService |
From |
To |
|
Change Variable Type promise : Promise<PubSubConnectionEntry> to promise : RPromise<PubSubConnectionEntry> in method public psubscribe(channelName String, codec Codec, listener RedisPubSubListener<?>, semaphore AsyncSemaphore) : RFuture<PubSubConnectionEntry> in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type future2 : Future<Boolean> to future2 : RFuture<Boolean> in method public testAddAsync() : void in class org.redisson.RedissonScoredSortedSetTest |
From |
To |
|
Change Variable Type f : Future<Void> to f : RFuture<Void> in method protected initEntry(config MasterSlaveServersConfig) : void in class org.redisson.connection.MasterSlaveConnectionManager |
From |
To |
|
Change Variable Type configFuture : Future<Map<String,String>> to configFuture : RFuture<Map<String,String>> in method public count() : int in class org.redisson.RedissonBloomFilter |
From |
To |
|
Change Variable Type s : Future<Void> to s : RFuture<Void> in method public setupMasterEntry(host String, port int) : RFuture<Void> in class org.redisson.connection.SingleEntry |
From |
To |