Uses of Interface
org.redisson.client.codec.Codec
-
-
Uses of Codec in org.redisson
Fields in org.redisson declared as Codec Modifier and Type Field Description protected Codec
RedissonBuckets. codec
protected Codec
RedissonObject. codec
Methods in org.redisson that return Codec Modifier and Type Method Description Codec
RedissonObject. getCodec()
Methods in org.redisson that return types with arguments of type Codec Modifier and Type Method Description Class<? extends Codec>
RedissonReference. getCodecType()
Methods in org.redisson with parameters of type Codec Modifier and Type Method Description RedissonSortedSet.BinarySearchResult<V>
RedissonSortedSet. binarySearch(V value, Codec codec)
static RedissonTopic
RedissonTopic. createRaw(Codec codec, CommandAsyncExecutor commandExecutor, String name)
<R> RFuture<R>
RedissonScript. evalShaAsync(String key, RScript.Mode mode, Codec codec, String shaDigest, RScript.ReturnType returnType, List<Object> keys, Object... values)
protected <T> RFuture<T>
RedissonBaseLock. evalWriteAsync(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<V> RBlockingDeque<V>
Redisson. getBlockingDeque(String name, Codec codec)
<V> RBlockingDequeAsync<V>
RedissonBatch. getBlockingDeque(String name, Codec codec)
<V> RBlockingDequeReactive<V>
RedissonReactive. getBlockingDeque(String name, Codec codec)
<V> RBlockingDequeRx<V>
RedissonRx. getBlockingDeque(String name, Codec codec)
<V> RBlockingQueue<V>
Redisson. getBlockingQueue(String name, Codec codec)
<V> RBlockingQueueAsync<V>
RedissonBatch. getBlockingQueue(String name, Codec codec)
<V> RBlockingQueueReactive<V>
RedissonReactive. getBlockingQueue(String name, Codec codec)
<V> RBlockingQueueRx<V>
RedissonRx. getBlockingQueue(String name, Codec codec)
<V> RBloomFilter<V>
Redisson. getBloomFilter(String name, Codec codec)
<V> RBoundedBlockingQueue<V>
Redisson. getBoundedBlockingQueue(String name, Codec codec)
<V> RBucket<V>
Redisson. getBucket(String name, Codec codec)
<V> RBucketAsync<V>
RedissonBatch. getBucket(String name, Codec codec)
<V> RBucketReactive<V>
RedissonReactive. getBucket(String name, Codec codec)
<V> RBucketRx<V>
RedissonRx. getBucket(String name, Codec codec)
RBuckets
Redisson. getBuckets(Codec codec)
RBucketsReactive
RedissonReactive. getBuckets(Codec codec)
RBucketsRx
RedissonRx. getBuckets(Codec codec)
<V> RDeque<V>
Redisson. getDeque(String name, Codec codec)
<V> RDequeAsync<V>
RedissonBatch. getDeque(String name, Codec codec)
<V> RDequeReactive<V>
RedissonReactive. getDeque(String name, Codec codec)
<V> RDequeRx<V>
RedissonRx. getDeque(String name, Codec codec)
RScheduledExecutorService
Redisson. getExecutorService(String name, Codec codec)
RScheduledExecutorService
Redisson. getExecutorService(String name, Codec codec, ExecutorOptions options)
<V> RGeo<V>
Redisson. getGeo(String name, Codec codec)
<V> RGeoAsync<V>
RedissonBatch. getGeo(String name, Codec codec)
<V> RGeoReactive<V>
RedissonReactive. getGeo(String name, Codec codec)
<V> RGeoRx<V>
RedissonRx. getGeo(String name, Codec codec)
<V> RHyperLogLog<V>
Redisson. getHyperLogLog(String name, Codec codec)
<V> RHyperLogLogAsync<V>
RedissonBatch. getHyperLogLog(String name, Codec codec)
<V> RHyperLogLogReactive<V>
RedissonReactive. getHyperLogLog(String name, Codec codec)
<V> RHyperLogLogRx<V>
RedissonRx. getHyperLogLog(String name, Codec codec)
<V> RList<V>
Redisson. getList(String name, Codec codec)
<V> RListAsync<V>
RedissonBatch. getList(String name, Codec codec)
<V> RListReactive<V>
RedissonReactive. getList(String name, Codec codec)
<V> RListRx<V>
RedissonRx. getList(String name, Codec codec)
<K,V>
RListMultimap<K,V>Redisson. getListMultimap(String name, Codec codec)
<K,V>
RMultimapAsync<K,V>RedissonBatch. getListMultimap(String name, Codec codec)
<K,V>
RListMultimapReactive<K,V>RedissonReactive. getListMultimap(String name, Codec codec)
<K,V>
RListMultimapRx<K,V>RedissonRx. getListMultimap(String name, Codec codec)
<K,V>
RListMultimapCache<K,V>Redisson. getListMultimapCache(String name, Codec codec)
<K,V>
RMultimapCacheAsync<K,V>RedissonBatch. getListMultimapCache(String name, Codec codec)
<K,V>
RListMultimapCacheReactive<K,V>RedissonReactive. getListMultimapCache(String name, Codec codec)
<K,V>
RListMultimapCacheRx<K,V>RedissonRx. getListMultimapCache(String name, Codec codec)
<K,V>
RLocalCachedMap<K,V>Redisson. getLocalCachedMap(String name, Codec codec, LocalCachedMapOptions<K,V> options)
<K,V>
RMap<K,V>Redisson. getMap(String name, Codec codec)
<K,V>
RMap<K,V>Redisson. getMap(String name, Codec codec, MapOptions<K,V> options)
<K,V>
RMapAsync<K,V>RedissonBatch. getMap(String name, Codec codec)
<K,V>
RMapReactive<K,V>RedissonReactive. getMap(String name, Codec codec)
<K,V>
RMapReactive<K,V>RedissonReactive. getMap(String name, Codec codec, MapOptions<K,V> options)
<K,V>
RMapRx<K,V>RedissonRx. getMap(String name, Codec codec)
<K,V>
RMapRx<K,V>RedissonRx. getMap(String name, Codec codec, MapOptions<K,V> options)
<K,V>
RMapCache<K,V>Redisson. getMapCache(String name, Codec codec)
<K,V>
RMapCache<K,V>Redisson. getMapCache(String name, Codec codec, MapOptions<K,V> options)
<K,V>
RMapCacheAsync<K,V>RedissonBatch. getMapCache(String name, Codec codec)
<K,V>
RMapCacheReactive<K,V>RedissonReactive. getMapCache(String name, Codec codec)
<K,V>
RMapCacheReactive<K,V>RedissonReactive. getMapCache(String name, Codec codec, MapOptions<K,V> options)
<K,V>
RMapCacheRx<K,V>RedissonRx. getMapCache(String name, Codec codec)
<K,V>
RMapCacheRx<K,V>RedissonRx. getMapCache(String name, Codec codec, MapOptions<K,V> options)
RPatternTopic
Redisson. getPatternTopic(String pattern, Codec codec)
RPatternTopicReactive
RedissonReactive. getPatternTopic(String pattern, Codec codec)
RPatternTopicRx
RedissonRx. getPatternTopic(String pattern, Codec codec)
<V> RPriorityBlockingDeque<V>
Redisson. getPriorityBlockingDeque(String name, Codec codec)
<V> RPriorityBlockingQueue<V>
Redisson. getPriorityBlockingQueue(String name, Codec codec)
<V> RPriorityDeque<V>
Redisson. getPriorityDeque(String name, Codec codec)
<V> RPriorityQueue<V>
Redisson. getPriorityQueue(String name, Codec codec)
<V> RQueue<V>
Redisson. getQueue(String name, Codec codec)
<V> RQueueAsync<V>
RedissonBatch. getQueue(String name, Codec codec)
<V> RQueueReactive<V>
RedissonReactive. getQueue(String name, Codec codec)
<V> RQueueRx<V>
RedissonRx. getQueue(String name, Codec codec)
RReliableTopic
Redisson. getReliableTopic(String name, Codec codec)
RReliableTopicReactive
RedissonReactive. getReliableTopic(String name, Codec codec)
RReliableTopicRx
RedissonRx. getReliableTopic(String name, Codec codec)
RRemoteService
Redisson. getRemoteService(String name, Codec codec)
RRemoteService
Redisson. getRemoteService(Codec codec)
RRemoteService
RedissonReactive. getRemoteService(String name, Codec codec)
RRemoteService
RedissonReactive. getRemoteService(Codec codec)
RRemoteService
RedissonRx. getRemoteService(String name, Codec codec)
RRemoteService
RedissonRx. getRemoteService(Codec codec)
<V> RRingBuffer<V>
Redisson. getRingBuffer(String name, Codec codec)
<V> RRingBufferReactive<V>
RedissonReactive. getRingBuffer(String name, Codec codec)
<V> RRingBufferRx<V>
RedissonRx. getRingBuffer(String name, Codec codec)
<V> RScoredSortedSet<V>
Redisson. getScoredSortedSet(String name, Codec codec)
<V> RScoredSortedSetAsync<V>
RedissonBatch. getScoredSortedSet(String name, Codec codec)
<V> RScoredSortedSetReactive<V>
RedissonReactive. getScoredSortedSet(String name, Codec codec)
<V> RScoredSortedSetRx<V>
RedissonRx. getScoredSortedSet(String name, Codec codec)
RScript
Redisson. getScript(Codec codec)
RScript
RedissonBatch. getScript(Codec codec)
RScriptReactive
RedissonReactive. getScript(Codec codec)
RScriptRx
RedissonRx. getScript(Codec codec)
<V> RSet<V>
Redisson. getSet(String name, Codec codec)
<V> RSetAsync<V>
RedissonBatch. getSet(String name, Codec codec)
<V> RSetReactive<V>
RedissonReactive. getSet(String name, Codec codec)
<V> RSetRx<V>
RedissonRx. getSet(String name, Codec codec)
<V> RSetCache<V>
Redisson. getSetCache(String name, Codec codec)
<V> RSetCacheAsync<V>
RedissonBatch. getSetCache(String name, Codec codec)
<V> RSetCacheReactive<V>
RedissonReactive. getSetCache(String name, Codec codec)
<V> RSetCacheRx<V>
RedissonRx. getSetCache(String name, Codec codec)
<K,V>
RSetMultimap<K,V>Redisson. getSetMultimap(String name, Codec codec)
<K,V>
RMultimapAsync<K,V>RedissonBatch. getSetMultimap(String name, Codec codec)
<K,V>
RSetMultimapReactive<K,V>RedissonReactive. getSetMultimap(String name, Codec codec)
<K,V>
RSetMultimapRx<K,V>RedissonRx. getSetMultimap(String name, Codec codec)
<K,V>
RSetMultimapCache<K,V>Redisson. getSetMultimapCache(String name, Codec codec)
<K,V>
RMultimapCacheAsync<K,V>RedissonBatch. getSetMultimapCache(String name, Codec codec)
<K,V>
RSetMultimapCacheReactive<K,V>RedissonReactive. getSetMultimapCache(String name, Codec codec)
<K,V>
RSetMultimapCacheRx<K,V>RedissonRx. getSetMultimapCache(String name, Codec codec)
<V> RSortedSet<V>
Redisson. getSortedSet(String name, Codec codec)
<K,V>
RStream<K,V>Redisson. getStream(String name, Codec codec)
<K,V>
RStreamAsync<K,V>RedissonBatch. getStream(String name, Codec codec)
<K,V>
RStreamReactive<K,V>RedissonReactive. getStream(String name, Codec codec)
<K,V>
RStreamRx<K,V>RedissonRx. getStream(String name, Codec codec)
<V> RTimeSeries<V>
Redisson. getTimeSeries(String name, Codec codec)
<V> RTimeSeriesReactive<V>
RedissonReactive. getTimeSeries(String name, Codec codec)
<V> RTimeSeriesRx<V>
RedissonRx. getTimeSeries(String name, Codec codec)
RTopic
Redisson. getTopic(String name, Codec codec)
RTopicAsync
RedissonBatch. getTopic(String name, Codec codec)
RTopicReactive
RedissonReactive. getTopic(String name, Codec codec)
RTopicRx
RedissonRx. getTopic(String name, Codec codec)
<V> RTransferQueue<V>
Redisson. getTransferQueue(String name, Codec codec)
<V> RTransferQueueReactive<V>
RedissonReactive. getTransferQueue(String name, Codec codec)
<V> RTransferQueueRx<V>
RedissonRx. getTransferQueue(String name, Codec codec)
-
Uses of Codec in org.redisson.api
Methods in org.redisson.api that return Codec Modifier and Type Method Description Codec
RObject. getCodec()
Returns the underlying Codec used by this RObjectCodec
RObjectReactive. getCodec()
Codec
RObjectRx. getCodec()
Methods in org.redisson.api with parameters of type Codec Modifier and Type Method Description <V> RBlockingDequeAsync<V>
RBatch. getBlockingDeque(String name, Codec codec)
<V> RBlockingDequeReactive<V>
RBatchReactive. getBlockingDeque(String name, Codec codec)
<V> RBlockingDequeRx<V>
RBatchRx. getBlockingDeque(String name, Codec codec)
<V> RBlockingDeque<V>
RedissonClient. getBlockingDeque(String name, Codec codec)
Returns unbounded blocking deque instance by name using provided codec for deque objects.<V> RBlockingDequeReactive<V>
RedissonReactiveClient. getBlockingDeque(String name, Codec codec)
Returns unbounded blocking deque instance by name using provided codec for deque objects.<V> RBlockingDequeRx<V>
RedissonRxClient. getBlockingDeque(String name, Codec codec)
Returns unbounded blocking deque instance by name using provided codec for deque objects.<V> RBlockingQueueAsync<V>
RBatch. getBlockingQueue(String name, Codec codec)
<V> RBlockingQueueReactive<V>
RBatchReactive. getBlockingQueue(String name, Codec codec)
<V> RBlockingQueueRx<V>
RBatchRx. getBlockingQueue(String name, Codec codec)
<V> RBlockingQueue<V>
RedissonClient. getBlockingQueue(String name, Codec codec)
Returns unbounded blocking queue instance by name using provided codec for queue objects.<V> RBlockingQueueReactive<V>
RedissonReactiveClient. getBlockingQueue(String name, Codec codec)
Returns blocking queue instance by name using provided codec for queue objects.<V> RBlockingQueueRx<V>
RedissonRxClient. getBlockingQueue(String name, Codec codec)
Returns blocking queue instance by name using provided codec for queue objects.<V> RBloomFilter<V>
RedissonClient. getBloomFilter(String name, Codec codec)
Returns bloom filter instance by name using provided codec for objects.<V> RBoundedBlockingQueue<V>
RedissonClient. getBoundedBlockingQueue(String name, Codec codec)
Returns bounded blocking queue instance by name using provided codec for queue objects.<V> RBucketAsync<V>
RBatch. getBucket(String name, Codec codec)
<V> RBucketReactive<V>
RBatchReactive. getBucket(String name, Codec codec)
<V> RBucketRx<V>
RBatchRx. getBucket(String name, Codec codec)
<V> RBucket<V>
RedissonClient. getBucket(String name, Codec codec)
Returns object holder instance by name using provided codec for object.<V> RBucketReactive<V>
RedissonReactiveClient. getBucket(String name, Codec codec)
Returns object holder instance by name using provided codec for object.<V> RBucketRx<V>
RedissonRxClient. getBucket(String name, Codec codec)
Returns object holder instance by name using provided codec for object.<V> RBucket<V>
RTransaction. getBucket(String name, Codec codec)
Returns transactional object holder instance by name using provided codec for object.<V> RBucketReactive<V>
RTransactionReactive. getBucket(String name, Codec codec)
Returns transactional object holder instance by name using provided codec for object.<V> RBucketRx<V>
RTransactionRx. getBucket(String name, Codec codec)
Returns transactional object holder instance by name using provided codec for object.RBuckets
RedissonClient. getBuckets(Codec codec)
Returns interface for mass operations with Bucket objects using provided codec for object.RBucketsReactive
RedissonReactiveClient. getBuckets(Codec codec)
Returns interface for mass operations with Bucket objects using provided codec for object.RBucketsRx
RedissonRxClient. getBuckets(Codec codec)
Returns interface for mass operations with Bucket objects using provided codec for object.RBuckets
RTransaction. getBuckets(Codec codec)
Returns transactional interface for mass operations with Bucket objects using provided codec for object.<V> RDequeAsync<V>
RBatch. getDeque(String name, Codec codec)
<V> RDequeReactive<V>
RBatchReactive. getDeque(String name, Codec codec)
<V> RDequeRx<V>
RBatchRx. getDeque(String name, Codec codec)
<V> RDeque<V>
RedissonClient. getDeque(String name, Codec codec)
Returns unbounded deque instance by name using provided codec for deque objects.<V> RDequeReactive<V>
RedissonReactiveClient. getDeque(String name, Codec codec)
Returns deque instance by name using provided codec for deque objects.<V> RDequeRx<V>
RedissonRxClient. getDeque(String name, Codec codec)
Returns deque instance by name using provided codec for deque objects.RScheduledExecutorService
RedissonClient. getExecutorService(String name, Codec codec)
Returns ScheduledExecutorService by name using provided codec for task, response and request serializationRScheduledExecutorService
RedissonClient. getExecutorService(String name, Codec codec, ExecutorOptions options)
Returns ScheduledExecutorService by name using provided codec for task, response and request serialization<V> RGeoAsync<V>
RBatch. getGeo(String name, Codec codec)
Returns geospatial items holder instance byname
using provided codec for geospatial members.<V> RGeoReactive<V>
RBatchReactive. getGeo(String name, Codec codec)
Returns geospatial items holder instance byname
using provided codec for geospatial members.<V> RGeoRx<V>
RBatchRx. getGeo(String name, Codec codec)
Returns geospatial items holder instance byname
using provided codec for geospatial members.<V> RGeo<V>
RedissonClient. getGeo(String name, Codec codec)
Returns geospatial items holder instance byname
using provided codec for geospatial members.<V> RGeoReactive<V>
RedissonReactiveClient. getGeo(String name, Codec codec)
Returns geospatial items holder instance byname
using provided codec for geospatial members.<V> RGeoRx<V>
RedissonRxClient. getGeo(String name, Codec codec)
Returns geospatial items holder instance byname
using provided codec for geospatial members.<V> RHyperLogLogAsync<V>
RBatch. getHyperLogLog(String name, Codec codec)
<V> RHyperLogLogReactive<V>
RBatchReactive. getHyperLogLog(String name, Codec codec)
<V> RHyperLogLogRx<V>
RBatchRx. getHyperLogLog(String name, Codec codec)
<V> RHyperLogLog<V>
RedissonClient. getHyperLogLog(String name, Codec codec)
Returns HyperLogLog instance by name using provided codec for hll objects.<V> RHyperLogLogReactive<V>
RedissonReactiveClient. getHyperLogLog(String name, Codec codec)
Returns HyperLogLog instance by name using provided codec for hll objects.<V> RHyperLogLogRx<V>
RedissonRxClient. getHyperLogLog(String name, Codec codec)
Returns HyperLogLog instance by name using provided codec for hll objects.<V> RListAsync<V>
RBatch. getList(String name, Codec codec)
<V> RListReactive<V>
RBatchReactive. getList(String name, Codec codec)
<V> RListRx<V>
RBatchRx. getList(String name, Codec codec)
<V> RList<V>
RedissonClient. getList(String name, Codec codec)
Returns list instance by name using provided codec for list objects.<V> RListReactive<V>
RedissonReactiveClient. getList(String name, Codec codec)
Returns list instance by name using provided codec for list objects.<V> RListRx<V>
RedissonRxClient. getList(String name, Codec codec)
Returns list instance by name using provided codec for list objects.<K,V>
RMultimapAsync<K,V>RBatch. getListMultimap(String name, Codec codec)
Returns List based MultiMap instance by name using provided codec for both map keys and values.<K,V>
RListMultimapReactive<K,V>RBatchReactive. getListMultimap(String name, Codec codec)
Returns List based MultiMap instance by name using provided codec for both map keys and values.<K,V>
RListMultimapRx<K,V>RBatchRx. getListMultimap(String name, Codec codec)
Returns List based MultiMap instance by name using provided codec for both map keys and values.<K,V>
RListMultimap<K,V>RedissonClient. getListMultimap(String name, Codec codec)
Returns List based Multimap instance by name using provided codec for both map keys and values.<K,V>
RListMultimapReactive<K,V>RedissonReactiveClient. getListMultimap(String name, Codec codec)
Returns List based Multimap instance by name using provided codec for both map keys and values.<K,V>
RListMultimapRx<K,V>RedissonRxClient. getListMultimap(String name, Codec codec)
Returns List based Multimap instance by name using provided codec for both map keys and values.<K,V>
RMultimapAsync<K,V>RBatch. getListMultimapCache(String name, Codec codec)
Returns List based Multimap instance by name using provided codec for both map keys and values.<K,V>
RListMultimapCacheRx<K,V>RBatchRx. getListMultimapCache(String name, Codec codec)
Returns List based Multimap cache instance by name using provided codec for both map keys and values.<K,V>
RListMultimapCache<K,V>RedissonClient. getListMultimapCache(String name, Codec codec)
Returns List based Multimap instance by name using provided codec for both map keys and values.<K,V>
RListMultimapCacheReactive<K,V>RedissonReactiveClient. getListMultimapCache(String name, Codec codec)
Returns List based Multimap cache instance by name using provided codec for both map keys and values.<K,V>
RListMultimapCacheRx<K,V>RedissonRxClient. getListMultimapCache(String name, Codec codec)
Returns List based Multimap cache instance by name using provided codec for both map keys and values.<K,V>
RLocalCachedMap<K,V>RedissonClient. getLocalCachedMap(String name, Codec codec, LocalCachedMapOptions<K,V> options)
Returns local cached map instance by name using provided codec.<K,V>
RMapAsync<K,V>RBatch. getMap(String name, Codec codec)
<K,V>
RMapReactive<K,V>RBatchReactive. getMap(String name, Codec codec)
<K,V>
RMapRx<K,V>RBatchRx. getMap(String name, Codec codec)
<K,V>
RMap<K,V>RedissonClient. getMap(String name, Codec codec)
Returns map instance by name using provided codec for both map keys and values.<K,V>
RMap<K,V>RedissonClient. getMap(String name, Codec codec, MapOptions<K,V> options)
Returns map instance by name using provided codec for both map keys and values.<K,V>
RMapReactive<K,V>RedissonReactiveClient. getMap(String name, Codec codec)
Returns map instance by name using provided codec for both map keys and values.<K,V>
RMapReactive<K,V>RedissonReactiveClient. getMap(String name, Codec codec, MapOptions<K,V> options)
Returns map instance by name using provided codec for both map keys and values.<K,V>
RMapRx<K,V>RedissonRxClient. getMap(String name, Codec codec)
Returns map instance by name using provided codec for both map keys and values.<K,V>
RMapRx<K,V>RedissonRxClient. getMap(String name, Codec codec, MapOptions<K,V> options)
Returns map instance by name using provided codec for both map keys and values.<K,V>
RMap<K,V>RTransaction. getMap(String name, Codec codec)
Returns transactional map instance by name using provided codec for both map keys and values.<K,V>
RMapReactive<K,V>RTransactionReactive. getMap(String name, Codec codec)
Returns transactional map instance by name using provided codec for both map keys and values.<K,V>
RMapRx<K,V>RTransactionRx. getMap(String name, Codec codec)
Returns transactional map instance by name using provided codec for both map keys and values.<K,V>
RMapCacheAsync<K,V>RBatch. getMapCache(String name, Codec codec)
Returns map-based cache instance byname
using providedcodec
for both cache keys and values.<K,V>
RMapCacheReactive<K,V>RBatchReactive. getMapCache(String name, Codec codec)
Returns map-based cache instance byname
using providedcodec
for both cache keys and values.<K,V>
RMapCacheRx<K,V>RBatchRx. getMapCache(String name, Codec codec)
Returns map-based cache instance byname
using providedcodec
for both cache keys and values.<K,V>
RMapCache<K,V>RedissonClient. getMapCache(String name, Codec codec)
Returns map-based cache instance byname
using providedcodec
for both cache keys and values.<K,V>
RMapCache<K,V>RedissonClient. getMapCache(String name, Codec codec, MapOptions<K,V> options)
Returns map-based cache instance byname
using providedcodec
for both cache keys and values.<K,V>
RMapCacheReactive<K,V>RedissonReactiveClient. getMapCache(String name, Codec codec)
Returns map-based cache instance by name using provided codec for both cache keys and values.<K,V>
RMapCacheReactive<K,V>RedissonReactiveClient. getMapCache(String name, Codec codec, MapOptions<K,V> options)
Returns map-based cache instance byname
using providedcodec
for both cache keys and values.<K,V>
RMapCacheRx<K,V>RedissonRxClient. getMapCache(String name, Codec codec)
Returns map-based cache instance by name using provided codec for both cache keys and values.<K,V>
RMapCacheRx<K,V>RedissonRxClient. getMapCache(String name, Codec codec, MapOptions<K,V> options)
Returns map-based cache instance byname
using providedcodec
for both cache keys and values.<K,V>
RMapCache<K,V>RTransaction. getMapCache(String name, Codec codec)
Returns transactional map-based cache instance byname
using providedcodec
for both cache keys and values.<K,V>
RMapCacheReactive<K,V>RTransactionReactive. getMapCache(String name, Codec codec)
Returns transactional map-based cache instance byname
using providedcodec
for both cache keys and values.<K,V>
RMapCacheRx<K,V>RTransactionRx. getMapCache(String name, Codec codec)
Returns transactional map-based cache instance byname
using providedcodec
for both cache keys and values.RPatternTopic
RedissonClient. getPatternTopic(String pattern, Codec codec)
Returns topic instance satisfies by pattern name using provided codec for messages.RPatternTopicReactive
RedissonReactiveClient. getPatternTopic(String pattern, Codec codec)
Returns topic instance satisfies by pattern name using provided codec for messages.RPatternTopicRx
RedissonRxClient. getPatternTopic(String pattern, Codec codec)
Returns topic instance satisfies by pattern name using provided codec for messages.<V> RPriorityBlockingDeque<V>
RedissonClient. getPriorityBlockingDeque(String name, Codec codec)
Returns unbounded priority blocking deque instance by name using provided codec for queue objects.<V> RPriorityBlockingQueue<V>
RedissonClient. getPriorityBlockingQueue(String name, Codec codec)
Returns unbounded priority blocking queue instance by name using provided codec for queue objects.<V> RPriorityDeque<V>
RedissonClient. getPriorityDeque(String name, Codec codec)
Returns priority unbounded deque instance by name using provided codec for queue objects.<V> RPriorityQueue<V>
RedissonClient. getPriorityQueue(String name, Codec codec)
Returns priority unbounded queue instance by name using provided codec for queue objects.<V> RQueueAsync<V>
RBatch. getQueue(String name, Codec codec)
<V> RQueueReactive<V>
RBatchReactive. getQueue(String name, Codec codec)
<V> RQueueRx<V>
RBatchRx. getQueue(String name, Codec codec)
<V> RQueue<V>
RedissonClient. getQueue(String name, Codec codec)
Returns unbounded queue instance by name using provided codec for queue objects.<V> RQueueReactive<V>
RedissonReactiveClient. getQueue(String name, Codec codec)
Returns queue instance by name using provided codec for queue objects.<V> RQueueRx<V>
RedissonRxClient. getQueue(String name, Codec codec)
Returns queue instance by name using provided codec for queue objects.RReliableTopic
RedissonClient. getReliableTopic(String name, Codec codec)
Returns reliable topic instance by name using provided codec for messages.RReliableTopicReactive
RedissonReactiveClient. getReliableTopic(String name, Codec codec)
Returns reliable topic instance by name using provided codec for messages.RReliableTopicRx
RedissonRxClient. getReliableTopic(String name, Codec codec)
Returns reliable topic instance by name using provided codec for messages.RRemoteService
RedissonClient. getRemoteService(String name, Codec codec)
Returns object for remote operations prefixed with the specified name and uses provided codec for method arguments and result.RRemoteService
RedissonClient. 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.RRemoteService
RedissonReactiveClient. getRemoteService(String name, Codec codec)
Returns object for remote operations prefixed with the specified name and uses provided codec for method arguments and result.RRemoteService
RedissonReactiveClient. 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.RRemoteService
RedissonRxClient. getRemoteService(String name, Codec codec)
Returns object for remote operations prefixed with the specified name and uses provided codec for method arguments and result.RRemoteService
RedissonRxClient. 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.<V> RRingBuffer<V>
RedissonClient. getRingBuffer(String name, Codec codec)
Returns RingBuffer based queue.<V> RRingBufferReactive<V>
RedissonReactiveClient. getRingBuffer(String name, Codec codec)
Returns RingBuffer based queue.<V> RRingBufferRx<V>
RedissonRxClient. getRingBuffer(String name, Codec codec)
Returns RingBuffer based queue.<V> RScoredSortedSetAsync<V>
RBatch. getScoredSortedSet(String name, Codec codec)
<V> RScoredSortedSetReactive<V>
RBatchReactive. getScoredSortedSet(String name, Codec codec)
<V> RScoredSortedSetRx<V>
RBatchRx. getScoredSortedSet(String name, Codec codec)
<V> RScoredSortedSet<V>
RedissonClient. getScoredSortedSet(String name, Codec codec)
Returns Redis Sorted Set instance by name using provided codec for sorted set objects.<V> RScoredSortedSetReactive<V>
RedissonReactiveClient. getScoredSortedSet(String name, Codec codec)
Returns Redis Sorted Set instance by name using provided codec for sorted set objects.<V> RScoredSortedSetRx<V>
RedissonRxClient. getScoredSortedSet(String name, Codec codec)
Returns Redis Sorted Set instance by name using provided codec for sorted set objects.RScript
RBatch. getScript(Codec codec)
Returns script operations object using provided codec.RScriptReactive
RBatchReactive. getScript(Codec codec)
Returns script operations object using provided codec.RScriptRx
RBatchRx. getScript(Codec codec)
Returns script operations object using provided codec.RScript
RedissonClient. getScript(Codec codec)
Returns script operations object using provided codec.RScriptReactive
RedissonReactiveClient. getScript(Codec codec)
Returns script operations object using provided codec.RScriptRx
RedissonRxClient. getScript(Codec codec)
Returns script operations object using provided codec.<V> RSetAsync<V>
RBatch. getSet(String name, Codec codec)
<V> RSetReactive<V>
RBatchReactive. getSet(String name, Codec codec)
<V> RSetRx<V>
RBatchRx. getSet(String name, Codec codec)
<V> RSet<V>
RedissonClient. getSet(String name, Codec codec)
Returns set instance by name using provided codec for set objects.<V> RSetReactive<V>
RedissonReactiveClient. getSet(String name, Codec codec)
Returns set instance by name using provided codec for set objects.<V> RSetRx<V>
RedissonRxClient. getSet(String name, Codec codec)
Returns set instance by name using provided codec for set objects.<V> RSet<V>
RTransaction. getSet(String name, Codec codec)
Returns transactional set instance by name using provided codec for set objects.<V> RSetReactive<V>
RTransactionReactive. getSet(String name, Codec codec)
Returns transactional set instance by name using provided codec for set objects.<V> RSetRx<V>
RTransactionRx. getSet(String name, Codec codec)
Returns transactional set instance by name using provided codec for set objects.<V> RSetCacheAsync<V>
RBatch. getSetCache(String name, Codec codec)
Returns set-based cache instance byname
using providedcodec
for values.<V> RSetCacheReactive<V>
RBatchReactive. getSetCache(String name, Codec codec)
Returns set-based cache instance byname
using providedcodec
for values.<V> RSetCacheRx<V>
RBatchRx. getSetCache(String name, Codec codec)
Returns set-based cache instance byname
using providedcodec
for values.<V> RSetCache<V>
RedissonClient. getSetCache(String name, Codec codec)
Returns set-based cache instance byname
.<V> RSetCacheReactive<V>
RedissonReactiveClient. getSetCache(String name, Codec codec)
Returns set-based cache instance byname
.<V> RSetCacheRx<V>
RedissonRxClient. getSetCache(String name, Codec codec)
Returns set-based cache instance byname
.<V> RSetCache<V>
RTransaction. getSetCache(String name, Codec codec)
Returns transactional set-based cache instance byname
.<V> RSetCacheReactive<V>
RTransactionReactive. getSetCache(String name, Codec codec)
Returns transactional set-based cache instance byname
.<V> RSetCacheRx<V>
RTransactionRx. getSetCache(String name, Codec codec)
Returns transactional set-based cache instance byname
.<K,V>
RMultimapAsync<K,V>RBatch. getSetMultimap(String name, Codec codec)
Returns Set based MultiMap instance by name using provided codec for both map keys and values.<K,V>
RSetMultimapReactive<K,V>RBatchReactive. getSetMultimap(String name, Codec codec)
Returns Set based Multimap instance by name using provided codec for both map keys and values.<K,V>
RSetMultimapRx<K,V>RBatchRx. getSetMultimap(String name, Codec codec)
Returns Set based Multimap instance by name using provided codec for both map keys and values.<K,V>
RSetMultimap<K,V>RedissonClient. getSetMultimap(String name, Codec codec)
Returns Set based Multimap instance by name using provided codec for both map keys and values.<K,V>
RSetMultimapReactive<K,V>RedissonReactiveClient. getSetMultimap(String name, Codec codec)
Returns Set based Multimap instance by name using provided codec for both map keys and values.<K,V>
RSetMultimapRx<K,V>RedissonRxClient. getSetMultimap(String name, Codec codec)
Returns Set based Multimap instance by name using provided codec for both map keys and values.<K,V>
RMultimapCacheAsync<K,V>RBatch. getSetMultimapCache(String name, Codec codec)
Returns Set based Multimap instance by name using provided codec for both map keys and values.<K,V>
RSetMultimapCacheRx<K,V>RBatchRx. getSetMultimapCache(String name, Codec codec)
Returns Set based Multimap cache instance by name using provided codec for both map keys and values.<K,V>
RSetMultimapCache<K,V>RedissonClient. getSetMultimapCache(String name, Codec codec)
Returns Set based Multimap instance by name using provided codec for both map keys and values.<K,V>
RSetMultimapCacheReactive<K,V>RedissonReactiveClient. getSetMultimapCache(String name, Codec codec)
Returns Set based Multimap cache instance by name using provided codec for both map keys and values.<K,V>
RSetMultimapCacheRx<K,V>RedissonRxClient. getSetMultimapCache(String name, Codec codec)
Returns Set based Multimap cache instance by name using provided codec for both map keys and values.<V> RSortedSet<V>
RedissonClient. getSortedSet(String name, Codec codec)
Returns sorted set instance by name using provided codec for sorted set objects.<K,V>
RStreamAsync<K,V>RBatch. getStream(String name, Codec codec)
Returns stream instance byname
using providedcodec
for entries.<K,V>
RStreamReactive<K,V>RBatchReactive. getStream(String name, Codec codec)
Returns stream instance byname
using providedcodec
for entries.<K,V>
RStreamRx<K,V>RBatchRx. getStream(String name, Codec codec)
Returns stream instance byname
using providedcodec
for entries.<K,V>
RStream<K,V>RedissonClient. getStream(String name, Codec codec)
Returns stream instance byname
using providedcodec
for entries.<K,V>
RStreamReactive<K,V>RedissonReactiveClient. getStream(String name, Codec codec)
Returns stream instance byname
using providedcodec
for entries.<K,V>
RStreamRx<K,V>RedissonRxClient. getStream(String name, Codec codec)
Returns stream instance byname
using providedcodec
for entries.<V> RTimeSeries<V>
RedissonClient. getTimeSeries(String name, Codec codec)
Returns time-series instance byname
using providedcodec
for values.<V> RTimeSeriesReactive<V>
RedissonReactiveClient. getTimeSeries(String name, Codec codec)
Returns time-series instance byname
using providedcodec
for values.<V> RTimeSeriesRx<V>
RedissonRxClient. getTimeSeries(String name, Codec codec)
Returns time-series instance byname
using providedcodec
for values.RTopicAsync
RBatch. getTopic(String name, Codec codec)
RTopicReactive
RBatchReactive. getTopic(String name, Codec codec)
RTopicRx
RBatchRx. getTopic(String name, Codec codec)
RTopic
RedissonClient. getTopic(String name, Codec codec)
Returns topic instance by name using provided codec for messages.RTopicReactive
RedissonReactiveClient. getTopic(String name, Codec codec)
Returns topic instance by name using provided codec for messages.RTopicRx
RedissonRxClient. getTopic(String name, Codec codec)
Returns topic instance by name using provided codec for messages.<V> RTransferQueue<V>
RedissonClient. getTransferQueue(String name, Codec codec)
Returns transfer queue instance by name using provided codec for queue objects.<V> RTransferQueueReactive<V>
RedissonReactiveClient. getTransferQueue(String name, Codec codec)
Returns transfer queue instance by name using provided codec for queue objects.<V> RTransferQueueRx<V>
RedissonRxClient. getTransferQueue(String name, Codec codec)
Returns transfer queue instance by name using provided codec for queue objects. -
Uses of Codec in org.redisson.api.annotation
Classes in org.redisson.api.annotation that implement Codec Modifier and Type Class Description static class
REntity.DEFAULT
static class
RObjectField.DEFAULT
Methods in org.redisson.api.annotation that return types with arguments of type Codec Modifier and Type Method Description Class<? extends Codec>
codec()
(Optional) Live Object state codec.Class<? extends Codec>
codec()
(Optional) Live Object state codec. -
Uses of Codec in org.redisson.cache
Classes in org.redisson.cache that implement Codec Modifier and Type Class Description class
LocalCachedMessageCodec
Constructors in org.redisson.cache with parameters of type Codec Constructor Description LocalCacheListener(String name, CommandAsyncExecutor commandExecutor, RObject object, Codec codec, LocalCachedMapOptions<?,?> options, long cacheUpdateLogTime)
-
Uses of Codec in org.redisson.client
Methods in org.redisson.client that return types with arguments of type Codec Modifier and Type Method Description Map<ChannelName,Codec>
RedisPubSubConnection. getChannels()
Map<ChannelName,Codec>
RedisPubSubConnection. getPatternChannels()
Methods in org.redisson.client with parameters of type Codec Modifier and Type Method Description <T,R>
RFuture<R>RedisConnection. async(long timeout, Codec encoder, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>RedisConnection. async(Codec encoder, RedisCommand<T> command, Object... params)
<T,R>
CommandData<T,R>RedisConnection. create(Codec encoder, RedisCommand<T> command, Object... params)
io.netty.channel.ChannelFuture
RedisPubSubConnection. psubscribe(Codec codec, ChannelName... channels)
io.netty.channel.ChannelFuture
RedisPubSubConnection. subscribe(Codec codec, ChannelName... channels)
<T,R>
RRedisConnection. sync(Codec encoder, RedisCommand<T> command, Object... params)
-
Uses of Codec in org.redisson.client.codec
Classes in org.redisson.client.codec that implement Codec Modifier and Type Class Description class
BaseCodec
class
BitSetCodec
class
ByteArrayCodec
class
DoubleCodec
class
IntegerCodec
class
LongCodec
class
StringCodec
Methods in org.redisson.client.codec that return Codec Modifier and Type Method Description static Codec
BaseCodec. copy(ClassLoader classLoader, Codec codec)
Methods in org.redisson.client.codec with parameters of type Codec Modifier and Type Method Description static Codec
BaseCodec. copy(ClassLoader classLoader, Codec codec)
-
Uses of Codec in org.redisson.client.protocol
Methods in org.redisson.client.protocol that return Codec Modifier and Type Method Description Codec
CommandData. getCodec()
Constructors in org.redisson.client.protocol with parameters of type Codec 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)
-
Uses of Codec in org.redisson.client.protocol.decoder
Methods in org.redisson.client.protocol.decoder with parameters of type Codec Modifier and Type Method Description Decoder<Object>
AutoClaimDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
FastAutoClaimDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
GeoDistanceDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
GeoPositionDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ListMultiDecoder2. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ListObjectDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ListResultReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ListScanResultReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
Long2MultiDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
MapCacheScanResultReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
MapEntriesDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
MapKeyDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
MapScanResultReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
MapValueDecoder. getDecoder(Codec codec, int paramNum, State state)
default Decoder<Object>
MultiDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ObjectDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ObjectFirstScoreReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ObjectListReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ObjectMapDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ObjectMapEntryReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ObjectMapReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
RedisURIDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ScoredSortedSetPolledObjectDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ScoredSortedSetRandomMapDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ScoredSortedSetReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ScoredSortedSetScanDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
ScoredSortedSetScanReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
SlotsDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
StreamObjectMapReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
StringListReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
StringMapDataDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
TimeSeriesEntryReplayDecoder. getDecoder(Codec codec, int paramNum, State state)
Constructors in org.redisson.client.protocol.decoder with parameters of type Codec Constructor Description ObjectMapReplayDecoder(Codec codec)
-
Uses of Codec in org.redisson.client.protocol.pubsub
Methods in org.redisson.client.protocol.pubsub with parameters of type Codec Modifier and Type Method Description Decoder<Object>
PubSubMessageDecoder. getDecoder(Codec codec, int paramNum, State state)
Decoder<Object>
PubSubPatternMessageDecoder. getDecoder(Codec codec, int paramNum, State state)
-
Uses of Codec in org.redisson.codec
Classes in org.redisson.codec that implement Codec Modifier and Type Class Description class
AvroJacksonCodec
Avro binary codecclass
BaseEventCodec
class
CborJacksonCodec
class
CompositeCodec
class
FstCodec
Efficient and speedy serialization codec fully compatible with JDK Serialization codec.class
IonJacksonCodec
Amazon Ion codec based on Jackson implementation https://github.com/FasterXML/jackson-dataformats-binary/tree/master/ionclass
JsonJacksonCodec
Json codec based on Jackson implementation.class
Kryo5Codec
Kryo 5 codecclass
KryoCodec
Kryo 4 codecclass
LZ4Codec
LZ4 compression codec.class
MapCacheEventCodec
class
MarshallingCodec
JBoss Marshalling codec.class
MsgPackJacksonCodec
MsgPack binary codecclass
SerializationCodec
JDK's serialization codec.class
SmileJacksonCodec
Smile binary codec.class
SnappyCodec
Snappy compression codec.class
SnappyCodecV2
Google's Snappy compression codec.class
TypedJsonJacksonCodec
Json Jackson Type codec.Fields in org.redisson.codec declared as Codec Modifier and Type Field Description protected Codec
BaseEventCodec. codec
Methods in org.redisson.codec with type parameters of type Codec Modifier and Type Method Description <T extends Codec>
TDefaultReferenceCodecProvider. getCodec(Class<T> codecClass)
<T extends Codec>
TDefaultReferenceCodecProvider. getCodec(REntity anno, Class<?> cls, Config config)
<T extends Codec,K extends RObject>
TDefaultReferenceCodecProvider. getCodec(RObjectField anno, Class<?> cls, Class<K> rObjectClass, String fieldName, Config config)
<T extends Codec>
TReferenceCodecProvider. getCodec(Class<T> codecClass)
Get codec instance by its class.<T extends Codec>
TReferenceCodecProvider. getCodec(REntity anno, Class<?> cls, Config config)
Get a codec instance by a REntity annotation and the class annotated with it.<T extends Codec,K extends RObject>
TReferenceCodecProvider. getCodec(RObjectField anno, Class<?> cls, Class<K> rObjectClass, String fieldName, Config config)
Get a codec instance by a RObjectField annotation and the class annotated with REntity, the implementation class of RObject the field is going to be transformed into and the name of the field with this RObjectField annotation.<T extends Codec>
voidDefaultReferenceCodecProvider. registerCodec(Class<T> cls, T codec)
<T extends Codec>
voidReferenceCodecProvider. registerCodec(Class<T> codecClass, T codec)
Register a codec by its class or super class.Constructors in org.redisson.codec with parameters of type Codec Constructor Description BaseEventCodec(Codec codec, BaseEventCodec.OSType osType)
CompositeCodec(Codec mapKeyCodec, Codec mapValueCodec)
CompositeCodec(Codec mapKeyCodec, Codec mapValueCodec, Codec valueCodec)
LZ4Codec(Codec innerCodec)
MapCacheEventCodec(Codec codec, BaseEventCodec.OSType osType)
SnappyCodec(Codec innerCodec)
SnappyCodecV2(Codec innerCodec)
-
Uses of Codec in org.redisson.command
Methods in org.redisson.command that return Codec Modifier and Type Method Description protected Codec
RedisExecutor. getCodec(Codec codec)
Methods in org.redisson.command with parameters of type Codec Modifier and Type Method Description <V,R>
voidCommandAsyncExecutor. async(boolean readOnlyMode, NodeSource source, Codec codec, RedisCommand<V> command, Object[] params, RPromise<R> mainPromise, boolean ignoreRedirect, boolean noRetry)
<V,R>
voidCommandAsyncService. async(boolean readOnlyMode, NodeSource source, Codec codec, RedisCommand<V> command, Object[] params, RPromise<R> mainPromise, boolean ignoreRedirect, boolean noRetry)
<V,R>
voidCommandBatchService. async(boolean readOnlyMode, NodeSource nodeSource, Codec codec, RedisCommand<V> command, Object[] params, RPromise<R> mainPromise, boolean ignoreRedirect, boolean noRetry)
io.netty.buffer.ByteBuf
CommandAsyncExecutor. encode(Codec codec, Object value)
io.netty.buffer.ByteBuf
CommandAsyncService. encode(Codec codec, Object value)
io.netty.buffer.ByteBuf
CommandAsyncExecutor. encodeMapKey(Codec codec, Object value)
io.netty.buffer.ByteBuf
CommandAsyncService. encodeMapKey(Codec codec, Object value)
io.netty.buffer.ByteBuf
CommandAsyncExecutor. encodeMapValue(Codec codec, Object value)
io.netty.buffer.ByteBuf
CommandAsyncService. encodeMapValue(Codec codec, Object value)
<T,R>
RCommandSyncExecutor. evalRead(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RCommandSyncService. evalRead(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. evalReadAsync(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. evalReadAsync(RedisClient client, String name, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. evalReadAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncService. evalReadAsync(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncService. evalReadAsync(RedisClient client, String name, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncService. evalReadAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RCommandSyncExecutor. evalWrite(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RCommandSyncService. evalWrite(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. evalWriteAsync(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. evalWriteAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncService. evalWriteAsync(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncService. evalWriteAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. evalWriteNoRetryAsync(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
<T,R>
RFuture<R>CommandAsyncService. evalWriteNoRetryAsync(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params)
protected Codec
RedisExecutor. getCodec(Codec codec)
<V> RFuture<V>
CommandAsyncExecutor. pollFromAnyAsync(String name, Codec codec, RedisCommand<Object> command, long secondsTimeout, String... queueNames)
<V> RFuture<V>
CommandAsyncService. pollFromAnyAsync(String name, Codec codec, RedisCommand<Object> command, long secondsTimeout, String... queueNames)
<T,R>
RCommandSyncExecutor. read(String key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RCommandSyncService. read(String key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<Collection<R>>CommandAsyncExecutor. readAllAsync(Collection<R> results, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<Collection<R>>CommandAsyncExecutor. readAllAsync(Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<Collection<R>>CommandAsyncService. readAllAsync(Collection<R> results, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<Collection<R>>CommandAsyncService. readAllAsync(Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. readAsync(byte[] key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. readAsync(String key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. readAsync(RedisClient client, byte[] key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. readAsync(RedisClient client, String name, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. readAsync(RedisClient client, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. readAsync(RedisClient client, MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. readAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. readAsync(byte[] key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. readAsync(String key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. readAsync(RedisClient client, byte[] key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. readAsync(RedisClient client, String name, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. readAsync(RedisClient client, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. readAsync(RedisClient client, MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. readAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. readBatchedAsync(Codec codec, RedisCommand<T> command, SlotCallback<T,R> callback, String... keys)
<T,R>
RFuture<R>CommandAsyncService. readBatchedAsync(Codec codec, RedisCommand<T> command, SlotCallback<T,R> callback, String... keys)
<T,R>
RFuture<R>CommandAsyncExecutor. readRandomAsync(Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. readRandomAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. readRandomAsync(Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. readRandomAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params)
<R,T>
RFuture<R>CommandAsyncExecutor. writeAllAsync(Codec codec, RedisCommand<T> command, SlotCallback<T,R> callback, Object... params)
<R,T>
RFuture<R>CommandAsyncService. writeAllAsync(Codec codec, RedisCommand<T> command, SlotCallback<T,R> callback, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. writeAsync(byte[] key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. writeAsync(String key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. writeAsync(RedisClient client, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. writeAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. writeAsync(byte[] key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. writeAsync(String key, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. writeAsync(RedisClient client, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncService. writeAsync(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params)
<T,R>
RFuture<R>CommandAsyncExecutor. writeBatchedAsync(Codec codec, RedisCommand<T> command, SlotCallback<T,R> callback, String... keys)
<T,R>
RFuture<R>CommandAsyncService. writeBatchedAsync(Codec codec, RedisCommand<T> command, SlotCallback<T,R> callback, String... keys)
-
Uses of Codec in org.redisson.config
Methods in org.redisson.config that return Codec Modifier and Type Method Description Codec
Config. getCodec()
Methods in org.redisson.config with parameters of type Codec Modifier and Type Method Description Config
Config. setCodec(Codec codec)
Redis data codec. -
Uses of Codec in org.redisson.connection
Fields in org.redisson.connection declared as Codec Modifier and Type Field Description protected Codec
MasterSlaveConnectionManager. codec
Methods in org.redisson.connection that return Codec Modifier and Type Method Description Codec
ConnectionManager. getCodec()
Codec
MasterSlaveConnectionManager. getCodec()
-
Uses of Codec in org.redisson.executor
Constructors in org.redisson.executor with parameters of type Codec Constructor Description RedissonExecutorRemoteService(Codec codec, String name, CommandAsyncExecutor commandExecutor, String executorId, ConcurrentMap<String,ResponseEntry> responses)
ScheduledTasksService(Codec codec, String name, CommandAsyncExecutor commandExecutor, String redissonId, ConcurrentMap<String,ResponseEntry> responses)
TasksBatchService(Codec codec, String name, CommandAsyncExecutor commandExecutor, String executorId, ConcurrentMap<String,ResponseEntry> responses)
TasksRunnerService(CommandAsyncExecutor commandExecutor, RedissonClient redisson, Codec codec, String name, ConcurrentMap<String,ResponseEntry> responses)
TasksService(Codec codec, String name, CommandAsyncExecutor commandExecutor, String executorId, ConcurrentMap<String,ResponseEntry> responses)
-
Uses of Codec in org.redisson.jcache
Classes in org.redisson.jcache that implement Codec Modifier and Type Class Description class
JCacheEventCodec
Constructors in org.redisson.jcache with parameters of type Codec Constructor Description JCacheEventCodec(Codec codec, BaseEventCodec.OSType osType, boolean sync)
JCacheEventCodec(Codec codec, BaseEventCodec.OSType osType, boolean sync, boolean expectOldValueInMsg)
-
Uses of Codec in org.redisson.liveobject.core
Methods in org.redisson.liveobject.core with parameters of type Codec Modifier and Type Method Description NamingScheme
RedissonObjectBuilder. getNamingScheme(Class<?> rEntity, Codec c)
-
Uses of Codec in org.redisson.liveobject.resolver
Fields in org.redisson.liveobject.resolver declared as Codec Modifier and Type Field Description protected Codec
AbstractNamingScheme. codec
Methods in org.redisson.liveobject.resolver that return Codec Modifier and Type Method Description Codec
AbstractNamingScheme. getCodec()
Codec
NamingScheme. getCodec()
Constructors in org.redisson.liveobject.resolver with parameters of type Codec Constructor Description AbstractNamingScheme(Codec codec)
DefaultNamingScheme(Codec codec)
-
Uses of Codec in org.redisson.mapreduce
Fields in org.redisson.mapreduce declared as Codec Modifier and Type Field Description protected Codec
CoordinatorTask. codec
Constructors in org.redisson.mapreduce with parameters of type Codec Constructor Description Collector(Codec codec, RedissonClient client, String name, int parts, long timeout)
-
Uses of Codec in org.redisson.pubsub
Methods in org.redisson.pubsub that return types with arguments of type Codec Modifier and Type Method Description RFuture<Codec>
PublishSubscribeService. unsubscribe(ChannelName channelName, PubSubType topicType)
Methods in org.redisson.pubsub with parameters of type Codec Modifier and Type Method Description RFuture<Collection<PubSubConnectionEntry>>
PublishSubscribeService. psubscribe(ChannelName channelName, Codec codec, RedisPubSubListener<?>... listeners)
io.netty.channel.ChannelFuture
PubSubConnectionEntry. psubscribe(Codec codec, ChannelName pattern)
RFuture<PubSubConnectionEntry>
PublishSubscribeService. subscribe(Codec codec, String channelName, AsyncSemaphore semaphore, RedisPubSubListener<?>... listeners)
RFuture<PubSubConnectionEntry>
PublishSubscribeService. subscribe(Codec codec, ChannelName channelName, RedisPubSubListener<?>... listeners)
io.netty.channel.ChannelFuture
PubSubConnectionEntry. subscribe(Codec codec, ChannelName channelName)
-
Uses of Codec in org.redisson.reactive
Methods in org.redisson.reactive with parameters of type Codec 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, boolean noRetry)
<V> RBlockingDequeReactive<V>
RedissonBatchReactive. getBlockingDeque(String name, Codec codec)
<V> RBlockingQueueReactive<V>
RedissonBatchReactive. getBlockingQueue(String name, Codec codec)
<V> RBucketReactive<V>
RedissonBatchReactive. getBucket(String name, Codec codec)
<V> RBucketReactive<V>
RedissonTransactionReactive. getBucket(String name, Codec codec)
<V> RDequeReactive<V>
RedissonBatchReactive. getDeque(String name, Codec codec)
<V> RGeoReactive<V>
RedissonBatchReactive. getGeo(String name, Codec codec)
<V> RHyperLogLogReactive<V>
RedissonBatchReactive. getHyperLogLog(String name, Codec codec)
<V> RListReactive<V>
RedissonBatchReactive. getList(String name, Codec codec)
<K,V>
RListMultimapReactive<K,V>RedissonBatchReactive. getListMultimap(String name, Codec codec)
<K,V>
RMapReactive<K,V>RedissonBatchReactive. getMap(String name, Codec codec)
<K,V>
RMapReactive<K,V>RedissonTransactionReactive. getMap(String name, Codec codec)
<K,V>
RMapCacheReactive<K,V>RedissonBatchReactive. getMapCache(String name, Codec codec)
<K,V>
RMapCacheReactive<K,V>RedissonTransactionReactive. getMapCache(String name, Codec codec)
<V> RQueueReactive<V>
RedissonBatchReactive. getQueue(String name, Codec codec)
<V> RScoredSortedSetReactive<V>
RedissonBatchReactive. getScoredSortedSet(String name, Codec codec)
RScriptReactive
RedissonBatchReactive. getScript(Codec codec)
<V> RSetReactive<V>
RedissonBatchReactive. getSet(String name, Codec codec)
<V> RSetReactive<V>
RedissonTransactionReactive. getSet(String name, Codec codec)
<V> RSetCacheReactive<V>
RedissonBatchReactive. getSetCache(String name, Codec codec)
<V> RSetCacheReactive<V>
RedissonTransactionReactive. getSetCache(String name, Codec codec)
<K,V>
RSetMultimapReactive<K,V>RedissonBatchReactive. getSetMultimap(String name, Codec codec)
<K,V>
RStreamReactive<K,V>RedissonBatchReactive. getStream(String name, Codec codec)
RTopicReactive
RedissonBatchReactive. getTopic(String name, Codec codec)
Constructors in org.redisson.reactive with parameters of type Codec Constructor Description RedissonListMultimapReactive(Codec codec, CommandReactiveExecutor commandExecutor, String name)
RedissonListReactive(Codec codec, CommandReactiveExecutor commandExecutor, String name)
RedissonScoredSortedSetReactive(Codec codec, CommandReactiveExecutor commandExecutor, String name)
RedissonSetMultimapReactive(Codec codec, CommandReactiveExecutor commandExecutor, String name, RedissonReactiveClient redisson)
-
Uses of Codec in org.redisson.remote
Fields in org.redisson.remote declared as Codec Modifier and Type Field Description protected Codec
BaseRemoteService. codec
Constructors in org.redisson.remote with parameters of type Codec Constructor Description AsyncRemoteProxy(CommandAsyncExecutor commandExecutor, String name, String responseQueueName, ConcurrentMap<String,ResponseEntry> responses, Codec codec, String executorId, String cancelRequestMapName, BaseRemoteService remoteService)
BaseRemoteService(Codec codec, String name, CommandAsyncExecutor commandExecutor, String executorId, ConcurrentMap<String,ResponseEntry> responses)
ReactiveRemoteProxy(CommandAsyncExecutor commandExecutor, String name, String responseQueueName, ConcurrentMap<String,ResponseEntry> responses, Codec codec, String executorId, String cancelRequestMapName, BaseRemoteService remoteService)
RxRemoteProxy(CommandAsyncExecutor commandExecutor, String name, String responseQueueName, ConcurrentMap<String,ResponseEntry> responses, Codec codec, String executorId, String cancelRequestMapName, BaseRemoteService remoteService)
SyncRemoteProxy(CommandAsyncExecutor commandExecutor, String name, String responseQueueName, ConcurrentMap<String,ResponseEntry> responses, Codec codec, String executorId, BaseRemoteService remoteService)
-
Uses of Codec in org.redisson.rx
Methods in org.redisson.rx with parameters of type Codec 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, boolean noRetry)
<V> RBlockingDequeRx<V>
RedissonBatchRx. getBlockingDeque(String name, Codec codec)
<V> RBlockingQueueRx<V>
RedissonBatchRx. getBlockingQueue(String name, Codec codec)
<V> RBucketRx<V>
RedissonBatchRx. getBucket(String name, Codec codec)
<V> RBucketRx<V>
RedissonTransactionRx. getBucket(String name, Codec codec)
<V> RDequeRx<V>
RedissonBatchRx. getDeque(String name, Codec codec)
<V> RGeoRx<V>
RedissonBatchRx. getGeo(String name, Codec codec)
<V> RHyperLogLogRx<V>
RedissonBatchRx. getHyperLogLog(String name, Codec codec)
<V> RListRx<V>
RedissonBatchRx. getList(String name, Codec codec)
<K,V>
RListMultimapRx<K,V>RedissonBatchRx. getListMultimap(String name, Codec codec)
<K,V>
RListMultimapCacheRx<K,V>RedissonBatchRx. getListMultimapCache(String name, Codec codec)
<K,V>
RMapRx<K,V>RedissonBatchRx. getMap(String name, Codec codec)
<K,V>
RMapRx<K,V>RedissonTransactionRx. getMap(String name, Codec codec)
<K,V>
RMapCacheRx<K,V>RedissonBatchRx. getMapCache(String name, Codec codec)
<K,V>
RMapCacheRx<K,V>RedissonTransactionRx. getMapCache(String name, Codec codec)
<V> RQueueRx<V>
RedissonBatchRx. getQueue(String name, Codec codec)
<V> RScoredSortedSetRx<V>
RedissonBatchRx. getScoredSortedSet(String name, Codec codec)
RScriptRx
RedissonBatchRx. getScript(Codec codec)
<V> RSetRx<V>
RedissonBatchRx. getSet(String name, Codec codec)
<V> RSetRx<V>
RedissonTransactionRx. getSet(String name, Codec codec)
<V> RSetCacheRx<V>
RedissonBatchRx. getSetCache(String name, Codec codec)
<V> RSetCacheRx<V>
RedissonTransactionRx. getSetCache(String name, Codec codec)
<K,V>
RSetMultimapRx<K,V>RedissonBatchRx. getSetMultimap(String name, Codec codec)
<K,V>
RSetMultimapCacheRx<K,V>RedissonBatchRx. getSetMultimapCache(String name, Codec codec)
<K,V>
RStreamRx<K,V>RedissonBatchRx. getStream(String name, Codec codec)
RTopicRx
RedissonBatchRx. getTopic(String name, Codec codec)
-
Uses of Codec in org.redisson.spring.cache
Methods in org.redisson.spring.cache with parameters of type Codec Modifier and Type Method Description void
RedissonSpringCacheManager. setCodec(Codec codec)
Set Codec instance shared between all Cache instancesConstructors in org.redisson.spring.cache with parameters of type Codec Constructor Description RedissonSpringCacheManager(RedissonClient redisson, String configLocation, Codec codec)
Creates CacheManager supplied by Redisson instance, Codec instance and Config location path.RedissonSpringCacheManager(RedissonClient redisson, Map<String,? extends CacheConfig> config, Codec codec)
Creates CacheManager supplied by Redisson instance, Codec instance and Cache config mapped by Cache name. -
Uses of Codec in org.redisson.transaction
Methods in org.redisson.transaction that return Codec Modifier and Type Method Description Codec
HashKey. getCodec()
Methods in org.redisson.transaction with parameters of type Codec Modifier and Type Method Description <V> RBucket<V>
RedissonTransaction. getBucket(String name, Codec codec)
RBuckets
RedissonTransaction. getBuckets(Codec codec)
<K,V>
RMap<K,V>RedissonTransaction. getMap(String name, Codec codec)
<K,V>
RMapCache<K,V>RedissonTransaction. getMapCache(String name, Codec codec)
<V> RSet<V>
RedissonTransaction. getSet(String name, Codec codec)
<V> RSetCache<V>
RedissonTransaction. getSetCache(String name, Codec codec)
-
Uses of Codec in org.redisson.transaction.operation
Fields in org.redisson.transaction.operation declared as Codec Modifier and Type Field Description protected Codec
TransactionalOperation. codec
Methods in org.redisson.transaction.operation that return Codec Modifier and Type Method Description Codec
TransactionalOperation. getCodec()
Constructors in org.redisson.transaction.operation with parameters of type Codec Constructor Description TransactionalOperation(String name, Codec codec)
TransactionalOperation(String name, Codec codec, long threadId)
-
Uses of Codec in org.redisson.transaction.operation.bucket
Constructors in org.redisson.transaction.operation.bucket with parameters of type Codec Constructor Description BucketCompareAndSetOperation(String name, String lockName, Codec codec, V expected, V value, String transactionId, long threadId)
BucketGetAndDeleteOperation(String name, String lockName, Codec codec, String transactionId, long threadId)
BucketGetAndSetOperation(String name, String lockName, Codec codec, Object value, long timeToLive, TimeUnit timeUnit, String transactionId)
BucketGetAndSetOperation(String name, String lockName, Codec codec, Object value, String transactionId)
BucketSetOperation(String name, String lockName, Codec codec, Object value, long timeToLive, TimeUnit timeUnit, String transactionId, long threadId)
BucketSetOperation(String name, String lockName, Codec codec, Object value, String transactionId, long threadId)
BucketsTrySetOperation(Codec codec, Map<String,Object> values, String transactionId)
BucketTrySetOperation(String name, String lockName, Codec codec, Object value, long timeToLive, TimeUnit timeUnit, String transactionId, long threadId)
BucketTrySetOperation(String name, String lockName, Codec codec, Object value, String transactionId, long threadId)
-
Uses of Codec in org.redisson.transaction.operation.set
Constructors in org.redisson.transaction.operation.set with parameters of type Codec Constructor Description AddCacheOperation(String name, Codec codec, Object value, long ttl, TimeUnit timeUnit, String transactionId, long threadId)
AddOperation(String name, Codec codec, Object value, String transactionId, long threadId)
MoveOperation(String name, Codec codec, String destinationName, long threadId, Object value, String transactionId)
RemoveCacheOperation(String name, Codec codec, Object value, String transactionId, long threadId)
RemoveOperation(String name, Codec codec, Object value, String transactionId, long threadId)
SetOperation(String name, Codec codec, String transactionId)
SetOperation(String name, Codec codec, String transactionId, long threadId)
-