All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.mobaijun.redisson.util.RedisUtil Maven / Gradle / Ivy

There is a newer version: 3.0.14
Show newest version
/*
 * Copyright (C) 2022 [www.mobaijun.com]
 *
 * Licensed under the Apache License, Version 2.0 (the "License");
 * you may not use this file except in compliance with the License.
 * You may obtain a copy of the License at
 *
 *         https://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
package com.mobaijun.redisson.util;

import com.mobaijun.core.spring.SpringUtil;
import java.time.Duration;
import java.util.Collection;
import java.util.List;
import java.util.Map;
import java.util.Set;
import java.util.function.Consumer;
import java.util.stream.Collectors;
import java.util.stream.Stream;
import org.redisson.api.ObjectListener;
import org.redisson.api.RAtomicLong;
import org.redisson.api.RBatch;
import org.redisson.api.RBucket;
import org.redisson.api.RBucketAsync;
import org.redisson.api.RKeys;
import org.redisson.api.RList;
import org.redisson.api.RMap;
import org.redisson.api.RMapAsync;
import org.redisson.api.RRateLimiter;
import org.redisson.api.RSet;
import org.redisson.api.RTopic;
import org.redisson.api.RateIntervalUnit;
import org.redisson.api.RateType;
import org.redisson.api.RedissonClient;

/**
 * Description: [redis 工具类]
 * Author: [mobaijun]
 * Date: [2024/8/14 18:29]
 * IntelliJ IDEA Version: [IntelliJ IDEA 2023.1.4]
 */
public class RedisUtil {

    /**
     * 客户端实例
     */
    private static final RedissonClient CLIENT = SpringUtil.getBean(RedissonClient.class);

    /**
     * 限流
     *
     * @param key          限流key
     * @param rateType     限流类型
     * @param rate         速率
     * @param rateInterval 速率间隔
     * @return -1 表示失败
     */
    public static long rateLimiter(String key, RateType rateType, int rate, int rateInterval) {
        RRateLimiter rateLimiter = CLIENT.getRateLimiter(key);
        rateLimiter.trySetRate(rateType, rate, rateInterval, RateIntervalUnit.SECONDS);
        if (rateLimiter.tryAcquire()) {
            return rateLimiter.availablePermits();
        } else {
            return -1L;
        }
    }

    /**
     * 获取客户端实例
     */
    public static RedissonClient getClient() {
        return CLIENT;
    }

    /**
     * 发布通道消息
     *
     * @param channelKey 通道key
     * @param msg        发送数据
     * @param consumer   自定义处理
     */
    public static  void publish(String channelKey, T msg, Consumer consumer) {
        RTopic topic = CLIENT.getTopic(channelKey);
        topic.publish(msg);
        consumer.accept(msg);
    }

    /**
     * 发布消息到指定的频道
     *
     * @param channelKey 通道key
     * @param msg        发送数据
     */
    public static  void publish(String channelKey, T msg) {
        RTopic topic = CLIENT.getTopic(channelKey);
        topic.publish(msg);
    }

    /**
     * 订阅通道接收消息
     *
     * @param channelKey 通道key
     * @param clazz      消息类型
     * @param consumer   自定义处理
     */
    public static  void subscribe(String channelKey, Class clazz, Consumer consumer) {
        RTopic topic = CLIENT.getTopic(channelKey);
        topic.addListener(clazz, (channel, msg) -> consumer.accept(msg));
    }

    /**
     * 缓存基本的对象,Integer、String、实体类等
     *
     * @param key   缓存的键值
     * @param value 缓存的值
     */
    public static  void setObj(final String key, final T value) {
        setObj(key, value, false);
    }

    /**
     * 缓存基本的对象,保留当前对象 TTL 有效期
     *
     * @param key       缓存的键值
     * @param value     缓存的值
     * @param isSaveTtl 是否保留TTL有效期(例如: set之前ttl剩余90 set之后还是为90)
     * @since Redis 6.X 以上使用 setAndKeepTTL 兼容 5.X 方案
     */
    public static  void setObj(final String key, final T value, final boolean isSaveTtl) {
        RBucket bucket = CLIENT.getBucket(key);
        if (isSaveTtl) {
            try {
                bucket.setAndKeepTTL(value);
            } catch (Exception e) {
                long timeToLive = bucket.remainTimeToLive();
                if (timeToLive == -1) {
                    setObj(key, value);
                } else {
                    setObj(key, value, Duration.ofMillis(timeToLive));
                }
            }
        } else {
            bucket.set(value);
        }
    }

