Class JedisConnection
java.lang.Object
org.springframework.data.redis.connection.AbstractRedisConnection
org.springframework.data.redis.connection.jedis.JedisConnection
- All Implemented Interfaces:
- AutoCloseable,- DefaultedRedisConnection,- RedisCommands,- RedisCommandsProvider,- RedisConnection,- RedisConnectionCommands,- RedisGeoCommands,- RedisHashCommands,- RedisHyperLogLogCommands,- RedisKeyCommands,- RedisListCommands,- RedisPubSubCommands,- RedisScriptingCommands,- RedisServerCommands,- RedisSetCommands,- RedisStreamCommands,- RedisStringCommands,- RedisTxCommands,- RedisZSetCommands
RedisConnection implementation on top of Jedis library.
 This class is not Thread-safe and instances should not be shared across threads.
- Author:
- Costin Leau, Jennifer Hickey, Christoph Strobl, Thomas Darimont, Jungtaek Lim, Konstantin Shchepanovskyi, David Liu, Milan Agatonovic, Mark Paluch, Ninad Divadkar, Guy Korland, Dengliming, John Blum
- See Also:
- 
- Jedis
 
- 
Nested Class SummaryNested classes/interfaces inherited from interface org.springframework.data.redis.connection.RedisGeoCommandsRedisGeoCommands.DistanceUnit, RedisGeoCommands.GeoCommandArgs, RedisGeoCommands.GeoLocation<T>, RedisGeoCommands.GeoRadiusCommandArgs, RedisGeoCommands.GeoSearchCommandArgs, RedisGeoCommands.GeoSearchStoreCommandArgsNested classes/interfaces inherited from interface org.springframework.data.redis.connection.RedisListCommandsRedisListCommands.Direction, RedisListCommands.PositionNested classes/interfaces inherited from interface org.springframework.data.redis.connection.RedisServerCommandsRedisServerCommands.FlushOption, RedisServerCommands.MigrateOption, RedisServerCommands.ShutdownOptionNested classes/interfaces inherited from interface org.springframework.data.redis.connection.RedisStreamCommandsRedisStreamCommands.XAddOptions, RedisStreamCommands.XClaimOptions, RedisStreamCommands.XPendingOptionsNested classes/interfaces inherited from interface org.springframework.data.redis.connection.RedisStringCommandsRedisStringCommands.BitOperation, RedisStringCommands.SetOptionNested classes/interfaces inherited from interface org.springframework.data.redis.connection.RedisZSetCommandsRedisZSetCommands.Limit, RedisZSetCommands.Range, RedisZSetCommands.ZAddArgs
- 
Constructor SummaryConstructorsModifierConstructorDescriptionJedisConnection(redis.clients.jedis.Jedis jedis) Constructs a newJedisConnectioninstance.JedisConnection(redis.clients.jedis.Jedis jedis, redis.clients.jedis.util.Pool<redis.clients.jedis.Jedis> pool, int dbIndex) Constructs a newJedisConnectioninstance backed by a jedis pool.protectedJedisConnection(redis.clients.jedis.Jedis jedis, redis.clients.jedis.util.Pool<redis.clients.jedis.Jedis> pool, int dbIndex, String clientName) Constructs a newJedisConnectioninstance backed by a jedis pool.protectedJedisConnection(redis.clients.jedis.Jedis jedis, redis.clients.jedis.util.Pool<redis.clients.jedis.Jedis> pool, redis.clients.jedis.JedisClientConfig nodeConfig, redis.clients.jedis.JedisClientConfig sentinelConfig) Constructs a newJedisConnectioninstance backed by a jedis pool.
- 
Method SummaryModifier and TypeMethodDescriptionvoidclose()Closes (or quits) the connection.Executes the commands in the pipeline and returns their result.commands()GetRedisCommands.protected org.springframework.dao.DataAccessExceptionvoiddiscard()Discard all commands issued afterRedisTxCommands.multi().byte[]echo(byte[] message) Returnsmessagevia server roundtrip.exec()Executes all queued commands in a transaction started withRedisTxCommands.multi().Native or raw execution of the given Redis command along with the given arguments.GetRedisGeoCommands.redis.clients.jedis.JedisgetJedis()protected redis.clients.jedis.Jedisredis.clients.jedis.JedisReturns the native connection (the underlying library/driver object).redis.clients.jedis.Pipelineredis.clients.jedis.Pipelineredis.clients.jedis.Transactionprotected JedisSentinelConnectiongetSentinelConnection(RedisNode sentinel) GetRedisSentinelCommandsconnected to given node.Returns the current subscription for this connection or null if the connection is not subscribed.redis.clients.jedis.TransactionGetRedisHashCommands.protected booleanCheck if node is active by sending ping.booleanisClosed()Indicates whether the underlying connection is closed or not.booleanIndicates whether the connection is currently pipelined or not.booleanIndicates whether the connection is in "queue"(or "MULTI") mode or not.booleanIndicates whether the current connection is subscribed (to at least one channel) or not.GetRedisKeyCommands.GetRedisListCommands.voidmulti()Mark the start of a transaction block.voidActivates the pipeline mode for this connection.ping()Test connection.voidpSubscribe(MessageListener listener, byte[]... patterns) Subscribes the connection to all channels matching the given patterns.publish(byte[] channel, byte[] message) Publishes the given message to the given channel.voidselect(int dbIndex) Select the DB with given positivedbIndex.GetRedisServerCommands.GetRedisSetCommands.voidsetConvertPipelineAndTxResults(boolean convertPipelineAndTxResults) Specifies if pipelined results should be converted to the expected data type.GetRedisStreamCommands.GetRedisStringCommands.voidsubscribe(MessageListener listener, byte[]... channels) Subscribes the connection to the given channels.voidunwatch()Flushes all the previouslyRedisTxCommands.watch(byte[]...)keys.voidwatch(byte[]... keys) Watch givenkeysfor modifications during transaction started withRedisTxCommands.multi().GetRedisZSetCommands.Methods inherited from class org.springframework.data.redis.connection.AbstractRedisConnectiongetSentinelConnection, hasRedisSentinelConfigured, setSentinelConfigurationMethods inherited from class java.lang.Objectclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.springframework.data.redis.connection.DefaultedRedisConnectionappend, bgReWriteAof, bgSave, bitCount, bitCount, bitField, bitOp, bitPos, bLMove, bLPop, bRPop, bRPopLPush, bZPopMax, bZPopMin, copy, dbSize, decr, decrBy, del, dump, encodingOf, eval, evalSha, evalSha, exists, exists, expire, expireAt, flushAll, flushAll, flushDb, flushDb, geoAdd, geoAdd, geoAdd, geoDist, geoDist, geoHash, geoPos, geoRadius, geoRadius, geoRadiusByMember, geoRadiusByMember, geoRemove, geoSearch, geoSearchStore, get, getBit, getClientList, getClientName, getConfig, getDel, getEx, getRange, getSet, hDel, hExists, hGet, hGetAll, hIncrBy, hIncrBy, hKeys, hLen, hMGet, hMSet, hRandField, hRandField, hRandFieldWithValues, hRandFieldWithValues, hScan, hSet, hSetNX, hStrLen, hVals, idletime, incr, incrBy, incrBy, info, info, keys, killClient, lastSave, lIndex, lInsert, lLen, lMove, lPop, lPop, lPos, lPush, lPushX, lRange, lRem, lSet, lTrim, mGet, migrate, migrate, move, mSet, mSetNX, persist, pExpire, pExpireAt, pfAdd, pfCount, pfMerge, pSetEx, pTtl, pTtl, randomKey, refcount, rename, renameNX, replicaOf, replicaOfNoOne, resetConfigStats, restore, rewriteConfig, rPop, rPop, rPopLPush, rPush, rPushX, sAdd, save, scan, sCard, scriptExists, scriptFlush, scriptKill, scriptLoad, sDiff, sDiffStore, set, set, setBit, setClientName, setConfig, setEx, setNX, setRange, shutdown, shutdown, sInter, sInterStore, sIsMember, sMembers, sMIsMember, sMove, sort, sort, sPop, sPop, sRandMember, sRandMember, sRem, sScan, strLen, sUnion, sUnionStore, time, time, touch, ttl, ttl, type, unlink, xAck, xAdd, xClaim, xClaimJustId, xDel, xGroupCreate, xGroupCreate, xGroupDelConsumer, xGroupDestroy, xInfo, xInfoConsumers, xInfoGroups, xLen, xPending, xPending, xRange, xRange, xRead, xRead, xReadGroup, xReadGroup, xRevRange, xRevRange, xTrim, xTrim, zAdd, zAdd, zCard, zCount, zCount, zDiff, zDiffStore, zDiffWithScores, zIncrBy, zInter, zInterStore, zInterStore, zInterStore, zInterWithScores, zInterWithScores, zInterWithScores, zLexCount, zMScore, zPopMax, zPopMax, zPopMin, zPopMin, zRandMember, zRandMember, zRandMemberWithScore, zRandMemberWithScore, zRange, zRangeByLex, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScoreWithScores, zRangeStoreByLex, zRangeStoreByScore, zRangeStoreRevByLex, zRangeStoreRevByScore, zRangeWithScores, zRank, zRem, zRemRange, zRemRangeByLex, zRemRangeByScore, zRemRangeByScore, zRevRange, zRevRangeByLex, zRevRangeByScore, zRevRangeByScoreWithScores, zRevRangeWithScores, zRevRank, zScan, zScore, zUnion, zUnionStore, zUnionStore, zUnionStore, zUnionWithScores, zUnionWithScores, zUnionWithScoresMethods inherited from interface org.springframework.data.redis.connection.RedisGeoCommandsgeoAdd, geoRadiusByMemberMethods inherited from interface org.springframework.data.redis.connection.RedisKeyCommandsrestore, scanMethods inherited from interface org.springframework.data.redis.connection.RedisListCommandslPosMethods inherited from interface org.springframework.data.redis.connection.RedisStreamCommandsxAck, xAdd, xAdd, xClaim, xDel, xGroupDelConsumer, xPending, xPending, xPending, xPending, xPendingMethods inherited from interface org.springframework.data.redis.connection.RedisStringCommandsbitPosMethods inherited from interface org.springframework.data.redis.connection.RedisZSetCommandszAdd, zAdd, zRangeByLex, zRangeByLex, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScoreWithScores, zRangeByScoreWithScores, zRangeByScoreWithScores, zRangeStoreByLex, zRangeStoreByScore, zRangeStoreRevByLex, zRangeStoreRevByScore, zRevRangeByLex, zRevRangeByLex, zRevRangeByScore, zRevRangeByScore, zRevRangeByScore, zRevRangeByScoreWithScores, zRevRangeByScoreWithScores, zRevRangeByScoreWithScores
- 
Constructor Details- 
JedisConnectionpublic JedisConnection(redis.clients.jedis.Jedis jedis) Constructs a newJedisConnectioninstance.- Parameters:
- jedis- Jedis entity
 
