Uses of Interface
org.redisson.misc.RPromise
-
-
Uses of RPromise in org.redisson
Methods in org.redisson that return RPromise Modifier and Type Method Description RPromise<E>
PubSubEntry. getPromise()
RPromise<RedissonCountDownLatchEntry>
RedissonCountDownLatchEntry. getPromise()
RPromise<RedissonLockEntry>
RedissonLockEntry. getPromise()
Methods in org.redisson with parameters of type RPromise Modifier and Type Method Description protected RFuture<Boolean>
RedissonMap. containsKeyAsync(Object key, RPromise<V> promise)
protected <T> void
RedissonRemoteService. invokeMethod(RemoteServiceRequest request, RemoteServiceMethod method, RFuture<RemoteServiceCancelRequest> cancelRequestFuture, RPromise<RRemoteServiceResponse> responsePromise)
protected void
RedissonMap. loadValue(K key, RPromise<V> result, boolean replaceValue)
protected <T> void
RedissonPriorityBlockingQueue. takeAsync(RPromise<V> result, long delay, long timeoutInMicro, RedisCommand<T> command, Object... params)
protected void
RedissonMultiLock. tryLockAsync(long threadId, long leaseTime, TimeUnit unit, long waitTime, RPromise<Void> result)
Constructors in org.redisson with parameters of type RPromise Constructor Description RedissonCountDownLatchEntry(RPromise<RedissonCountDownLatchEntry> promise)
RedissonLockEntry(RPromise<RedissonLockEntry> promise)
-
Uses of RPromise in org.redisson.client
Methods in org.redisson.client that return RPromise Modifier and Type Method Description <C extends RedisConnection>
RPromise<C>RedisConnection. getConnectionPromise()
Constructors in org.redisson.client with parameters of type RPromise Constructor Description RedisConnection(RedisClient redisClient, io.netty.channel.Channel channel, RPromise<C> connectionPromise)
RedisPubSubConnection(RedisClient redisClient, io.netty.channel.Channel channel, RPromise<RedisPubSubConnection> connectionPromise)
-
Uses of RPromise in org.redisson.client.protocol
Methods in org.redisson.client.protocol that return RPromise Modifier and Type Method Description RPromise<R>
CommandData. getPromise()
RPromise<Void>
CommandsData. getPromise()
Constructors in org.redisson.client.protocol with parameters of type RPromise Constructor Description BatchCommandData(RPromise<R> promise, Codec codec, RedisCommand<T> command, Object[] params, int index)
CommandData(RPromise<R> promise, Codec codec, RedisCommand<T> command, Object[] params)
CommandData(RPromise<R> promise, MultiDecoder<Object> messageDecoder, Codec codec, RedisCommand<T> command, Object[] params)
CommandsData(RPromise<Void> promise, List<CommandData<?,?>> commands, boolean queued, boolean syncSlaves)
CommandsData(RPromise<Void> promise, List<CommandData<?,?>> commands, boolean skipResult, boolean atomic, boolean queued, boolean syncSlaves)
CommandsData(RPromise<Void> promise, List<CommandData<?,?>> commands, List<CommandData<?,?>> attachedCommands, boolean skipResult, boolean atomic, boolean queued, boolean syncSlaves)
-
Uses of RPromise in org.redisson.command
Classes in org.redisson.command that implement RPromise Modifier and Type Class Description class
BatchPromise<T>
Methods in org.redisson.command that return RPromise Modifier and Type Method Description protected <R> RPromise<R>
CommandAsyncService. createPromise()
<R> RPromise<R>
CommandBatchService. createPromise()
RPromise<T>
BatchPromise. sync()
RPromise<T>
BatchPromise. syncUninterruptibly()
Methods in org.redisson.command with parameters of type RPromise Modifier and Type Method Description <V,R>
voidCommandAsyncService. async(boolean readOnlyMode, NodeSource source, Codec codec, RedisCommand<V> command, Object[] params, RPromise<R> mainPromise, boolean ignoreRedirect)
<V,R>
voidCommandBatchService. async(boolean readOnlyMode, NodeSource nodeSource, Codec codec, RedisCommand<V> command, Object[] params, RPromise<R> mainPromise, boolean ignoreRedirect)
protected void
RedisExecutor. checkAttemptPromise(RPromise<R> attemptFuture, RFuture<RedisConnection> connectionFuture)
protected void
CommandBatchService. handle(RPromise<Void> mainPromise, AtomicInteger slots, RFuture<?> future)
protected void
RedisCommonBatchExecutor. handleResult(RPromise<Void> attemptPromise, RFuture<RedisConnection> connectionFuture)
protected void
RedisExecutor. handleResult(RPromise<R> attemptPromise, RFuture<RedisConnection> connectionFuture)
protected void
RedisExecutor. handleSuccess(RPromise<R> promise, RFuture<RedisConnection> connectionFuture, R res)
protected void
RedisQueuedBatchExecutor. handleSuccess(RPromise<R> promise, RFuture<RedisConnection> connectionFuture, R res)
protected void
RedisExecutor. releaseConnection(RPromise<R> attemptPromise, RFuture<RedisConnection> connectionFuture)
protected void
RedisQueuedBatchExecutor. releaseConnection(RPromise<R> attemptPromise, RFuture<RedisConnection> connectionFuture)
protected void
RedisCommonBatchExecutor. sendCommand(RPromise<Void> attemptPromise, RedisConnection connection)
protected void
RedisExecutor. sendCommand(RPromise<R> attemptPromise, RedisConnection connection)
protected void
RedisQueuedBatchExecutor. sendCommand(RPromise<R> attemptPromise, RedisConnection connection)
-
Uses of RPromise in org.redisson.executor
Classes in org.redisson.executor that implement RPromise Modifier and Type Class Description class
RedissonExecutorBatchFuture
class
RedissonExecutorFuture<V>
class
RedissonScheduledFuture<V>
class
RemotePromise<T>
Methods in org.redisson.executor that return RPromise Modifier and Type Method Description RPromise<?>
RedissonExecutorFutureReference. getPromise()
Methods in org.redisson.executor with parameters of type RPromise Modifier and Type Method Description protected <T> void
RedissonExecutorRemoteService. invokeMethod(RemoteServiceRequest request, RemoteServiceMethod method, RFuture<RemoteServiceCancelRequest> cancelRequestFuture, RPromise<RRemoteServiceResponse> responsePromise)
Constructors in org.redisson.executor with parameters of type RPromise Constructor Description RedissonExecutorFuture(RPromise<V> promise, RequestId taskId)
RedissonExecutorFutureReference(RequestId requestId, RExecutorFuture<?> referent, ReferenceQueue<? super RExecutorFuture<?>> q, RPromise<?> promise)
-
Uses of RPromise in org.redisson.misc
Classes in org.redisson.misc that implement RPromise Modifier and Type Class Description class
PromiseDelegator<T>
class
RedissonPromise<T>
Fields in org.redisson.misc declared as RPromise Modifier and Type Field Description protected RPromise<T>
CountableListener. result
Methods in org.redisson.misc that return RPromise Modifier and Type Method Description RPromise<T>
PromiseDelegator. await()
RPromise<T>
RedissonPromise. await()
RPromise<T>
RPromise. await()
RPromise<T>
PromiseDelegator. awaitUninterruptibly()
RPromise<T>
RedissonPromise. awaitUninterruptibly()
RPromise<T>
RPromise. awaitUninterruptibly()
RPromise<T>
PromiseDelegator. getInnerPromise()
RPromise<T>
PromiseDelegator. sync()
RPromise<T>
RedissonPromise. sync()
RPromise<T>
RPromise. sync()
RPromise<T>
PromiseDelegator. syncUninterruptibly()
RPromise<T>
RedissonPromise. syncUninterruptibly()
RPromise<T>
RPromise. syncUninterruptibly()
Constructors in org.redisson.misc with parameters of type RPromise Constructor Description CountableListener(RPromise<T> result, T value)
CountableListener(RPromise<T> result, T value, int count)
PromiseDelegator(RPromise<T> promise)
TransferListener(RPromise<T> promise)
-
Uses of RPromise in org.redisson.pubsub
Methods in org.redisson.pubsub with parameters of type RPromise Modifier and Type Method Description protected RedissonCountDownLatchEntry
CountDownLatchPubSub. createEntry(RPromise<RedissonCountDownLatchEntry> newPromise)
protected RedissonLockEntry
LockPubSub. createEntry(RPromise<RedissonLockEntry> newPromise)
protected RedissonLockEntry
SemaphorePubSub. createEntry(RPromise<RedissonLockEntry> newPromise)
-
Uses of RPromise in org.redisson.reactive
Methods in org.redisson.reactive that return RPromise Modifier and Type Method Description protected <R> RPromise<R>
CommandReactiveBatchService. createPromise()
Methods in org.redisson.reactive with parameters of type RPromise Modifier and Type Method Description <V,R>
voidCommandReactiveBatchService. async(boolean readOnlyMode, NodeSource nodeSource, Codec codec, RedisCommand<V> command, Object[] params, RPromise<R> mainPromise, boolean ignoreRedirect)
-
Uses of RPromise in org.redisson.remote
Methods in org.redisson.remote that return RPromise Modifier and Type Method Description <T extends RRemoteServiceResponse>
RPromise<T>ResponseEntry.Result. getPromise()
protected <T extends RRemoteServiceResponse>
RPromise<T>BaseRemoteProxy. pollResponse(long timeout, RequestId requestId, boolean insertFirst)
Methods in org.redisson.remote with parameters of type RPromise Modifier and Type Method Description protected <T> void
BaseRemoteService. scheduleCheck(String mapName, RequestId requestId, RPromise<T> cancelRequest)
Constructors in org.redisson.remote with parameters of type RPromise Constructor Description Result(RPromise<? extends RRemoteServiceResponse> promise, ScheduledFuture<?> responseTimeoutFuture)
-
Uses of RPromise in org.redisson.rx
Methods in org.redisson.rx that return RPromise Modifier and Type Method Description protected <R> RPromise<R>
CommandRxBatchService. createPromise()
Methods in org.redisson.rx with parameters of type RPromise Modifier and Type Method Description <V,R>
voidCommandRxBatchService. async(boolean readOnlyMode, NodeSource nodeSource, Codec codec, RedisCommand<V> command, Object[] params, RPromise<R> mainPromise, boolean ignoreRedirect)
-
Uses of RPromise in org.redisson.transaction
Methods in org.redisson.transaction with parameters of type RPromise Modifier and Type Method Description protected <R> void
BaseTransactionalMap. executeLocked(RPromise<R> promise, Runnable runnable, Collection<K> keys)
protected <R> void
BaseTransactionalMap. executeLocked(RPromise<R> promise, Runnable runnable, RLock lock)
protected <R> void
BaseTransactionalMap. executeLocked(RPromise<R> promise, K key, Runnable runnable)
protected <R> void
BaseTransactionalSet. executeLocked(RPromise<R> promise, Object value, Runnable runnable)
protected <R> void
BaseTransactionalSet. executeLocked(RPromise<R> promise, Runnable runnable, Collection<?> values)
protected <R> void
BaseTransactionalSet. executeLocked(RPromise<R> promise, Runnable runnable, RLock lock)
protected <R> void
RedissonTransactionalBucket. executeLocked(RPromise<R> promise, Runnable runnable)
protected <R> void
RedissonTransactionalBuckets. executeLocked(RPromise<R> promise, Runnable runnable, Collection<String> keys)
-