Interface RedissonReactiveClient

All Known Implementing Classes:
RedissonReactive

public interface RedissonReactiveClient
Main Redisson interface for access to all redisson objects with Reactive interface.
Author:
Nikita Koksharov
See Also:
  • Method Details

    • getTimeSeries

      <V, L> RTimeSeriesReactive<V,L> getTimeSeries(String name)
      Returns time-series instance by name
      Type Parameters:
      V - value type
      L - label type
      Parameters:
      name - - name of instance
      Returns:
      RTimeSeries object
    • getTimeSeries

      <V, L> RTimeSeriesReactive<V,L> getTimeSeries(String name, Codec codec)
      Returns time-series instance by name using provided codec for values.
      Type Parameters:
      V - value type
      L - label type
      Parameters:
      name - - name of instance
      codec - - codec for values
      Returns:
      RTimeSeries object
    • getStream

      <K, V> RStreamReactive<K,V> getStream(String name)
      Returns stream instance by name

      Requires Redis 5.0.0 and higher.

      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - of stream
      Returns:
      RStream object
    • getStream

      <K, V> RStreamReactive<K,V> getStream(String name, Codec codec)
      Returns stream instance by name using provided codec for entries.

      Requires Redis 5.0.0 and higher.

      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of stream
      codec - - codec for entry
      Returns:
      RStream object
    • getSearch

      RSearchReactive getSearch()
      Returns API for RediSearch module
      Returns:
      RSearch object
    • getSearch

      RSearchReactive getSearch(Codec codec)
      Returns API for RediSearch module using defined codec for attribute values.
      Returns:
      RSearch object
    • getGeo

      <V> RGeoReactive<V> getGeo(String name)
      Returns geospatial items holder instance by name.
      Type Parameters:
      V - type of value
      Parameters:
      name - - name of object
      Returns:
      Geo object
    • getGeo

      <V> RGeoReactive<V> getGeo(String name, Codec codec)
      Returns geospatial items holder instance by name using provided codec for geospatial members.
      Type Parameters:
      V - type of value
      Parameters:
      name - - name of object
      codec - - codec for value
      Returns:
      Geo object
    • getRateLimiter

      RRateLimiterReactive getRateLimiter(String name)
      Returns rate limiter instance by name
      Parameters:
      name - of rate limiter
      Returns:
      RateLimiter object
    • getBinaryStream

      RBinaryStreamReactive getBinaryStream(String name)
      Returns binary stream holder instance by name
      Parameters:
      name - of binary stream
      Returns:
      BinaryStream object
    • getSemaphore

      RSemaphoreReactive getSemaphore(String name)
      Returns semaphore instance by name
      Parameters:
      name - - name of object
      Returns:
      Semaphore object
    • getPermitExpirableSemaphore

      RPermitExpirableSemaphoreReactive getPermitExpirableSemaphore(String name)
      Returns semaphore instance by name. Supports lease time parameter for each acquired permit.
      Parameters:
      name - - name of object
      Returns:
      PermitExpirableSemaphore object
    • getReadWriteLock

      RReadWriteLockReactive getReadWriteLock(String name)
      Returns ReadWriteLock instance by name.

      To increase reliability during failover, all operations wait for propagation to all Redis slaves.

      Parameters:
      name - - name of object
      Returns:
      Lock object
    • getFairLock

      RLockReactive getFairLock(String name)
      Returns Lock instance by name.

      Implements a fair locking so it guarantees an acquire order by threads.

      To increase reliability during failover, all operations wait for propagation to all Redis slaves.

      Parameters:
      name - - name of object
      Returns:
      Lock object
    • getLock

      RLockReactive getLock(String name)
      Returns Lock instance by name.

      Implements a non-fair locking so doesn't guarantees an acquire order by threads.

      To increase reliability during failover, all operations wait for propagation to all Redis slaves.

      Parameters:
      name - - name of object
      Returns:
      Lock object
    • getSpinLock

      RLockReactive getSpinLock(String name)
      Returns Spin lock instance by name.

      Implements a non-fair locking so doesn't guarantees an acquire order by threads.

      Lock doesn't use a pub/sub mechanism

      Parameters:
      name - - name of object
      Returns:
      Lock object
    • getSpinLock

      RLockReactive getSpinLock(String name, LockOptions.BackOff backOff)
      Returns Spin lock instance by name with specified back off options.

      Implements a non-fair locking so doesn't guarantees an acquire order by threads.

      Lock doesn't use a pub/sub mechanism

      Parameters:
      name - - name of object
      Returns:
      Lock object
    • getFencedLock

      RFencedLockReactive getFencedLock(String name)
      Returns Fenced Lock by name.

      Implements a non-fair locking so doesn't guarantee an acquire order by threads.

      Parameters:
      name - name of object
      Returns:
      Lock object
    • getMultiLock

      RLockReactive getMultiLock(RLockReactive... locks)
      Returns MultiLock instance associated with specified locks
      Parameters:
      locks - - collection of locks
      Returns:
      MultiLock object
    • getMultiLock

      @Deprecated RLockReactive getMultiLock(RLock... locks)
      Deprecated.
    • getRedLock

      @Deprecated RLockReactive getRedLock(RLock... locks)
      Deprecated.
    • getCountDownLatch

      RCountDownLatchReactive getCountDownLatch(String name)
      Returns CountDownLatch instance by name.
      Parameters:
      name - - name of object
      Returns:
      CountDownLatch object
    • getSetCache

      <V> RSetCacheReactive<V> getSetCache(String name)
      Returns set-based cache instance by name. Supports value eviction with a given TTL value.

      If eviction is not required then it's better to use regular map getSet(String, Codec).

      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      SetCache object
    • getSetCache

      <V> RSetCacheReactive<V> getSetCache(String name, Codec codec)
      Returns set-based cache instance by name. Supports value eviction with a given TTL value.

      If eviction is not required then it's better to use regular map getSet(String, Codec).

      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      codec - - codec for values
      Returns:
      SetCache object
    • getMapCache

      <K, V> RMapCacheReactive<K,V> getMapCache(String name, Codec codec)
      Returns map-based cache instance by name using provided codec for both cache keys and values. Supports entry eviction with a given MaxIdleTime and TTL settings.

      If eviction is not required then it's better to use regular map getMap(String, Codec).

      Type Parameters:
      K - type of keys
      V - type of values
      Parameters:
      name - - name of object
      codec - - codec for values
      Returns:
      MapCache object
    • getMapCache

      <K, V> RMapCacheReactive<K,V> getMapCache(String name, Codec codec, MapCacheOptions<K,V> options)
      Returns map-based cache instance by name using provided codec for both cache keys and values. Supports entry eviction with a given MaxIdleTime and TTL settings.

      If eviction is not required then it's better to use regular map getMap(String, Codec, MapOptions).

      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - object name
      codec - - codec for keys and values
      options - - map options
      Returns:
      MapCache object
    • getMapCache

      <K, V> RMapCacheReactive<K,V> getMapCache(String name)
      Returns map-based cache instance by name. Supports entry eviction with a given MaxIdleTime and TTL settings.

      If eviction is not required then it's better to use regular map getMap(String).

      Type Parameters:
      K - type of keys
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      MapCache object
    • getMapCache

      <K, V> RMapCacheReactive<K,V> getMapCache(String name, MapCacheOptions<K,V> options)
      Returns map-based cache instance by name. Supports entry eviction with a given MaxIdleTime and TTL settings.

      If eviction is not required then it's better to use regular map getMap(String, MapOptions).

      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      options - - map options
      Returns:
      MapCache object
    • getBucket

      <V> RBucketReactive<V> getBucket(String name)
      Returns object holder instance by name
      Type Parameters:
      V - type of value
      Parameters:
      name - - name of object
      Returns:
      Bucket object
    • getBucket

      <V> RBucketReactive<V> getBucket(String name, Codec codec)
      Returns object holder instance by name using provided codec for object.
      Type Parameters:
      V - type of value
      Parameters:
      name - - name of object
      codec - - codec for value
      Returns:
      Bucket object
    • getBuckets

      RBucketsReactive getBuckets()
      Returns interface for mass operations with Bucket objects.
      Returns:
      Buckets
    • getBuckets

      RBucketsReactive getBuckets(Codec codec)
      Returns interface for mass operations with Bucket objects using provided codec for object.
      Parameters:
      codec - - codec for bucket objects
      Returns:
      Buckets
    • findBuckets

      <V> List<RBucketReactive<V>> findBuckets(String pattern)
      Returns a list of object holder instances by a key pattern
      Type Parameters:
      V - type of value
      Parameters:
      pattern - - pattern for name of buckets
      Returns:
      list of buckets
    • getJsonBucket

      <V> RJsonBucketReactive<V> getJsonBucket(String name, JsonCodec<V> codec)
      Returns JSON data holder instance by name using provided codec.
      Type Parameters:
      V - type of value
      Parameters:
      name - name of object
      codec - codec for values
      Returns:
      JsonBucket object
    • getHyperLogLog

      <V> RHyperLogLogReactive<V> getHyperLogLog(String name)
      Returns HyperLogLog instance by name.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      HyperLogLog object
    • getHyperLogLog

      <V> RHyperLogLogReactive<V> getHyperLogLog(String name, Codec codec)
      Returns HyperLogLog instance by name using provided codec for hll objects.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      codec - - codec of values
      Returns:
      HyperLogLog object
    • getIdGenerator

      RIdGeneratorReactive getIdGenerator(String name)
      Returns id generator by name.
      Parameters:
      name - - name of object
      Returns:
      IdGenerator object
    • getList

      <V> RListReactive<V> getList(String name)
      Returns list instance by name.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      List object
    • getList

      <V> RListReactive<V> getList(String name, Codec codec)
      Returns list instance by name using provided codec for list objects.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      codec - - codec for values
      Returns:
      List object
    • getListMultimap

      <K, V> RListMultimapReactive<K,V> getListMultimap(String name)
      Returns List based Multimap instance by name.
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      Returns:
      ListMultimap object
    • getListMultimap

      <K, V> RListMultimapReactive<K,V> getListMultimap(String name, Codec codec)
      Returns List based Multimap instance by name using provided codec for both map keys and values.
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      codec - - codec for keys and values
      Returns:
      RListMultimapReactive object
    • getListMultimapCache

      <K, V> RListMultimapCacheReactive<K,V> getListMultimapCache(String name)
      Returns List based Multimap cache instance by name. Supports key eviction by specifying a time to live. If eviction is not required then it's better to use regular list multimap getListMultimap(String).
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      Returns:
      RListMultimapCacheReactive object
    • getListMultimapCache

      <K, V> RListMultimapCacheReactive<K,V> getListMultimapCache(String name, Codec codec)
      Returns List based Multimap cache instance by name using provided codec for both map keys and values. Supports key eviction by specifying a time to live. If eviction is not required then it's better to use regular list multimap getListMultimap(String, Codec).
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      codec - - codec for keys and values
      Returns:
      RListMultimapCacheReactive object
    • getSetMultimap

      <K, V> RSetMultimapReactive<K,V> getSetMultimap(String name)
      Returns Set based Multimap instance by name.
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      Returns:
      SetMultimap object
    • getSetMultimap

      <K, V> RSetMultimapReactive<K,V> getSetMultimap(String name, Codec codec)
      Returns Set based Multimap instance by name using provided codec for both map keys and values.
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      codec - - codec for keys and values
      Returns:
      SetMultimap object
    • getSetMultimapCache

      <K, V> RSetMultimapCacheReactive<K,V> getSetMultimapCache(String name)
      Returns Set based Multimap cache instance by name. Supports key eviction by specifying a time to live. If eviction is not required then it's better to use regular set multimap getSetMultimap(String).
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      Returns:
      RSetMultimapCacheReactive object
    • getSetMultimapCache

      <K, V> RSetMultimapCacheReactive<K,V> getSetMultimapCache(String name, Codec codec)
      Returns Set based Multimap cache instance by name using provided codec for both map keys and values. Supports key eviction by specifying a time to live. If eviction is not required then it's better to use regular set multimap getSetMultimap(String, Codec).
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      codec - - codec for keys and values
      Returns:
      RSetMultimapCacheReactive object
    • getMap

      <K, V> RMapReactive<K,V> getMap(String name)
      Returns map instance by name.
      Type Parameters:
      K - type of keys
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      Map object
    • getMap

      <K, V> RMapReactive<K,V> getMap(String name, MapOptions<K,V> options)
      Returns map instance by name.
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      options - - map options
      Returns:
      Map object
    • getMap

      <K, V> RMapReactive<K,V> getMap(String name, Codec codec)
      Returns map instance by name using provided codec for both map keys and values.
      Type Parameters:
      K - type of keys
      V - type of values
      Parameters:
      name - - name of object
      codec - - codec for keys and values
      Returns:
      Map object
    • getMap

      <K, V> RMapReactive<K,V> getMap(String name, Codec codec, MapOptions<K,V> options)
      Returns map instance by name using provided codec for both map keys and values.
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      codec - - codec for keys and values
      options - - map options
      Returns:
      Map object
    • getLocalCachedMap

      <K, V> RLocalCachedMapReactive<K,V> getLocalCachedMap(String name, LocalCachedMapOptions<K,V> options)
      Returns local cached map instance by name. Configured by parameters of options-object.
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      options - - local map options
      Returns:
      LocalCachedMap object
    • getLocalCachedMap

      <K, V> RLocalCachedMapReactive<K,V> getLocalCachedMap(String name, Codec codec, LocalCachedMapOptions<K,V> options)
      Returns local cached map instance by name using provided codec. Configured by parameters of options-object.
      Type Parameters:
      K - type of key
      V - type of value
      Parameters:
      name - - name of object
      codec - - codec for keys and values
      options - - local map options
      Returns:
      LocalCachedMap object
    • getSet

      <V> RSetReactive<V> getSet(String name)
      Returns set instance by name.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      Set object
    • getSet

      <V> RSetReactive<V> getSet(String name, Codec codec)
      Returns set instance by name using provided codec for set objects.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of set
      codec - - codec for values
      Returns:
      Set object
    • getScoredSortedSet

      <V> RScoredSortedSetReactive<V> getScoredSortedSet(String name)
      Returns Redis Sorted Set instance by name. This sorted set sorts objects by object score.
      Type Parameters:
      V - type of values
      Parameters:
      name - of scored sorted set
      Returns:
      ScoredSortedSet object
    • getScoredSortedSet

      <V> RScoredSortedSetReactive<V> getScoredSortedSet(String name, Codec codec)
      Returns Redis Sorted Set instance by name using provided codec for sorted set objects. This sorted set sorts objects by object score.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of scored sorted set
      codec - - codec for values
      Returns:
      ScoredSortedSet object
    • getLexSortedSet

      RLexSortedSetReactive getLexSortedSet(String name)
      Returns String based Redis Sorted Set instance by name All elements are inserted with the same score during addition, in order to force lexicographical ordering
      Parameters:
      name - - name of object
      Returns:
      LexSortedSet object
    • getShardedTopic

      RShardedTopicReactive getShardedTopic(String name)
      Returns Sharded Topic instance by name.

      Messages are delivered to message listeners connected to the same Topic.

      Parameters:
      name - - name of object
      Returns:
      Topic object
    • getShardedTopic

      RShardedTopicReactive getShardedTopic(String name, Codec codec)
      Returns Sharded Topic instance by name using provided codec for messages.

      Messages are delivered to message listeners connected to the same Topic.

      Parameters:
      name - - name of object
      codec - - codec for message
      Returns:
      Topic object
    • getTopic

      RTopicReactive getTopic(String name)
      Returns topic instance by name.
      Parameters:
      name - - name of object
      Returns:
      Topic object
    • getTopic

      RTopicReactive getTopic(String name, Codec codec)
      Returns topic instance by name using provided codec for messages.
      Parameters:
      name - - name of object
      codec - - codec for message
      Returns:
      Topic object
    • getReliableTopic

      RReliableTopicReactive getReliableTopic(String name)
      Returns reliable topic instance by name.

      Dedicated Redis connection is allocated per instance (subscriber) of this object. Messages are delivered to all listeners attached to the same Redis setup.

      Requires Redis 5.0.0 and higher.

      Parameters:
      name - - name of object
      Returns:
      ReliableTopic object
    • getReliableTopic

      RReliableTopicReactive getReliableTopic(String name, Codec codec)
      Returns reliable topic instance by name using provided codec for messages.

      Dedicated Redis connection is allocated per instance (subscriber) of this object. Messages are delivered to all listeners attached to the same Redis setup.

      Requires Redis 5.0.0 and higher.

      Parameters:
      name - - name of object
      codec - - codec for message
      Returns:
      ReliableTopic object
    • getPatternTopic

      RPatternTopicReactive getPatternTopic(String pattern)
      Returns topic instance satisfies by pattern name. Supported glob-style patterns: h?llo subscribes to hello, hallo and hxllo h*llo subscribes to hllo and heeeello h[ae]llo subscribes to hello and hallo, but not hillo
      Parameters:
      pattern - of the topic
      Returns:
      PatternTopic object
    • getPatternTopic

      RPatternTopicReactive getPatternTopic(String pattern, Codec codec)
      Returns topic instance satisfies by pattern name using provided codec for messages. Supported glob-style patterns: h?llo subscribes to hello, hallo and hxllo h*llo subscribes to hllo and heeeello h[ae]llo subscribes to hello and hallo, but not hillo
      Parameters:
      pattern - of the topic
      codec - - codec for message
      Returns:
      PatternTopic object
    • getQueue

      <V> RQueueReactive<V> getQueue(String name)
      Returns queue instance by name.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      Queue object
    • getQueue

      <V> RQueueReactive<V> getQueue(String name, Codec codec)
      Returns queue instance by name using provided codec for queue objects.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      codec - - codec for values
      Returns:
      Queue object
    • getRingBuffer

      <V> RRingBufferReactive<V> getRingBuffer(String name)
      Returns RingBuffer based queue.
      Type Parameters:
      V - value type
      Parameters:
      name - - name of object
      Returns:
      RingBuffer object
    • getRingBuffer

      <V> RRingBufferReactive<V> getRingBuffer(String name, Codec codec)
      Returns RingBuffer based queue.
      Type Parameters:
      V - value type
      Parameters:
      name - - name of object
      codec - - codec for values
      Returns:
      RingBuffer object
    • getBlockingQueue

      <V> RBlockingQueueReactive<V> getBlockingQueue(String name)
      Returns blocking queue instance by name.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      BlockingQueue object
    • getBlockingQueue

      <V> RBlockingQueueReactive<V> getBlockingQueue(String name, Codec codec)
      Returns blocking queue instance by name using provided codec for queue objects.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      codec - - code for values
      Returns:
      BlockingQueue object
    • getBlockingDeque

      <V> RBlockingDequeReactive<V> getBlockingDeque(String name)
      Returns unbounded blocking deque instance by name.
      Type Parameters:
      V - type of value
      Parameters:
      name - - name of object
      Returns:
      BlockingDeque object
    • getBlockingDeque

      <V> RBlockingDequeReactive<V> getBlockingDeque(String name, Codec codec)
      Returns unbounded blocking deque instance by name using provided codec for deque objects.
      Type Parameters:
      V - type of value
      Parameters:
      name - - name of object
      codec - - deque objects codec
      Returns:
      BlockingDeque object
    • getTransferQueue

      <V> RTransferQueueReactive<V> getTransferQueue(String name)
      Returns transfer queue instance by name.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      TransferQueue object
    • getTransferQueue

      <V> RTransferQueueReactive<V> getTransferQueue(String name, Codec codec)
      Returns transfer queue instance by name using provided codec for queue objects.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      codec - - code for values
      Returns:
      TransferQueue object
    • getDeque

      <V> RDequeReactive<V> getDeque(String name)
      Returns deque instance by name.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      Returns:
      Deque object
    • getDeque

      <V> RDequeReactive<V> getDeque(String name, Codec codec)
      Returns deque instance by name using provided codec for deque objects.
      Type Parameters:
      V - type of values
      Parameters:
      name - - name of object
      codec - - coded for values
      Returns:
      Deque object
    • getAtomicLong

      RAtomicLongReactive getAtomicLong(String name)
      Returns "atomic long" instance by name.
      Parameters:
      name - of the "atomic long"
      Returns:
      AtomicLong object
    • getAtomicDouble

      RAtomicDoubleReactive getAtomicDouble(String name)
      Returns "atomic double" instance by name.
      Parameters:
      name - of the "atomic double"
      Returns:
      AtomicLong object
    • getRemoteService

      RRemoteService getRemoteService()
      Returns object for remote operations prefixed with the default name (redisson_remote_service)
      Returns:
      RemoteService object
    • getRemoteService

      RRemoteService getRemoteService(Codec codec)
      Returns object for remote operations prefixed with the default name (redisson_remote_service) and uses provided codec for method arguments and result.
      Parameters:
      codec - - codec for response and request
      Returns:
      RemoteService object
    • getRemoteService

      RRemoteService getRemoteService(String name)
      Returns object for remote operations prefixed with the specified name
      Parameters:
      name - - the name used as the Redis key prefix for the services
      Returns:
      RemoteService object
    • getRemoteService

      RRemoteService getRemoteService(String name, Codec codec)
      Returns object for remote operations prefixed with the specified name and uses provided codec for method arguments and result.
      Parameters:
      name - - the name used as the Redis key prefix for the services
      codec - - codec for response and request
      Returns:
      RemoteService object
    • getBitSet

      RBitSetReactive getBitSet(String name)
      Returns bitSet instance by name.
      Parameters:
      name - - name of object
      Returns:
      BitSet object
    • getFunction

      RFunctionReactive getFunction()
      Returns interface for Redis Function feature
      Returns:
      function object
    • getFunction

      RFunctionReactive getFunction(Codec codec)
      Returns interface for Redis Function feature using provided codec
      Parameters:
      codec - - codec for params and result
      Returns:
      function interface
    • getScript

      RScriptReactive getScript()
      Returns script operations object
      Returns:
      Script object
    • getScript

      RScriptReactive getScript(Codec codec)
      Returns script operations object using provided codec.
      Parameters:
      codec - - codec for params and result
      Returns:
      Script object
    • createTransaction

      RTransactionReactive createTransaction(TransactionOptions options)
      Creates transaction with READ_COMMITTED isolation level.
      Parameters:
      options - - transaction configuration
      Returns:
      Transaction object
    • createBatch

      RBatchReactive createBatch(BatchOptions options)
      Return batch object which executes group of command in pipeline. See http://redis.io/topics/pipelining
      Parameters:
      options - - batch configuration
      Returns:
      Batch object
    • createBatch

      RBatchReactive createBatch()
      Return batch object which executes group of command in pipeline. See http://redis.io/topics/pipelining
      Returns:
      Batch object
    • getKeys

      RKeysReactive getKeys()
      Returns keys operations. Each of Redis/Redisson object associated with own key
      Returns:
      Keys object
    • shutdown

      void shutdown()
      Shuts down Redisson instance NOT Redis server
    • getConfig

      Config getConfig()
      Allows to get configuration provided during Redisson instance creation. Further changes on this object not affect Redisson instance.
      Returns:
      Config object
    • getNodesGroup

      NodesGroup<Node> getNodesGroup()
      Get Redis nodes group for server operations
      Returns:
      NodesGroup object
    • getClusterNodesGroup

      NodesGroup<ClusterNode> getClusterNodesGroup()
      Get Redis cluster nodes group for server operations
      Returns:
      NodesGroup object
    • isShutdown

      boolean isShutdown()
      Returns true if this Redisson instance has been shut down.
      Returns:
      true if this Redisson instance has been shut down otherwise false
    • isShuttingDown

      boolean isShuttingDown()
      Returns true if this Redisson instance was started to be shutdown or was shutdown isShutdown() already.
      Returns:
      true if this Redisson instance was started to be shutdown or was shutdown isShutdown() already otherwise false
    • getId

      String getId()
      Returns id of this Redisson instance
      Returns:
      id