Jedis客戶端分片--構建高可用客戶端分片

記錄是一種精神,是加深理解最好的方式之一。

最近深入研究了Jedis的源碼,對Jedis的使用進行深入理解,提筆記錄。
曹金桂 cao_jingui@163.com(如有遺漏之處還請指教)
時間:2016年12月06日15:00

概述

分片允許數據存放在不同的物理機器上,以適應數據量過大的場景,克服單臺機器內存或者磁盤空間的限制。Redis在3.0之前是沒有集群的,就算現在3.0推出3.0集群版本,也沒有幾家公司用于生產。Jedis作為Java的Redis客戶端工具,其內部也提供了客戶的分片的實現。具體可以參考我的文章《Jedis使用教程完整版》,講解了Jedis客戶端使用,包括了Jedis的客戶端分片的使用方法。

Jedis客戶端分片存在問題

Jedis的客戶端分片采用一致性hash算法,實現數據的分配存儲。但當某一個分片服務掛了之后,客戶端需要修改服務的指向才能動態的切換到當前分片的從服務去。其實完全可以采用和JedisSentinel一樣的方法,利用Jedis的Sentinel構建高可用的服務。

實現

個人參照JedisSentinelPool的實現,完成了對構建Jedis分片的高可用的修改。源碼如下:

package redis.clients.jedis;

import org.apache.commons.pool2.PooledObject;
import org.apache.commons.pool2.PooledObjectFactory;
import org.apache.commons.pool2.impl.DefaultPooledObject;
import org.apache.commons.pool2.impl.GenericObjectPoolConfig;
import redis.clients.jedis.exceptions.JedisConnectionException;
import redis.clients.jedis.exceptions.JedisException;
import redis.clients.util.Hashing;
import redis.clients.util.Pool;

import java.util.*;
import java.util.concurrent.ConcurrentHashMap;
import java.util.concurrent.atomic.AtomicBoolean;
import java.util.logging.Level;
import java.util.logging.Logger;
import java.util.regex.Pattern;

public class SentinelShardedJedisPool extends Pool<SentinelShardedJedis> {

    protected Logger log = Logger.getLogger(getClass().getName());

    private final Map<String, JedisShardInfo> shardInfoMap = new ConcurrentHashMap<>(); // key=masterName
    private final Map<String, String> sentinels = new ConcurrentHashMap<>(); // key=host+port value=masterName

    private SentinelShardedJedisFactory factory;
    private Set<MasterListener> masterListeners = new HashSet<>();

    public SentinelShardedJedisPool(Set<SentinelInfo> sentinelInfos, final GenericObjectPoolConfig poolConfig, Hashing algo, Pattern keyTagPattern) {
        initShards(sentinelInfos);
        factory = new SentinelShardedJedisFactory(shardInfoMap.values(), algo, keyTagPattern);
        super.initPool(poolConfig, factory);

    }

    private void initShards(Set<SentinelInfo> sentinelInfos) {
        for (SentinelInfo info : sentinelInfos) {
            JedisShardInfo shardInfo = getJedisSharedInfoFromSentinelInfo(info);
            sentinels.put(shardInfo.getHost() + ":" + shardInfo.getPort(), info.getMasterName());
            shardInfoMap.put(info.getMasterName(), shardInfo);

            for (String sentinel : info.getSentinels()) {
                HostAndPort hap = HostAndPort.parseString(sentinel);
                MasterListener masterListener = new MasterListener(info.getMasterName(), hap.getHost(), hap.getPort());
                masterListeners.add(masterListener);
                masterListener.setDaemon(true);
                masterListener.start();
            }
        }
    }

    private JedisShardInfo getJedisSharedInfoFromSentinelInfo(SentinelInfo info) {
        log.info("Trying to find master from available Sentinels...");
        for (String sentinel : info.getSentinels()) {
            final HostAndPort hap = HostAndPort.parseString(sentinel);
            log.fine("Connecting to Sentinel " + hap);
            Jedis jedis = null;
            try {
                jedis = new Jedis(hap.getHost(), hap.getPort());
                List<String> masterAddr = jedis.sentinelGetMasterAddrByName(info.getMasterName());
                if (masterAddr == null || masterAddr.size() != 2) {
                    log.warning("Can not get master addr, master name: " + info.getMasterName() + ". Sentinel: " + hap + ".");
                    continue;
                }

                String host = masterAddr.get(0);
                int port = Integer.parseInt(masterAddr.get(1));
                JedisShardInfo jedisShardInfo = new JedisShardInfo(host, port);
                log.fine("Found Redis master at " + masterAddr);
                return jedisShardInfo;
            } catch (JedisException e) {
                log.warning("Cannot get master address from sentinel running @ " + hap + ". Reason: " + e + ". Trying next one.");
            } finally {
                if (jedis != null) {
                    jedis.close();
                }
            }
        }
        throw new JedisConnectionException("All sentinels down, cannot determine where is " + info.getMasterName() + " master is running...");
    }

