This repository has been archived by the owner on Dec 22, 2024. It is now read-only.
fix(deps): update dependency org.redisson:redisson-spring-boot-starter to v3.36.0 #644
Add this suggestion to a batch that can be applied as a single commit.
This suggestion is invalid because no changes were made to the code.
Suggestions cannot be applied while the pull request is closed.
Suggestions cannot be applied while viewing a subset of changes.
Only one suggestion per line can be applied in a batch.
Add this suggestion to a batch that can be applied as a single commit.
Applying suggestions on deleted lines is not supported.
You must change the existing code in this line in order to create a valid suggestion.
Outdated suggestions cannot be applied.
This suggestion has been applied or marked resolved.
Suggestions cannot be applied from pending reviews.
Suggestions cannot be applied on multi-line comments.
Suggestions cannot be applied while the pull request is queued to merge.
Suggestion cannot be applied right now. Please check back later.
This PR contains the following updates:
3.24.1
->3.36.0
Release Notes
redisson/redisson (org.redisson:redisson-spring-boot-starter)
v3.36.0
Feature -
Kryo5Codec
useReferences
setting addedFeature -
RListMultimapCacheNative
andRSetMultimapCacheNative
objects added. Require Redis 7.4+Feature -
AggregationOptions.sortBy()
method withwithCount
parameter added (thanks to @pfyod)Feature -
allowedClasses
setting added toFuryCodec
Feature -
addIfAbsent(Map)
method added toRSetCache
object (thanks to @lyrric)Improvement - 'hmget' should be instead of 'hget' in
RMapCache.getAllWithTTLOnly()
methodFixed - RedisExecutor throws "Failed to submit a listener notification task" error during shutdown
Fixed - Keep the jmockit version in the plugin consistent with that in the dependencies (thanks to @lyrric)
Fixed - hostname after comma in Redis Cluster topology isn't parsed
Fixed -
drainToAsync()
method returns an incorrect value (thanks to @seakider)Fixed - numeric cast in
CommandDecoder
Fixed -
RLiveObject
value shouldn't be deleted during index updateFixed -
RSetCache.addAllIfAbsent()
method doesn't workFixed - missed
getSetMultimapCache()
andgetListMultimapCache()
methods inRBatchReactive
objectFixed - missed
getMapCacheNative()
method inRBatch
objectFixed -
MapValueDecoder
throws NPEFixed -
EnumMap
type handling byKryo5Codec
Fixed -
Kryo5Codec
registrationRequired
setting replaced withallowedClasses
Fixed - JCache eviction task isn't removed on
close()
method invocationFixed - missed
destroy()
method forRListMultimapCache
andRSetMultimapCache
objectsv3.35.0
Feature -
INDEXEMPTY
option added to tag and text fields inRSearch.createIndex()
methodFeature -
INDEXMISSING
option added to all fields inRSearch.createIndex()
methodFeature -
StreamMessageId.LAST
option addedFeature -
copy()
andcopyAndReplace()
methods added toRObject
interfaceFeature - Apache Fury codec support
Feature -
RSetCache
object supportsTrackingListener
,SetAddListener
andSetRemoveListener
listenersFeature -
RClusteredMapCacheNative
object implemented. Requires Redis 7.4+Feature -
RLocalCachedMapCacheNative
object implemented. Requires Redis 7.4+Feature -
localcache_native
andclustered_native
implementations added to Quarkus module. Requires Redis 7.4+Feature -
RedissonClusteredCacheNative
andRedissonLocalCachedCacheNative
implementations added to MyBatis module. Requires Redis 7.4+Feature -
RedissonClusteredSpringCacheNativeManager
andRedissonSpringLocalCachedCacheNativeManager
implementations added to Spring Cache module. Requires Redis 7.4+Feature -
RedissonClusteredNativeRegionFactory
andRedissonLocalCachedNativeRegionFactory
added to Hibernate module. Requires Redis 7.4+Feature -
local-caches-native
andclustered-caches-native
implementations added to Micronaut module. Requires Redis 7.4+Improvement -
ProtobufCodec
memory allocation optimizationImprovement - Apache Fury codec optimization (thanks to @chaokunyang)
Improvement - quarkus should make an attempt to read config file using Thread's ContextClassLoader
Improvement - quarkus should make an attempt to read config file using Thread's ContextClassLoader (thanks to @seakider)
Improvement - don't take lock for
RMap.computeIfAbsent()
if only get is needed (thanks to @shreyas-sprinklr)Fixed - writer, writeMode, writerAsync, writeBehindDelay, writeBehindBatchSize, loader, loaderAsync settings aren't applied to caches-native in Micronaut module
Fixed - missed
caches-native
implementation for Micronaut 3.x and Micronaut 2.xFixed - a new retry attempt to the same node isn't made for INFO_REPLICATION, SENTINEL_GET_MASTER_ADDR_BY_NAME, SENTINEL_SENTINELS, SENTINEL_SLAVES and CLUSTER_NODES commands
Fixed -
RType.JSON
andRType.STREAM
can't be resolved byRKey.getType()
methodFixed -
RKeys.removeListener()
method doesn't removeNewObjectListener
andSetObjectListener
Fixed -
copy()
method doesn't works with db (thanks to @seakider)Fixed -
maven.compiler.release
setting isn't definedFixed -
RSearch.info()
method throwsNumberFormatException
(thanks to @iamtakingiteasy)Fixed - timeout parameters defined per object aren't applied to
RJsonBuckets
andRJsonBucket
objectsFixed - RedisException is thrown by
.removeAll()
and.indexOf()
methods ofRedissonSubList
object (thanks to @seakider)Fixed - wrong event keyspace name for
MapCacheNative
object (thanks to @larryTheCoder)Fixed - missed
rename()
andrenamenx()
methods implementation forRIdGenerator
,RMapCache
andRTimeSeries
objectsFixed -
Kryo5Codec
doesn't handleUnmodifiableCollection
,SynchronizedCollection
andCheckedCollection
Fixed -
RRateLimiter
incorrect rate count in the event of an attempt to exceed the limitFixed -
credentials-resolver
,failed-slave-node-detector
,command-mapper
,name-mapper
,nat-mapper
settings aren't recognized by Helidon and QuarkusFixed -
RMultimapCacheReactive.expireKey()
method returns Single instead of Reactor MonoFixed -
@RObjectField
annotation with codec option has no effectFixed - an exception is thrown if the
@RObjectField
annotation is defined on a fieldFixed -
RDestroyable.destroy()
method doesn't remove listenersFixed - FailedSlaveNodeDetector's parameters by can't be defined in YAML config
v3.34.1
Fixed - RObject.rename() method doesn't work in cluster
v3.34.0
Feature - RJsonBuckets object added (thanks to @seakider)
Feature -
remainTimeToLive(Set keys)
andclearExpire(Set keys)
methods added toRMapCacheNative
objectFeature -
eval()
andevalSha()
methods added toRScript
object for execution on all nodes in Redis ClusterImprovement - performance optimization for Apache Tomcat Session management
Improvement - default value of quietPeriod set to 0 in
RedissonClient.shutdown()
methodImprovement - upgrade protobuf from 3.16.3 to 4.27.2 (thanks to @zzhlhc)
Fixed - Apache Tomcat Session Manager throws CROSSSLOT Keys in request don't hash to the same slot (regression since 3.32.0)
Fixed - empty partitions shouldn't be skipped in cluster topology scan
Fixed -
ClusterConnectionManager.checkSlotsMigration()
method throws NPEFixed - RSearch IndexInfoDecoder may throw NPE
Fixed - local cached Map implementations don't emit cache clear event on
clear()
ordelete()
methods callFixed -
RObject.rename()
method doesn't work in clusterFixed - a new attempt to send a command should be made right after channel reconnection
Fixed - 'race condition' while calling RLock.tryLock() method (thanks to @pad-master82)
Fixed - Can't connect to servers error doesn't show exception reported during connection
Fixed -
SeekableByteChannel.truncate()
method (thanks to @seakider)Fixed -
RMap.computeAsync()
method doesn't handle empty keys properly (thanks to @phrone)v3.33.0
Feature - RJsonStore object added
Feature - RLocalCachedJsonStore object added
Feature -
RSearch.getIndexes()
method addedFeature -
RedissonRegionNativeFactory
added for Hibernate module. Requires Redis 7.4+Feature -
RedissonSpringCacheNativeManager
implemented. Requires Redis 7.4+Feature -
RedissonCacheNative
implementation added for Mybatis cache. Requires Redis 7.4+Feature -
caches-native
cache type added to Micronaut module. Requires Redis 7.4+Improvement - Spring Cache
RedissonCache.put()
method optimizationBreaking change - JsonCodec interface refactoring
Fixed - re-added master node isn't updated in Cluster topology
Fixed - expiration time isn't set for Apacht Tomcat Manager
redisson:tomcat_notified_nodes
keys (thanks to @ehardy)Fixed - RSearch
AggregationOptions.loadAll()
setting isn't appliedFixed - containsAll() method of RList, RQueue, RMultimap objects returns incorrect result (thanks to @seakider)
Fixed - too many requests with small threads amount may cause OOM
Fixed - connection leak during high load with few connections
Fixed - RingBuffer#setCapacity, trim list incorrect (thanks to @seakider)
Fixed - password shouldn't be printed in logs
Fixed - encoded user/password in URL aren't accepted
v3.32.0
Feature - Quarkus Cache implementation added
Feature -
RMapCacheNative
implementation which uses Redis 7.4+ commandsFeature - unlinkByPattern() method added to RKeys interface (thanks to @seakider)
Fixed - Apache Tomcat request.changeSessionId() method does not change the session id in Redis (thanks to @bclay2116)
Fixed - RSearch parse params error (thanks to @seakider)
Fixed - RSearch.info() throws
NumberFormatException
(thanks to @seakider)Fixed - cluster failover handling
Fixed - last master node shouldn't be removed in cluster topology
Fixed - duplicated master/slave added log output in sentinel mode
Fixed - connection leak if master change operation failed during failover
Fixed -
RxJava3
request can't be canceledFixed -
RFairLock
doesn't calculate remaining ttl properly before next acquisition attemptFixed -
scanInterval
setting checkFixed -
ElementsSubscribeService.resubscribe()
method throwsRedissonShutdownException
Fixed -
RMap.getAll()
method throws an exception if result ofRMap.keySet()
method passed as an argumentFixed - Redis node random selection doesn't work properly
Fixed - concurrency problem during RLock expiration renewal (thanks to @seakider)
Fixed -
RListMultimap
throws too many results to unpack errorFixed - entry shutdown during cluster slots migration check
v3.31.0
Feature - Spring Boot 3.3.0 integration
Feature - Spring Data Redis 3.3.0 integration
Feature - allow retry of
NOREPLICAS
error (thanks to @ghollies)Improvement -
SequentialDnsAddressResolverFactory
defaultconcurrencyLevel
set to 2Improvement -
ThreadLocalRandom
replaced withxoshiro256++
RNG to avoid collisionsFixed - cluster failover handling
Fixed - cluster topology scan shouldn't be stopped by any exception
Fixed -
RSetMultiMap
throwstoo many results to unpack
errorFixed - append commands error when using batch mode (thanks to @seakider)
Fixed -
ERR unknown command EVALSHA_RO
error shouldn't be loggedFixed -
TransactionalBucket#set(V, Duration)
PSETEX
command is called beforeMULTI
command (thanks to @seakider)Fixed -
CommandMapper
isn't applied to Lua scriptsFixed - incorrect connection release if
BatchOptions.executionMode
=REDIS_WRITE_ATOMIC
orREDIS_READ_ATOMIC
(thanks to @seakider)Fixed -
RFairLock
methods throw 'attempt to compare nil with number' errorFixed - Spring Data Redis
RedissonConnectionFactory.getSentinelConnection()
method throws error on the first offline sentinelFixed - read mode = SLAVE isn't applied for
RSet.random()
methodsFixed - Keyspace notifications should be listened only on master nodes
Fixed -
RListMultimap.removeAll()
method always deletes link to listFixed -
RLockReactive
methods don't work in native imageFixed - Correctly update shutdown timeout after each step in connection manager shutdown (thanks to @MartinEkInsurely)
Fixed - broken tck
JCache
testsFixed - not all sentinels defined in the configuration are registered
v3.30.0
Feature -
sslKeystoreType
setting addedFeature -
RPatternTopic.getActiveTopic()
method added (thanks to @MasterShi)Feature -
RJsonBucket.merge()
method addedFeature - Async, Rx, Reactive interfaces implemented for
RBloomFilter
objectFeature - fallback mode for JCache
Feature - passwords encryption support
Feature - Spring Cloud Stream integration
Improvement - configuration variable defined as Java system property overrides environment variable
Fixed - io.projectreactor package should be defined as optional in OSGi Manifest
Fixed - Spring Data Redis
StreamPollTask.deserializeAndEmitRecords()
method throws NPE after failoverFixed - Spring Data Redis blocking poll commands can't be reattached after failover
Fixed - Unable to find session error reported by
RedissonSessionManager
Fixed - Sentinels discovery is applied at Redisson startup if
sentinelsDiscovery = true
Fixed - master node is used for read operations after slave node addition if
readMode = SLAVE
in replicated modeFixed - failover handling of blocking methods calls with defined timeout. RStream, RBlockingQueue objects
Fixed - multiple
RLocalCachedMap
objects don't work in the same RTransaction (thanks to @vlad-ogol @RajaJaisankar)Fixed - codec setting isn't applied in
redisson.getMap(MapOptions)
methodFixed - Live Object field can't set to null value
Fixed -
SentinelConnectionManager
stops scheduling topology change change / dns check after host resolution errorFixed -
RMapCache.fastPutIfExistsOperation()
method uses incorrect pubsub channelv3.29.0
Feature -
NewObjectListener
added to track created objectsFeature -
NewObjectListener
andSetObjectListener
can be registered withRKeys.addListener()
methodFeature -
subscribeOnElements()
,subscribeOnLastElements()
andsubscribeOnFirstElements()
methods wait forCompletionStage
to complete before polling the next elementFeature -
shardedSubscriptionMode
setting added in Cluster configurationFeature -
RSemaphore.trySetPermits()
method with ttl parameter addedFeature -
getDeletedIds()
method added toRStream
AutoClaimResult
objectImprovement - responses map lock replaced with fine-grained entry locking in
RRemoteService
andRScheduledExecutorService
Fixed -
RStream.autoClaim()
method throws ClassCastExceptionFixed -
RSearch
aggregate expression applied incorrectlyFixed -
LocalCachedMapDisabledKey
event is parsed incorrectly if local cache used withRTransaction
Fixed - Slave node in cluster mode isn't shutdown properly if
readMode = MASTER
andsubscribeMode = MASTER
(regression since 3.27.2)Fixed - race condition during cluster topology update causes slave added/removed events
Fixed - OSGi MANIFEST should define optional dependencies
Fixed -
TimeoutException
is thrown ifconnectionMinimumIdleSize = 0
Fixed -
ClassCastException
is thrown for Reactive/Rx RemoteService invocation if Redisson instance isn't Reactive/RxFixed - semaphore object is not deleted after
RLocalCachedMap.clearLocalCache()
method invocationFixed -
AggregationOptions.groupBy()
setting with reducers used inRSearch.aggregate()
method causes an exceptionFixed -
AggregationOptions.groupBy()
setting usage withRSearch.aggregate()
method causes an exception if reducers aren't definedFixed -
AggregationOptions.sortBy()
setting usage withRSearch.aggregate()
method causes an exceptionFixed - resource leak error when executing multiple contains operation of
RSet
in transaction (thanks to @wynn5a)Fixed - jmockit upgraded to 1.52.0 inside maven-surefire-plugin (thanks to @roharon)
v3.28.0
Feature - Multi Sentinel mode implementation
Feature -
RLocalCachedMapCacheV2
object implemented with effecient partitioning and advanced entry evictionFeature - graceful shutdown in quarkus (thanks to @naah69)
Improvement -
RLongAdder
andRDoubleAddder
should use sharded topic if possibleImprovement - reduced CPU and Memory consumption by
ClusterConnectionManager.getLastPartitonsByURI()
methodImprovement -
RedisURI.hashCode()
caching to reduce CPU consumptionImprovement - shutdown check added in
RTopic.removeListener()
methodFixed - incorrect detection of sharded pubsub support
Fixed -
RBatch
does not work with RKeys.randomKeyAsync() method (thanks to @wynn5a)Fixed - unresolved Redis node hostname in cluster mode affects cluster topology scan
Fixed -
MASTER
nodes aren't used ifreadMode = MASTER_SLAVE
Fixed -
RLock
,RFencedLock
,RReadWriteLock
miss unlock messages and wait a defined timeout before a next attempt or hangFixed -
RSemaphore
,RPermitExpirableSemaphore
miss release messages and wait a defined timeout before a next attempt or hangFixed - incorrect value of
RLongAdder.sum()
andRDoubleAddder.sum()
methods if multiple Adder instances for the same Redisson object are usedFixed -
CountDownLatch.await()
method may throw NPEFixed - ExecutionException handling in RExecutorService, RLock, RPermitExpirableSemaphore, RSemaphore objects
Fixed -
ConcurrentModificationException
is thrown on RedissonSession save method if readMode = MEMORYFixed - Spring Data Redis zPopMin() and zPopMax() methods don't work (thanks to @bimslab)
v3.27.2
Feature -
RShardedTopic.countSubscribers()
method implementedFeature -
RedissonMultiLock
implementsisHeldByThread()
andisHeldByCurrentThread()
methodsFixed - Multiple locking of RLock reset remainTimeToLive to config default
Fixed - exception thrown by
natMapper
is not shown in logsFixed - OSGi jdk.net package import should be optional
Fixed -
ServiceManager.resolveAll()
method throws NPEFixed -
RObject.addListenerAsync()
method throwsUnsupportedOperationException
Fixed -
StatusListener
doesn't work withRShardedTopic
Fixed - NPE is thrown in cluster mode if slave node added
Fixed - continuously reconnecting to a removed slave node in cluster mode
Fixed - incorrect handling of TrackingListener removal
Fixed -
FlushListener
receives duplicate eventsFixed -
SlotsDecoder
throws NPE on empty resultFixed - Clash between RedissonCache and Spring (6.1+) Cache interface methods
Fixed -
RedissonClient.shutdown()
method hangs atserviceManager.getShutdownLatch()
invocationFixed - "Failed to submit a listener notification task. Event loop shut down?" error caused by
PingConnectionHandler
Fixed -
JsonCodecWrapper
isn't cached properlyv3.27.1
Feature - added
TrackingListener
support toRList
,RQueue
,RDeque
,RBlockingQueue
,RBlockingDeque
,RDelayedQueue
,RRingBuffer
objectsFeature -
addListener()
,random()
methods added toRLexSortedSet
objectImprovement - show log warning "DNS TCP fallback on UDP query timeout disabled" if Netty version is lower 4.1.105
Improvement - ChannelName.toString() conversion optimization
Fixed -
retryInterval
andretryAttempts
settings aren't applied in case of 'READONLY You can't write against a read only replica.' errorFixed -
RRemoteService
may cause CPU spike after Master failoverFixed -
FlushListener
causesClassCastException
Fixed -
TrackingListener
causesClassCastException
Fixed -
RedissonSetCache.addIfAbsentAsync()
uses incorrect argument for zadd (thanks @fooooxxxx)v3.27.0
Feature - client tracking support.
TrackingListener
is available forRBucket
,RStream
,RScoredSortedSet
,RSet
,RMap
andRBucket
objectsFeature - added
RKeys.addListener()
method to register global listenersFeature -
FlushListener
added to track flushdb/flushall command invocationFeature -
Kryo5Codec
constructor withregistrationRequired
parameter addedFeature -
nettyExecutor
setting addedFeature - enable DNS TCP fallback when UDP query timeout for
RoundRobinDnsAddressResolverGroupFactory
andSequentialDnsAddressResolverFactory
Improvement - cache result of
INFO REPLICATION
command forRLock
objectsFixed - Spring Data Redis
ReactiveKeyCommands.pExpire()
method throws an exceptionFixed - NPE is thrown by
RedisExecutor.handleError()
methodFixed - sharded pubsub detection for
Apache Tomcat Session Manager
,RMapCache
andRLocalCachedMap
objectsFixed - Redisson's threads aren't shutdown if Redis node address isn't defined
Fixed - NPE is thrown while creating
RLocalCacheMap
object without WriteMode valueFixed - incorrect RESP3 protocol parsing causes
SlaveConnectionPool no available Redis entries
errorFixed - repeated new connections with AWS Elasticache serverless
Fixed - internal
LRUCacheMap
object throwsConcurrentModificationException
v3.26.1
Feature - enable DNS TCP fallback when UDP query timeout (thanks to @hellojukay)
Feature -
StreamMessageId.autogenerateSequenceId()
method added (thanks to @mrmx)Feature -
RLockReactive.isHeldByThread()
method added (thanks to @sanail)Fixed - missed implementation of Spring Data Redis
ReactiveStringCommands.bitField()
methodFixed - Spring Data Redis
opsForCluster().randomKey()
method throwsUnsupportedOperationException
Fixed -
JCache.close()
method throwsIllegalStateException
if statistics enabledFixed - doubled connections to the master node if
readMode = MASTER_SLAVE
or there are no slave nodesFixed -
RSearch.delDict()
andRSearch.addDict()
methods throw NPEFixed - connection ping handler doesn't use
commandTimeout
settingFixed - repeated new connections with AWS Elasticache serverless
Fixed -
RLock
throwsERR unknown command 'wait'
with AWS Elasticache serverlessFixed -
RSearchReactive.dropIndex()
method doesn't call onComplete() handlerv3.26.0
Feature - ability to specify
retryInterval
,retryAttempts
,timeout
settings per Redisson object. Please refer to the documentationFeature -
LocalCachedMapOptions.expirationEventPolicy
setting addedFeature -
StreamAddListener
,StreamCreateConsumerListener
,StreamCreateGroupListener
,StreamRemoveConsumerListener
,StreamRemoveGroupListener
,StreamRemoveListener
,StreamTrimListener
listeners added forRStream
objectFixed - Spring Data Redis
RedissonConnection.setCommands()
method returns nullFixed - continuously reconnecting to a removed slave node in cluster mode
Fixed -
EntryExpiredListener
isn't invoked byRMapCache
instance in Redis Cluster 7+ and ifnameMapper
is definedFixed -
Skipped slave up ...
error is thrown in Sentinel mode if nodes use IPv6Fixed - NPE is thrown when adding or removing shards in ElastiCache
Fixed -
RAtomicDouble
,RAtomicLong
,RMap
,RScoredSortedSet
,RSet
listeners aren't removed properlyFixed - connection isn't reconnected on
WRONGPASS
Redis errorFixed - connection timeout during Redisson start ignores connections amount
Fixed -
RSearch.search()
method doesn't execute query with aliases properlyFixed -
FCALL_RO
command isn't used whenRFunction
method called withFunctionMode.READ
parameterFixed -
IllegalReferenceCountException
is thrown when canceling a method callFixed - Redis scan cursor exceed
Long.MAX_VALUE
in AWS ElasticacheFixed - internal
ServiceManager.calcSHA()
method should use UTF-8 encoding by defaultv3.25.2
Fixed - SSL connection can't be established
v3.25.1
Improvement - JDK21 Virtual Threads compatibility
Fixed - EvictionTask keeps running even after
destroy()
method calledFixed - Sprint Data Redis throws
Subscription registration timeout exceeded
Fixed - Sprint Data Redis
RedisMessageListenerContainer.addMessageListener()
method hangs if called after container startFixed - NPE is thrown if
lazyInitialization = true
Fixed -
PriorityQueue
methods may hang due to unreleased lock after exceptionFixed -
RMap.getAll()
method throwsIndexOutOfBoundsException
Fixed - natMapper isn't applied to slaves and master nodes at start in Sentinel mode
Fixed - method invocation hangs after failover if
retryInterval = 0
Fixed - transactional Map and MapCache keySet method returns inconsistent state
Fixed - Multilock lock method doesn't work properly with non-MILLISECONDS TimeUnit
v3.25.0
Feature - RESP3 protocol support. protocol setting added
Feature - Spring Data Redis 3.2.0 implementation
Feature -
RSetCacheV2
,RSetV2
objects with more effecient partitioning in Cluster added in PRO versionImprovement - SLF4j updated to 2.0.9 version
Fixed - RFunction/RScript keys parameter accepts only String values
Fixed - IP address instead of hostname is used in sentinel mode with SSL connection
Fixed - Resources leak in
Version.logVersion()
methodFixed -
RLiveObjectService.persist()
method with varargs hangs in cluster modeFixed - Redisson connection process may hang at start in some cases
Fixed -
EntryExpiredListener
isn't invoked by RMapCache instance in Redis Cluster 7+Fixed - slave node in sentinel mode can't be recovered if it's a master node
Fixed -
JsonJacksonCodec
fails to serialize Throwable on Java17 (thanks to @tomjankes)Fixed -
RBlockingDeque.move()
throws an exception for empty resultFixed -
RScoredSortedSet.pollFirstEntries(count)
andpollLastEntries(count)
methods return wrong resultFixed -
BZMPOP
command timeout isn't appliedFixed -
getBlockingDeque()
,getDeque()
,getPriorityDeque()
,getPriorityBlockingDeque()
throwNoClassDefFoundError
if JDK version < 21Fixed -
RLocalCachedMap.containsKey()
method does not work properly ifstoreCacheMiss = true
Fixed -
RedissonRemoteService
exceptions handling (thanks to @mrmx)Fixed -
RSearch.info()
method throwsNumberFormatException
Fixed -
HttpSessionListener.sessionDestroyed()
method isn't called if Tomcat Session deleted by the node which didn't create itFixed -
LZ4CodecV2
isn't compatible withLZ4Codec
Fixed -
RSearch
GroupBy.reduce alias isn't applied (thanks to @arjunE1395)v3.24.3
Feature - Helidon 4.0 integration
Fixed -
ERR invalid expire time
error is thrown duringRLock.unlock()
call ifretryAttempts = 0
v3.24.2
Fixed -
IllegalArgument timeout...
error is throw during Redisson shutdownFixed - Intermittent Exception when creating
RLocalCachedMap
(regression since 3.24.1)Fixed -
RSearch.aggregate()
doesn't applywithCursor()
andsortBy()
options correctlyFixed -
MOVED redirection loop detected
error should be thrown only if both source and target addresses are equalConfiguration
📅 Schedule: Branch creation - At any time (no schedule defined), Automerge - At any time (no schedule defined).
🚦 Automerge: Enabled.
♻ Rebasing: Whenever PR becomes conflicted, or you tick the rebase/retry checkbox.
🔕 Ignore: Close this PR and you won't be reminded about this update again.
This PR was generated by Mend Renovate. View the repository job log.