    /**
     * 缓存基本的对象,Integer、String、实体类等
     *
     * @param key      缓存的键值
     * @param value    缓存的值
     * @param duration 时间
     */
    public static  void setObj(final String key, final T value, final Duration duration) {
        RBatch batch = CLIENT.createBatch();
        RBucketAsync bucket = batch.getBucket(key);
        bucket.setAsync(value);
        bucket.expireAsync(duration);
        batch.execute();
    }

    /**
     * 如果不存在则设置 并返回 true 如果存在则返回 false
     *
     * @param key   缓存的键值
     * @param value 缓存的值
     * @return set成功或失败
     */
    public static  boolean setObjectIfAbsent(final String key, final T value, final Duration duration) {
        RBucket bucket = CLIENT.getBucket(key);
        return bucket.setIfAbsent(value, duration);
    }

    /**
     * 如果存在则设置 并返回 true 如果存在则返回 false
     *
     * @param key   缓存的键值
     * @param value 缓存的值
     * @return set成功或失败
     */
    public static  boolean setObjectIfExists(final String key, final T value, final Duration duration) {
        RBucket bucket = CLIENT.getBucket(key);
        return bucket.setIfExists(value, duration);
    }

    /**
     * 注册对象监听器
     * 

* key 监听器需开启 `notify-keyspace-events` 等 redis 相关配置 * * @param key 缓存的键值 * @param listener 监听器配置 */ public static void addObjectListener(final String key, final ObjectListener listener) { RBucket result = CLIENT.getBucket(key); result.addListener(listener); } /** * 设置有效时间 * * @param key Redis键 * @param timeout 超时时间 * @return true=设置成功;false=设置失败 */ public static boolean setExpire(final String key, final long timeout) { return setExpire(key, Duration.ofSeconds(timeout)); } /** * 设置有效时间 * * @param key Redis键 * @param duration 超时时间 * @return true=设置成功;false=设置失败 */ public static boolean setExpire(final String key, final Duration duration) { RBucket rBucket = CLIENT.getBucket(key); return rBucket.expire(duration); } /** * 获得缓存的基本对象。 * * @param key 缓存键值 * @return 缓存键值对应的数据 */ public static T getObj(final String key) { RBucket rBucket = CLIENT.getBucket(key); return rBucket.get(); } /** * 获得key剩余存活时间 * * @param key 缓存键值 * @return 剩余存活时间 */ public static long getTimeToLive(final String key) { RBucket rBucket = CLIENT.getBucket(key); return rBucket.remainTimeToLive(); } /** * 删除单个对象 * * @param key 缓存的键值 */ public static boolean deleteObj(final String key) { return CLIENT.getBucket(key).delete(); } /** * 删除集合对象 * * @param collection 多个对象 */ public static void deleteObj(final Collection collection) { RBatch batch = CLIENT.createBatch(); collection.forEach(t -> { batch.getBucket(t.toString()).deleteAsync(); }); batch.execute(); } /** * 检查缓存对象是否存在 * * @param key 缓存的键值 */ public static boolean isExistsObject(final String key) { return CLIENT.getBucket(key).isExists(); } /** * 缓存List数据 * * @param key 缓存的键值 * @param dataList 待缓存的List数据 * @return 缓存的对象 */ public static boolean setList(final String key, final List dataList) { RList rList = CLIENT.getList(key); return rList.addAll(dataList); } /** * 追加缓存List数据 * * @param key 缓存的键值 * @param data 待缓存的数据 * @return 缓存的对象 */ public static boolean addList(final String key, final T data) { RList rList = CLIENT.getList(key); return rList.add(data); } /** * 注册List监听器 *

* key 监听器需开启 `notify-keyspace-events` 等 redis 相关配置 * * @param key 缓存的键值 * @param listener 监听器配置 */ public static void addListListener(final String key, final ObjectListener listener) { RList rList = CLIENT.getList(key); rList.addListener(listener); } /** * 获得缓存的list对象 * * @param key 缓存的键值 * @return 缓存键值对应的数据 */ public static List getList(final String key) { RList rList = CLIENT.getList(key); return rList.readAll(); } /** * 获得缓存的list对象(范围) * * @param key 缓存的键值 * @param form 起始下标 * @param to 截止下标 * @return 缓存键值对应的数据 */ public static List getCacheListRange(final String key, int form, int to) { RList rList = CLIENT.getList(key); return rList.range(form, to); } /** * 缓存Set * * @param key 缓存键值 * @param dataSet 缓存的数据 * @return 缓存数据的对象 */ public static boolean setSet(final String key, final Set dataSet) { RSet rSet = CLIENT.getSet(key); return rSet.addAll(dataSet); } /** * 追加缓存Set数据 * * @param key 缓存的键值 * @param data 待缓存的数据 * @return 缓存的对象 */ public static boolean addSet(final String key, final T data) { RSet rSet = CLIENT.getSet(key); return rSet.add(data); } /** * 注册Set监听器 *

* key 监听器需开启 `notify-keyspace-events` 等 redis 相关配置 * * @param key 缓存的键值 * @param listener 监听器配置 */ public static void addSetListener(final String key, final ObjectListener listener) { RSet rSet = CLIENT.getSet(key); rSet.addListener(listener); } /** * 获得缓存的set * * @param key 缓存的key * @return set对象 */ public static Set getSet(final String key) { RSet rSet = CLIENT.getSet(key); return rSet.readAll(); } /** * 缓存Map * * @param key 缓存的键值 * @param dataMap 缓存的数据 */ public static void setMap(final String key, final Map dataMap) { if (dataMap != null) { RMap rMap = CLIENT.getMap(key); rMap.putAll(dataMap); } } /** * 注册Map监听器 *

* key 监听器需开启 `notify-keyspace-events` 等 redis 相关配置 * * @param key 缓存的键值 * @param listener 监听器配置 */ public static void addMapListener(final String key, final ObjectListener listener) { RMap rMap = CLIENT.getMap(key); rMap.addListener(listener); } /** * 获得缓存的Map * * @param key 缓存的键值 * @return map对象 */ public static Map getMap(final String key) { RMap rMap = CLIENT.getMap(key); return rMap.getAll(rMap.keySet()); } /** * 获得缓存Map的key列表 * * @param key 缓存的键值 * @return key列表 */ public static Set getMapKeySet(final String key) { RMap rMap = CLIENT.getMap(key); return rMap.keySet(); } /** * 往Hash中存入数据 * * @param key Redis键 * @param hKey Hash键 * @param value 值 */ public static void setMapValue(final String key, final String hKey, final T value) { RMap rMap = CLIENT.getMap(key); rMap.put(hKey, value); } /** * 获取Hash中的数据 * * @param key Redis键 * @param hKey Hash键 * @return Hash中的对象 */ public static T getMapValue(final String key, final String hKey) { RMap rMap = CLIENT.getMap(key); return rMap.get(hKey); } /** * 删除Hash中的数据 * * @param key Redis键 * @param hKey Hash键 * @return Hash中的对象 */ public static T delMapValue(final String key, final String hKey) { RMap rMap = CLIENT.getMap(key); return rMap.remove(hKey); } /** * 删除Hash中的数据 * * @param key Redis键 * @param hKeys Hash键 */ public static void delMultiMapValue(final String key, final Set hKeys) { RBatch batch = CLIENT.createBatch(); RMapAsync rMap = batch.getMap(key); for (String hKey : hKeys) { rMap.removeAsync(hKey); } batch.execute(); } /** * 获取多个Hash中的数据 * * @param key Redis键 * @param hKeys Hash键集合 * @return Hash对象集合 */ public static Map getMultiMapValue(final String key, final Set hKeys) { RMap rMap = CLIENT.getMap(key); return rMap.getAll(hKeys); } /** * 设置原子值 * * @param key Redis键 * @param value 值 */ public static void setAtomicValue(String key, long value) { RAtomicLong atomic = CLIENT.getAtomicLong(key); atomic.set(value); } /** * 获取原子值 * * @param key Redis键 * @return 当前值 */ public static long getAtomicValue(String key) { RAtomicLong atomic = CLIENT.getAtomicLong(key); return atomic.get(); } /** * 递增原子值 * * @param key Redis键 * @return 当前值 */ public static long incrAtomicValue(String key) { RAtomicLong atomic = CLIENT.getAtomicLong(key); return atomic.incrementAndGet(); } /** * 递减原子值 * * @param key Redis键 * @return 当前值 */ public static long decrAtomicValue(String key) { RAtomicLong atomic = CLIENT.getAtomicLong(key); return atomic.decrementAndGet(); } /** * 获得缓存的基本对象列表 * * @param pattern 字符串前缀 * @return 对象列表 */ public static Collection keys(final String pattern) { Stream stream = CLIENT.getKeys().getKeysStreamByPattern(pattern); return stream.collect(Collectors.toList()); } /** * 删除缓存的基本对象列表 * * @param pattern 字符串前缀 */ public static void deleteKeys(final String pattern) { CLIENT.getKeys().deleteByPattern(pattern); } /** * 检查redis中是否存在key * * @param key 键 */ public static Boolean hasKey(String key) { RKeys rKeys = CLIENT.getKeys(); return rKeys.countExists(key) > 0; } }





© 2015 - 2024 Weber Informatics LLC | Privacy Policy