    private void reInitPool() {
        internalPool.clear();
    }

    @Override
    public void destroy() {
        for (MasterListener m : masterListeners) {
            m.shutdown();
        }
        super.destroy();
    }

    @Override
    public SentinelShardedJedis getResource() {
        while (true) {
            SentinelShardedJedis jedis = super.getResource();
            for (Jedis shard : jedis.getAllShards()) {
                String host = shard.getClient().getHost();
                int port = shard.getClient().getPort();
                if (sentinels.containsKey(host + ":" + port)) {
                    jedis.setDataSource(this);
                    return jedis;
                }
            }
            returnBrokenResource(jedis);
        }
    }

    @Override
    protected void returnBrokenResource(final SentinelShardedJedis resource) {
        if (resource != null) {
            returnBrokenResourceObject(resource);
        }
    }

    @Override
    protected void returnResource(final SentinelShardedJedis resource) {
        if (resource != null) {
            resource.resetState();
            returnResourceObject(resource);
        }
    }

    private class MasterListener extends Thread {
        private String masterName;
        private String sentinelHost;
        private int sentinelPort;
        private volatile Jedis j;
        private AtomicBoolean running = new AtomicBoolean(false);

        public MasterListener(String masterName, String host, int port) {
            this.masterName = masterName;
            this.sentinelHost = host;
            this.sentinelPort = port;
            this.setName(String.format("MasterListener-%s-[%s:%d]", masterName, host, port));
        }

        @Override
        public void run() {
            running.set(true);
            while (running.get()) {
                j = new Jedis(sentinelHost, sentinelPort);
                try {
                    if (!running.get()) {
                        break;
                    }
                    j.subscribe(new JedisPubSub() {
                        @Override
                        public void onMessage(String channel, String message) {
                            log.fine("Sentinel " + sentinelHost + ":" + sentinelPort + " published: " + message + ".");
                            String[] switchMasterMsg = message.split(" ");
                            if (switchMasterMsg.length > 3) {
                                if (masterName.equals(switchMasterMsg[0])) {
                                    JedisShardInfo oldInfo = shardInfoMap.get(masterName);
                                    sentinels.remove(oldInfo.getHost() + ":" + oldInfo.getPort());

                                    JedisShardInfo newInfo = new JedisShardInfo(switchMasterMsg[3], switchMasterMsg[4]);
                                    newInfo.setConnectionTimeout(oldInfo.getConnectionTimeout());
                                    newInfo.setPassword(oldInfo.getPassword());
                                    newInfo.setSoTimeout(oldInfo.getSoTimeout());
                                    shardInfoMap.put(masterName, newInfo);
                                    sentinels.put(newInfo.getHost() + ":" + newInfo.getPort(), masterName);
                                    reInitPool();
                                } else {
                                    log.fine("Ignoring message on +switch-master for master name " + switchMasterMsg[0] + ", our master name is " + masterName);
                                }

                            } else {
                                log.severe("Invalid message received on Sentinel " + sentinelHost + ":" + sentinelPort + " on channel +switch-master: " + message);
                            }
                        }
                    }, "+switch-master");
                } catch (JedisConnectionException e) {
                    if (running.get()) {
                        log.log(Level.SEVERE, "Lost connection to Sentinel at " + sentinelHost + ":" + sentinelPort + ". Sleeping 5000ms and retrying.", e);
                        try {
                            Thread.sleep(5000);
                        } catch (InterruptedException e1) {
                            log.log(Level.SEVERE, "Sleep interrupted: ", e1);
                        }
                    } else {
                        log.fine("Unsubscribing from Sentinel at " + sentinelHost + ":" + sentinelPort);
                    }
                } finally {
                    j.close();
                }
            }
        }

        public void shutdown() {
            try {
                log.fine("Shutting down listener on " + sentinelHost + ":" + sentinelPort);
                running.set(false);
                if (j != null) {
                    j.disconnect();
                }
            } catch (Exception e) {
                log.log(Level.SEVERE, "Caught exception while shutting down: ", e);
            }
        }
    }