- 
JedisConnectionpublic JedisConnection(redis.clients.jedis.Jedis jedis, redis.clients.jedis.util.Pool<redis.clients.jedis.Jedis> pool, int dbIndex) Constructs a newJedisConnectioninstance backed by a jedis pool.- Parameters:
- jedis-
- pool- can be null, if no pool is used
- dbIndex-
 
- 
JedisConnectionprotected JedisConnection(redis.clients.jedis.Jedis jedis, @Nullable redis.clients.jedis.util.Pool<redis.clients.jedis.Jedis> pool, int dbIndex, @Nullable String clientName) Constructs a newJedisConnectioninstance backed by a jedis pool.- Parameters:
- jedis-
- pool- can be null, if no pool is used
- dbIndex-
- clientName- the client name, can be null.
- Since:
- 1.8
 
- 
JedisConnectionprotected JedisConnection(redis.clients.jedis.Jedis jedis, @Nullable redis.clients.jedis.util.Pool<redis.clients.jedis.Jedis> pool, redis.clients.jedis.JedisClientConfig nodeConfig, redis.clients.jedis.JedisClientConfig sentinelConfig) Constructs a newJedisConnectioninstance backed by a jedis pool.- Parameters:
- jedis-
- pool- can be null, if no pool is used
- nodeConfig- node configuration
- sentinelConfig- sentinel configuration
- Since:
- 2.5
 
 
- 
- 
Method Details- 
convertJedisAccessException
- 
commandsDescription copied from interface:RedisCommandsProviderGetRedisCommands.- Returns:
- never null.
 
- 
geoCommandsDescription copied from interface:RedisCommandsProviderGetRedisGeoCommands.- Returns:
- never null.
 
- 
hashCommandsDescription copied from interface:RedisCommandsProviderGetRedisHashCommands.- Returns:
- never null.
 
- 
hyperLogLogCommandsDescription copied from interface:RedisCommandsProvider- Returns:
- never null.
 
- 
keyCommandsDescription copied from interface:RedisCommandsProviderGetRedisKeyCommands.- Returns:
- never null.
 
- 
listCommandsDescription copied from interface:RedisCommandsProviderGetRedisListCommands.- Returns:
- never null.
 
- 
setCommandsDescription copied from interface:RedisCommandsProviderGetRedisSetCommands.- Returns:
- never null.
 
- 
streamCommandsDescription copied from interface:RedisCommandsProviderGetRedisStreamCommands.- Returns:
- never null.
 
- 
stringCommandsDescription copied from interface:RedisCommandsProviderGetRedisStringCommands.- Returns:
- never null.
 
- 
zSetCommandsDescription copied from interface:RedisCommandsProviderGetRedisZSetCommands.- Returns:
- never null.
 
- 
scriptingCommandsDescription copied from interface:RedisCommandsProvider- Returns:
- never null.
 
- 
serverCommandsDescription copied from interface:RedisCommandsProviderGetRedisServerCommands.- Returns:
- never null.
 