    /**
     * PoolableObjectFactory custom impl.
     */
    private class SentinelShardedJedisFactory implements PooledObjectFactory<SentinelShardedJedis> {

        private Collection<JedisShardInfo> shards;
        private Hashing algo;
        private Pattern keyTagPattern;

        public SentinelShardedJedisFactory(Collection<JedisShardInfo> shards, Hashing algo, Pattern keyTagPattern) {
            this.shards = shards;
            this.algo = algo;
            this.keyTagPattern = keyTagPattern;
        }

        @Override
        public PooledObject<SentinelShardedJedis> makeObject() throws Exception {
            SentinelShardedJedis jedis = new SentinelShardedJedis(new ArrayList<>(shards), algo, keyTagPattern);
            return new DefaultPooledObject<SentinelShardedJedis>(jedis);
        }

        @Override
        public void destroyObject(PooledObject<SentinelShardedJedis> pooledShardedJedis) throws Exception {
            final SentinelShardedJedis shardedJedis = pooledShardedJedis.getObject();
            for (Jedis jedis : shardedJedis.getAllShards()) {
                try {
                    try {
                        jedis.quit();
                    } catch (Exception e) {

                    }
                    jedis.disconnect();
                } catch (Exception e) {

                }
            }
        }

        @Override
        public boolean validateObject(PooledObject<SentinelShardedJedis> pooledShardedJedis) {
            try {
                SentinelShardedJedis jedis = pooledShardedJedis.getObject();
                for (Jedis shard : jedis.getAllShards()) {
                    String host = shard.getClient().getHost();
                    int port = shard.getClient().getPort();
                    if (!shardInfoMap.containsKey(host + port)) {
                        return false;
                    }

                    if (!shard.ping().equals("PONG")) {
                        return false;
                    }
                }
                return true;
            } catch (Exception ex) {
                return false;
            }
        }

        @Override
        public void activateObject(PooledObject<SentinelShardedJedis> p) throws Exception {

        }

        @Override
        public void passivateObject(PooledObject<SentinelShardedJedis> p) throws Exception {

        }
    }

    public static class SentinelInfo {
        private String masterName;
        private String clientName;
        private Set<String> sentinels;

        public SentinelInfo(String masterName, String clientName, Set<String> sentinels) {
            this.masterName = masterName;
            this.clientName = clientName;
            this.sentinels = sentinels;
        }

        public String getMasterName() {
            return masterName;
        }

        public String getClientName() {
            return clientName;
        }

        public Set<String> getSentinels() {
            return sentinels;
        }
    }
}
package redis.clients.jedis;

import redis.clients.util.Hashing;

import java.util.List;
import java.util.regex.Pattern;

public class SentinelShardedJedis extends ShardedJedis {

    protected SentinelShardedJedisPool dataSource = null;

    public SentinelShardedJedis(List<JedisShardInfo> shards) {
        super(shards);
    }

    public SentinelShardedJedis(List<JedisShardInfo> shards, Hashing algo) {
        super(shards, algo);
    }

    public SentinelShardedJedis(List<JedisShardInfo> shards, Pattern keyTagPattern) {
        super(shards, keyTagPattern);
    }

    public SentinelShardedJedis(List<JedisShardInfo> shards, Hashing algo, Pattern keyTagPattern) {
        super(shards, algo, keyTagPattern);
    }

    public void setDataSource(SentinelShardedJedisPool sentinelShardedJedisPool) {
        this.dataSource = sentinelShardedJedisPool;
    }

}

使用方法

JedisPoolConfig poolConfig = new JedisPoolConfig();
poolConfig.setMinIdle(4);
poolConfig.setMaxTotal(100);
poolConfig.setMaxWaitMillis(30000);

Set<String> sentinels = new HashSet<>();
sentinels.add("192.168.2.122:26379");
sentinels.add("192.168.2.128:26379");
Set<SentinelShardedJedisPool.SentinelInfo> sentinelInfos = new HashSet<>();
sentinelInfos.add(new SentinelShardedJedisPool.SentinelInfo("mymaster1", "m1", sentinels));
sentinelInfos.add(new SentinelShardedJedisPool.SentinelInfo("mymaster2", "m2", sentinels));
SentinelShardedJedisPool pool = new SentinelShardedJedisPool(sentinelInfos, poolConfig, Hashing.MURMUR_HASH, null);
SentinelShardedJedis jedis = pool.getResource();
jedis.set("key", "value");
jedis.close();
pool.close();

小結

本實現個人已經測試通過。但若采用本方案必須要經過一定的性能測試。如果問題歡迎一起討論。