- 
executeDescription copied from interface:RedisCommandsNative or raw execution of the given Redis command along with the given arguments.The command is executed as is, with as little interpretation as possible - it is up to the caller to take care of any processing of arguments or the result. - Parameters:
- command- Redis- commandto execute; must not be null.
- args- optional array of command arguments; may be empty;
- Returns:
- the execution result; may be null.
 
- 
closepublic void close() throws org.springframework.dao.DataAccessExceptionDescription copied from interface:RedisConnectionCloses (or quits) the connection.- Specified by:
- closein interface- AutoCloseable
- Specified by:
- closein interface- RedisConnection
- Overrides:
- closein class- AbstractRedisConnection
- Throws:
- org.springframework.dao.DataAccessException
 
- 
getNativeConnectionpublic redis.clients.jedis.Jedis getNativeConnection()Description copied from interface:RedisConnectionReturns the native connection (the underlying library/driver object).- Returns:
- underlying, native object
 
- 
isClosedpublic boolean isClosed()Description copied from interface:RedisConnectionIndicates whether the underlying connection is closed or not.- Returns:
- true if the connection is closed, false otherwise.
 
- 
isQueueingpublic boolean isQueueing()Description copied from interface:RedisConnectionIndicates whether the connection is in "queue"(or "MULTI") mode or not. When queueing, all commands are postponed until EXEC or DISCARD commands are issued. Since in queueing no results are returned, the connection will return NULL on all operations that interact with the data.- Returns:
- true if the connection is in queue/MULTI mode, false otherwise
 
- 
isPipelinedpublic boolean isPipelined()Description copied from interface:RedisConnectionIndicates whether the connection is currently pipelined or not.- Returns:
- true if the connection is pipelined, false otherwise
- See Also:
 