最后編輯于
?著作權歸作者所有,轉載或內容合作請聯系作者
平臺聲明:文章內容(如有圖片或視頻亦包括在內)由作者上傳并發布,文章內容僅代表作者本人觀點,簡書系信息發布平臺,僅提供信息存儲服務。
  • 序言:七十年代末,一起剝皮案震驚了整個濱河市,隨后出現的幾起案子,更是在濱河造成了極大的恐慌,老刑警劉巖,帶你破解...
    沈念sama閱讀 228,333評論 6 531
  • 序言:濱河連續發生了三起死亡事件,死亡現場離奇詭異,居然都是意外死亡,警方通過查閱死者的電腦和手機,發現死者居然都...
    沈念sama閱讀 98,491評論 3 416
  • 文/潘曉璐 我一進店門,熙熙樓的掌柜王于貴愁眉苦臉地迎上來,“玉大人,你說我怎么就攤上這事。” “怎么了?”我有些...
    開封第一講書人閱讀 176,263評論 0 374
  • 文/不壞的土叔 我叫張陵,是天一觀的道長。 經常有香客問我,道長,這世上最難降的妖魔是什么? 我笑而不...
    開封第一講書人閱讀 62,946評論 1 309
  • 正文 為了忘掉前任,我火速辦了婚禮,結果婚禮上,老公的妹妹穿的比我還像新娘。我一直安慰自己,他們只是感情好,可當我...
    茶點故事閱讀 71,708評論 6 410
  • 文/花漫 我一把揭開白布。 她就那樣靜靜地躺著,像睡著了一般。 火紅的嫁衣襯著肌膚如雪。 梳的紋絲不亂的頭發上,一...
    開封第一講書人閱讀 55,186評論 1 324
  • 那天,我揣著相機與錄音,去河邊找鬼。 笑死,一個胖子當著我的面吹牛,可吹牛的內容都是我干的。 我是一名探鬼主播,決...
    沈念sama閱讀 43,255評論 3 441
  • 文/蒼蘭香墨 我猛地睜開眼,長吁一口氣:“原來是場噩夢啊……” “哼!你這毒婦竟也來了?” 一聲冷哼從身側響起,我...
    開封第一講書人閱讀 42,409評論 0 288
  • 序言:老撾萬榮一對情侶失蹤,失蹤者是張志新(化名)和其女友劉穎,沒想到半個月后,有當地人在樹林里發現了一具尸體,經...
    沈念sama閱讀 48,939評論 1 335
  • 正文 獨居荒郊野嶺守林人離奇死亡,尸身上長有42處帶血的膿包…… 初始之章·張勛 以下內容為張勛視角 年9月15日...
    茶點故事閱讀 40,774評論 3 354
  • 正文 我和宋清朗相戀三年,在試婚紗的時候發現自己被綠了。 大學時的朋友給我發了我未婚夫和他白月光在一起吃飯的照片。...
    茶點故事閱讀 42,976評論 1 369
  • 序言:一個原本活蹦亂跳的男人離奇死亡,死狀恐怖,靈堂內的尸體忽然破棺而出,到底是詐尸還是另有隱情,我是刑警寧澤,帶...
    沈念sama閱讀 38,518評論 5 359
  • 正文 年R本政府宣布,位于F島的核電站,受9級特大地震影響,放射性物質發生泄漏。R本人自食惡果不足惜,卻給世界環境...
    茶點故事閱讀 44,209評論 3 347
  • 文/蒙蒙 一、第九天 我趴在偏房一處隱蔽的房頂上張望。 院中可真熱鬧,春花似錦、人聲如沸。這莊子的主人今日做“春日...
    開封第一講書人閱讀 34,641評論 0 26
  • 文/蒼蘭香墨 我抬頭看了看天上的太陽。三九已至,卻和暖如春,著一層夾襖步出監牢的瞬間,已是汗流浹背。 一陣腳步聲響...
    開封第一講書人閱讀 35,872評論 1 286
  • 我被黑心中介騙來泰國打工, 沒想到剛下飛機就差點兒被人妖公主榨干…… 1. 我叫王不留,地道東北人。 一個月前我還...
    沈念sama閱讀 51,650評論 3 391
  • 正文 我出身青樓,卻偏偏與公主長得像,于是被迫代替她去往敵國和親。 傳聞我的和親對象是個殘疾皇子,可洞房花燭夜當晚...
    茶點故事閱讀 47,958評論 2 373

推薦閱讀更多精彩內容