- 
openPipelinepublic void openPipeline()Description copied from interface:RedisConnectionActivates the pipeline mode for this connection. When pipelined, all commands return null (the reply is read at the end throughRedisConnection.closePipeline(). Calling this method when the connection is already pipelined has no effect. Pipelining is used for issuing commands without requesting the response right away but rather at the end of the batch. While somewhat similar to MULTI, pipelining does not guarantee atomicity - it only tries to improve performance when issuing a lot of commands (such as in batching scenarios).Note: Consider doing some performance testing before using this feature since in many cases the performance benefits are minimal yet the impact on usage are not.- See Also:
 
- 
closePipelineDescription copied from interface:RedisConnectionExecutes the commands in the pipeline and returns their result. If the connection is not pipelined, an empty collection is returned.- Returns:
- the result of the executed commands.
 
- 
echopublic byte[] echo(byte[] message) Description copied from interface:RedisConnectionCommandsReturnsmessagevia server roundtrip.- Parameters:
- message- the message to echo.
- Returns:
- the message or null when used in pipeline / transaction.
- See Also:
 
- 
pingDescription copied from interface:RedisConnectionCommandsTest connection.- Returns:
- Server response message - usually PONG. null when used in pipeline / transaction.
- See Also:
 
- 
discardpublic void discard()Description copied from interface:RedisTxCommandsDiscard all commands issued afterRedisTxCommands.multi().- See Also:
 
- 
execDescription copied from interface:RedisTxCommandsExecutes all queued commands in a transaction started withRedisTxCommands.multi().
 If used along withRedisTxCommands.watch(byte[]...)the operation will fail if any of watched keys has been modified.- Returns:
- List of replies for each executed command.
- See Also:
 
- 
getPipeline@Nullable public redis.clients.jedis.Pipeline getPipeline()
- 
getRequiredPipelinepublic redis.clients.jedis.Pipeline getRequiredPipeline()
- 
getTransaction@Nullable public redis.clients.jedis.Transaction getTransaction()
- 
getRequiredTransactionpublic redis.clients.jedis.Transaction getRequiredTransaction()
- 
getJedispublic redis.clients.jedis.Jedis getJedis()
- 
multipublic void multi()Description copied from interface:RedisTxCommandsMark the start of a transaction block.
 Commands will be queued and can then be executed by callingRedisTxCommands.exec()or rolled back usingRedisTxCommands.discard()- See Also:
 
- 
selectpublic void select(int dbIndex) Description copied from interface:RedisConnectionCommandsSelect the DB with given positivedbIndex.- Parameters:
- dbIndex- the database index.
- See Also:
 
- 
unwatchpublic void unwatch()Description copied from interface:RedisTxCommandsFlushes all the previouslyRedisTxCommands.watch(byte[]...)keys.- See Also:
 
- 
watchpublic void watch(byte[]... keys) Description copied from interface:RedisTxCommandsWatch givenkeysfor modifications during transaction started withRedisTxCommands.multi().- Parameters:
- keys- must not be null.
- See Also:
 
- 
publishDescription copied from interface:RedisPubSubCommandsPublishes the given message to the given channel.- Parameters:
- channel- the channel to publish to. Must not be null.
- message- message to publish. Must not be null.
- Returns:
- the number of clients that received the message or null when used in pipeline / transaction.
- See Also:
 
- 
getSubscriptionDescription copied from interface:RedisPubSubCommandsReturns the current subscription for this connection or null if the connection is not subscribed.- Returns:
- the current subscription, null if none is available.
 
- 
isSubscribedpublic boolean isSubscribed()Description copied from interface:RedisPubSubCommandsIndicates whether the current connection is subscribed (to at least one channel) or not.- Returns:
- true if the connection is subscribed, false otherwise
 
- 
pSubscribeDescription copied from interface:RedisPubSubCommandsSubscribes the connection to all channels matching the given patterns. Once subscribed, a connection enters listening mode and can only subscribe to other channels or unsubscribe. No other commands are accepted until the connection is unsubscribed.Note that this operation is blocking and the current thread starts waiting for new messages immediately. - Parameters:
- listener- message listener, must not be null.
- patterns- channel name patterns, must not be null.
- See Also:
 
- 
subscribeDescription copied from interface:RedisPubSubCommandsSubscribes the connection to the given channels. Once subscribed, a connection enters listening mode and can only subscribe to other channels or unsubscribe. No other commands are accepted until the connection is unsubscribed.Note that this operation is blocking and the current thread starts waiting for new messages immediately. - Parameters:
- listener- message listener, must not be null.
- channels- channel names, must not be null.
- See Also:
 
- 
setConvertPipelineAndTxResultspublic void setConvertPipelineAndTxResults(boolean convertPipelineAndTxResults) Specifies if pipelined results should be converted to the expected data type. If false, results ofclosePipeline()andexec()will be of the type returned by the Jedis driver- Parameters:
- convertPipelineAndTxResults- Whether or not to convert pipeline and tx results
 
- 
isActiveDescription copied from class:AbstractRedisConnectionCheck if node is active by sending ping.- Overrides:
- isActivein class- AbstractRedisConnection
- Returns:
 
- 
getSentinelConnectionDescription copied from class:AbstractRedisConnectionGetRedisSentinelCommandsconnected to given node.- Overrides:
- getSentinelConnectionin class- AbstractRedisConnection
- Returns:
 
- 
getJedis
 
-