Zookeeper的默认选举

zookeeper中默认的选举模式是通过类FastLeaderElection类来实现的,在QuorumPeer类的启动方法start()方法中,通过startLeaderElection()方法首先生成一开始自己的选票,首先会把投票的leader选为自己的id,同时带上自己的zxid,以及当前的epoch轮数,同时上者也是构成一张选票的三个元素。之后根据 createElectionAlgorithm()来生成选举功能的类。

synchronized public void startLeaderElection() {
    try {
        if (getPeerState() == ServerState.LOOKING) {
            currentVote = new Vote(myid, getLastLoggedZxid(), getCurrentEpoch());
        }
    } catch(IOException e) {
        RuntimeException re = new RuntimeException(e.getMessage());
        re.setStackTrace(e.getStackTrace());
        throw re;
    }

    this.electionAlg = createElectionAlgorithm(electionType);
}

protected Election createElectionAlgorithm(int electionAlgorithm){
    Election le=null;

    //TODO: use a factory rather than a switch
    switch (electionAlgorithm) {
    case 1:
        le = new AuthFastLeaderElection(this);
        break;
    case 2:
        le = new AuthFastLeaderElection(this, true);
        break;
    case 3:
        qcm = createCnxnManager();
        QuorumCnxManager.Listener listener = qcm.listener;
        if(listener != null){
            listener.start();
            FastLeaderElection fle = new FastLeaderElection(this, qcm);
            fle.start();
            le = fle;
        } else {
            LOG.error("Null listener when initializing cnx manager");
        }
        break;
    default:
        assert false;
    }
    return le;
}

 

Zookeeper中electionAlgorithm的值默认为3,所以这里会生成QuorumCnxManager以及FastLeaderElection来完成默认的选举。但此时FastLeaderElection只是完成了构造方法,并没有正式开始选举。

 

private void starter(QuorumPeer self, QuorumCnxManager manager) {
    this.self = self;
    proposedLeader = -1;
    proposedZxid = -1;

    sendqueue = new LinkedBlockingQueue<ToSend>();
    recvqueue = new LinkedBlockingQueue<Notification>();
    this.messenger = new Messenger(manager);
}

Messenger(QuorumCnxManager manager) {

    this.ws = new WorkerSender(manager);

    this.wsThread = new Thread(this.ws,
            "WorkerSender[myid=" + self.getId() + "]");
    this.wsThread.setDaemon(true);

    this.wr = new WorkerReceiver(manager);

    this.wrThread = new Thread(this.wr,
            "WorkerReceiver[myid=" + self.getId() + "]");
    this.wrThread.setDaemon(true);
}

 

在FastLeaderElection的构造方法中,构造了两条队列分别存放要发送的消息和接收到的消息,同时根据之前负责与各个服务器之前通信的QuorumCnxManager来生成WokerSender和WorkerReceiver两条线程来负责消息的接受解析和发出,但此时线程的start()方法并还没有被调用,此时的选举并未开始。

 

public void run() {
    while (!stop) {
        try {
            ToSend m = sendqueue.poll(3000, TimeUnit.MILLISECONDS);
            if(m == null) continue;

            process(m);
        } catch (InterruptedException e) {
            break;
        }
    }
    LOG.info("WorkerSender is down");
}
void process(ToSend m) {
    ByteBuffer requestBuffer = buildMsg(m.state.ordinal(),
                                        m.leader,
                                        m.zxid,
                                        m.electionEpoch,
                                        m.peerEpoch,
                                        m.configData);

    manager.toSend(m.sid, requestBuffer);

}

负责发送消息的WokerSender的run()方法实现显得极为简单,只是简单的不断从存放要发送消息的队列中不断去取,然后调用process()方法构造消息交由之前的QuorumCnxManager发送给别的服务器。

 

而负责接收消息的WorkerReceiver的run()方法的实现要复杂的多。

 public void run() {

        Message response;
        while (!stop) {
            // Sleeps on receive
            try {
                response = manager.pollRecvQueue(3000, TimeUnit.MILLISECONDS);
                if(response == null) continue;

                // The current protocol and two previous generations all send at least 28 bytes
                if (response.buffer.capacity() < 28) {
                    LOG.error("Got a short response: " + response.buffer.capacity());
                    continue;
                }

                // this is the backwardCompatibility mode in place before ZK-107
                // It is for a version of the protocol in which we didn't send peer epoch
                // With peer epoch and version the message became 40 bytes
                boolean backCompatibility28 = (response.buffer.capacity() == 28);

                // this is the backwardCompatibility mode for no version information
                boolean backCompatibility40 = (response.buffer.capacity() == 40);
                
                response.buffer.clear();

                // Instantiate Notification and set its attributes
                Notification n = new Notification();

                int rstate = response.buffer.getInt();
                long rleader = response.buffer.getLong();
                long rzxid = response.buffer.getLong();
                long relectionEpoch = response.buffer.getLong();
                long rpeerepoch;

                int version = 0x0;
                if (!backCompatibility28) {
                    rpeerepoch = response.buffer.getLong();
                    if (!backCompatibility40) {
                        /*
                         * Version added in 3.4.6
                         */
                        
                        version = response.buffer.getInt();
                    } else {
                        LOG.info("Backward compatibility mode (36 bits), server id: {}", response.sid);
                    }
                } else {
                    LOG.info("Backward compatibility mode (28 bits), server id: {}", response.sid);
                    rpeerepoch = ZxidUtils.getEpochFromZxid(rzxid);
                }

                QuorumVerifier rqv = null;

                // check if we have a version that includes config. If so extract config info from message.
                if (version > 0x1) {
                    int configLength = response.buffer.getInt();
                    byte b[] = new byte[configLength];

                    response.buffer.get(b);
                                               
                    synchronized(self) {
                        try {
                            rqv = self.configFromString(new String(b));
                            QuorumVerifier curQV = self.getQuorumVerifier();
                            if (rqv.getVersion() > curQV.getVersion()) {
                                LOG.info("{} Received version: {} my version: {}", self.getId(),
                                        Long.toHexString(rqv.getVersion()),
                                        Long.toHexString(self.getQuorumVerifier().getVersion()));
                                if (self.getPeerState() == ServerState.LOOKING) {
                                    LOG.debug("Invoking processReconfig(), state: {}", self.getServerState());
                                    self.processReconfig(rqv, null, null, false);
                                    if (!rqv.equals(curQV)) {
                                        LOG.info("restarting leader election");
                                        self.shuttingDownLE = true;
                                        self.getElectionAlg().shutdown();

                                        break;
                                    }
                                } else {
                                    LOG.debug("Skip processReconfig(), state: {}", self.getServerState());
                                }
                            }
                        } catch (IOException e) {
                            LOG.error("Something went wrong while processing config received from {}", response.sid);
                       } catch (ConfigException e) {
                           LOG.error("Something went wrong while processing config received from {}", response.sid);
                       }
                    }                          
                } else {
                    LOG.info("Backward compatibility mode (before reconfig), server id: {}", response.sid);
                }
               
                /*
                 * If it is from a non-voting server (such as an observer or
                 * a non-voting follower), respond right away.
                 */
                if(!self.getCurrentAndNextConfigVoters().contains(response.sid)) {
                    Vote current = self.getCurrentVote();
                    QuorumVerifier qv = self.getQuorumVerifier();
                    ToSend notmsg = new ToSend(ToSend.mType.notification,
                            current.getId(),
                            current.getZxid(),
                            logicalclock.get(),
                            self.getPeerState(),
                            response.sid,
                            current.getPeerEpoch(),
                            qv.toString().getBytes());

                    sendqueue.offer(notmsg);
                } else {
                    // Receive new message
                    if (LOG.isDebugEnabled()) {
                        LOG.debug("Receive new notification message. My id = "
                                + self.getId());
                    }

                    // State of peer that sent this message
                    QuorumPeer.ServerState ackstate = QuorumPeer.ServerState.LOOKING;
                    switch (rstate) {
                    case 0:
                        ackstate = QuorumPeer.ServerState.LOOKING;
                        break;
                    case 1:
                        ackstate = QuorumPeer.ServerState.FOLLOWING;
                        break;
                    case 2:
                        ackstate = QuorumPeer.ServerState.LEADING;
                        break;
                    case 3:
                        ackstate = QuorumPeer.ServerState.OBSERVING;
                        break;
                    default:
                        continue;
                    }

                    n.leader = rleader;
                    n.zxid = rzxid;
                    n.electionEpoch = relectionEpoch;
                    n.state = ackstate;
                    n.sid = response.sid;
                    n.peerEpoch = rpeerepoch;
                    n.version = version;
                    n.qv = rqv;
                    /*
                     * Print notification info
                     */
                    if(LOG.isInfoEnabled()){
                        printNotification(n);
                    }

                    /*
                     * If this server is looking, then send proposed leader
                     */

                    if(self.getPeerState() == QuorumPeer.ServerState.LOOKING){
                        recvqueue.offer(n);

                        /*
                         * Send a notification back if the peer that sent this
                         * message is also looking and its logical clock is
                         * lagging behind.
                         */
                        if((ackstate == QuorumPeer.ServerState.LOOKING)
                                && (n.electionEpoch < logicalclock.get())){
                            Vote v = getVote();
                            QuorumVerifier qv = self.getQuorumVerifier();
                            ToSend notmsg = new ToSend(ToSend.mType.notification,
                                    v.getId(),
                                    v.getZxid(),
                                    logicalclock.get(),
                                    self.getPeerState(),
                                    response.sid,
                                    v.getPeerEpoch(),
                                    qv.toString().getBytes());
                            sendqueue.offer(notmsg);
                        }
                    } else {
                        /*
                         * If this server is not looking, but the one that sent the ack
                         * is looking, then send back what it believes to be the leader.
                         */
                        Vote current = self.getCurrentVote();
                        if(ackstate == QuorumPeer.ServerState.LOOKING){
                            if(LOG.isDebugEnabled()){
                                LOG.debug("Sending new notification. My id ={} recipient={} zxid=0x{} leader={} config version = {}",
                                        self.getId(),
                                        response.sid,
                                        Long.toHexString(current.getZxid()),
                                        current.getId(),
                                        Long.toHexString(self.getQuorumVerifier().getVersion()));
                            }

                            QuorumVerifier qv = self.getQuorumVerifier();
                            ToSend notmsg = new ToSend(
                                    ToSend.mType.notification,
                                    current.getId(),
                                    current.getZxid(),
                                    current.getElectionEpoch(),
                                    self.getPeerState(),
                                    response.sid,
                                    current.getPeerEpoch(),
                                    qv.toString().getBytes());
                            sendqueue.offer(notmsg);
                        }
                    }
                }
            } catch (InterruptedException e) {
                LOG.warn("Interrupted Exception while waiting for new message" +
                        e.toString());
            }
        }
        LOG.info("WorkerReceiver is down");
    }
}

首先,会从QuorumCnxManager中存放接收到的消息的队列中去取得,之后就会对这个消息进行解析。但是,针对一条消息解析的前提是首先这个消息的大小应该大于28字节。消息发出者的角色(int),所要支持的leader(long),当前的zxid(long),当前的轮数epoch(long)。以上是消息必须所包含的成员,缺少一样都无法完成后面关于选举的选票消息解析。

 

在确认接受到的消息的大小之后,取得发出消息的服务器的id来判断该id是否在参与投票的服务器行列之内,如果不在(比如说该服务器的角色是一个observer),那么忽略这一消息,并且发送一条包含自己选票信息的消息给这个服务器。之后,将消息的具体数据注入在Notification类中,方便后续的使用。

 

之后,判断此时服务器处于的状态,如果处于looking,那么说明此时的服务器需要这条消息来参与选举的过程,那么将这条消息正式加入先前构造方法中创建的存放消息的队列中。但是,如果这条消息发出方处于looking状态,并且其轮数小于当前的轮数,那么将自己当前的选票发送给这条消息的发送者。

 

但是如果此时当前服务器不处于looking状态并且发送方还处于looking状态,那么则将选举结果发送回。

 

以上两条线程是FastLeaderElection内部接受和发送消息的逻辑。

 

但此时,FastLeaderElection还没有正式开始工作,不过在构造方法完成后,马上会调用start()方法开始,但选举的逻辑还没有开始。

void start(){
    this.wsThread.start();
    this.wrThread.start();
}

 

 

 

在QuorumPeer完成上述FastLeaderElection的构建之后,就会调用run()方法,在run()方法中,如果处于looking状态,就会调用FastLeaderElection的lookForLeader()方法,正式开始选举。

public Vote lookForLeader() throws InterruptedException {
    try {
        self.jmxLeaderElectionBean = new LeaderElectionBean();
        MBeanRegistry.getInstance().register(
                self.jmxLeaderElectionBean, self.jmxLocalPeerBean);
    } catch (Exception e) {
        LOG.warn("Failed to register with JMX", e);
        self.jmxLeaderElectionBean = null;
    }
    if (self.start_fle == 0) {
       self.start_fle = Time.currentElapsedTime();
    }
    try {
        Map<Long, Vote> recvset = new HashMap<Long, Vote>();

        Map<Long, Vote> outofelection = new HashMap<Long, Vote>();

        int notTimeout = finalizeWait;

        synchronized(this){
            logicalclock.incrementAndGet();
            updateProposal(getInitId(), getInitLastLoggedZxid(), getPeerEpoch());
        }

        LOG.info("New election. My id =  " + self.getId() +
                ", proposed zxid=0x" + Long.toHexString(proposedZxid));
        sendNotifications();

        /*
         * Loop in which we exchange notifications until we find a leader
         */

        while ((self.getPeerState() == ServerState.LOOKING) &&
                (!stop)){
            /*
             * Remove next notification from queue, times out after 2 times
             * the termination time
             */
            Notification n = recvqueue.poll(notTimeout,
                    TimeUnit.MILLISECONDS);

            /*
             * Sends more notifications if haven't received enough.
             * Otherwise processes new notification.
             */
            if(n == null){
                if(manager.haveDelivered()){
                    sendNotifications();
                } else {
                    manager.connectAll();
                }

                /*
                 * Exponential backoff
                 */
                int tmpTimeOut = notTimeout*2;
                notTimeout = (tmpTimeOut < maxNotificationInterval?
                        tmpTimeOut : maxNotificationInterval);
                LOG.info("Notification time out: " + notTimeout);
            } 
            else if (self.getCurrentAndNextConfigVoters().contains(n.sid)) {
                /*
                 * Only proceed if the vote comes from a replica in the current or next
                 * voting view.
                 */
                switch (n.state) {
                case LOOKING:
                    if (getInitLastLoggedZxid() == -1) {
                        LOG.debug("Ignoring notification as our zxid is -1");
                        break;
                    }
                    if (n.zxid == -1) {
                        LOG.debug("Ignoring notification from member with -1 zxid" + n.sid);
                        break;
                    }
                    // If notification > current, replace and send messages out
                    if (n.electionEpoch > logicalclock.get()) {
                        logicalclock.set(n.electionEpoch);
                        recvset.clear();
                        if(totalOrderPredicate(n.leader, n.zxid, n.peerEpoch,
                                getInitId(), getInitLastLoggedZxid(), getPeerEpoch())) {
                            updateProposal(n.leader, n.zxid, n.peerEpoch);
                        } else {
                            updateProposal(getInitId(),
                                    getInitLastLoggedZxid(),
                                    getPeerEpoch());
                        }
                        sendNotifications();
                    } else if (n.electionEpoch < logicalclock.get()) {
                        if(LOG.isDebugEnabled()){
                            LOG.debug("Notification election epoch is smaller than logicalclock. n.electionEpoch = 0x"
                                    + Long.toHexString(n.electionEpoch)
                                    + ", logicalclock=0x" + Long.toHexString(logicalclock.get()));
                        }
                        break;
                    } else if (totalOrderPredicate(n.leader, n.zxid, n.peerEpoch,
                            proposedLeader, proposedZxid, proposedEpoch)) {
                        updateProposal(n.leader, n.zxid, n.peerEpoch);
                        sendNotifications();
                    }

                    if(LOG.isDebugEnabled()){
                        LOG.debug("Adding vote: from=" + n.sid +
                                ", proposed leader=" + n.leader +
                                ", proposed zxid=0x" + Long.toHexString(n.zxid) +
                                ", proposed election epoch=0x" + Long.toHexString(n.electionEpoch));
                    }

                    recvset.put(n.sid, new Vote(n.leader, n.zxid, n.electionEpoch, n.peerEpoch));

                    if (termPredicate(recvset,
                            new Vote(proposedLeader, proposedZxid,
                                    logicalclock.get(), proposedEpoch))) {

                        // Verify if there is any change in the proposed leader
                        while((n = recvqueue.poll(finalizeWait,
                                TimeUnit.MILLISECONDS)) != null){
                            if(totalOrderPredicate(n.leader, n.zxid, n.peerEpoch,
                                    proposedLeader, proposedZxid, proposedEpoch)){
                                recvqueue.put(n);
                                break;
                            }
                        }

                        /*
                         * This predicate is true once we don't read any new
                         * relevant message from the reception queue
                         */
                        if (n == null) {
                            self.setPeerState((proposedLeader == self.getId()) ?
                                    ServerState.LEADING: learningState());

                            Vote endVote = new Vote(proposedLeader,
                                    proposedZxid, proposedEpoch);
                            leaveInstance(endVote);
                            return endVote;
                        }
                    }
                    break;
                case OBSERVING:
                    LOG.debug("Notification from observer: " + n.sid);
                    break;
                case FOLLOWING:
                case LEADING:
                    /*
                     * Consider all notifications from the same epoch
                     * together.
                     */
                    if(n.electionEpoch == logicalclock.get()){
                        recvset.put(n.sid, new Vote(n.leader, n.zxid, n.electionEpoch, n.peerEpoch));
                        if(termPredicate(recvset, new Vote(n.leader,
                                        n.zxid, n.electionEpoch, n.peerEpoch, n.state))
                                        && checkLeader(outofelection, n.leader, n.electionEpoch)) {
                            self.setPeerState((n.leader == self.getId()) ?
                                    ServerState.LEADING: learningState());

                            Vote endVote = new Vote(n.leader, n.zxid, n.peerEpoch);
                            leaveInstance(endVote);
                            return endVote;
                        }
                    }

                    /*
                     * Before joining an established ensemble, verify that
                     * a majority are following the same leader.
                     * Only peer epoch is used to check that the votes come
                     * from the same ensemble. This is because there is at
                     * least one corner case in which the ensemble can be
                     * created with inconsistent zxid and election epoch
                     * info. However, given that only one ensemble can be
                     * running at a single point in time and that each 
                     * epoch is used only once, using only the epoch to 
                     * compare the votes is sufficient.
                     * 
                     * @see https://issues.apache.org/jira/browse/ZOOKEEPER-1732
                     */
                    outofelection.put(n.sid, new Vote(n.leader, 
                            IGNOREVALUE, IGNOREVALUE, n.peerEpoch, n.state));
                    if (termPredicate(outofelection, new Vote(n.leader,
                            IGNOREVALUE, IGNOREVALUE, n.peerEpoch, n.state))
                            && checkLeader(outofelection, n.leader, IGNOREVALUE)) {
                        synchronized(this){
                            logicalclock.set(n.electionEpoch);
                            self.setPeerState((n.leader == self.getId()) ?
                                    ServerState.LEADING: learningState());
                        }
                        Vote endVote = new Vote(n.leader, n.zxid, n.peerEpoch);
                        leaveInstance(endVote);
                        return endVote;
                    }
                    break;
                default:
                    LOG.warn("Notification state unrecoginized: " + n.state
                          + " (n.state), " + n.sid + " (n.sid)");
                    break;
                }
            } else {
                LOG.warn("Ignoring notification from non-cluster member " + n.sid);
            }
        }
        return null;
    } finally {
        try {
            if(self.jmxLeaderElectionBean != null){
                MBeanRegistry.getInstance().unregister(
                        self.jmxLeaderElectionBean);
            }
        } catch (Exception e) {
            LOG.warn("Failed to unregister with JMX", e);
        }
        self.jmxLeaderElectionBean = null;
        LOG.debug("Number of connection processing threads: {}",
                manager.getConnectionThreadCount());
    }
}

首先记录下选举开始的时间,在选举之后开始正式lead的工作时会计算两者的间隔作为选举的持续时间。

之后,在进入选举前,给代表当前轮数的参数logicalclock加一,代表在先前轮数的基础上加一表示新的一轮选举。

之后初始化自己的选票,第一次的情况下,选举自己为所要投票的leader。

之后调用sendNotifications()方法发送给所有参与投票的服务器。

private void sendNotifications() {
    for (long sid : self.getCurrentAndNextConfigVoters()) {
        QuorumVerifier qv = self.getQuorumVerifier();
        ToSend notmsg = new ToSend(ToSend.mType.notification,
                proposedLeader,
                proposedZxid,
                logicalclock.get(),
                QuorumPeer.ServerState.LOOKING,
                sid,
                proposedEpoch, qv.toString().getBytes());
        if(LOG.isDebugEnabled()){
            LOG.debug("Sending Notification: " + proposedLeader + " (n.leader), 0x"  +
                  Long.toHexString(proposedZxid) + " (n.zxid), 0x" + Long.toHexString(logicalclock.get())  +
                  " (n.round), " + sid + " (recipient), " + self.getId() +
                  " (myid), 0x" + Long.toHexString(proposedEpoch) + " (n.peerEpoch)");
        }
        sendqueue.offer(notmsg);
    }
}

 

这个方法便利所有配置了的投票服务器,构造消息发送自己的选票给他们,当然这里只是交给了发送消息的队列。

 

之后如果自己的状态还是looking,那么开始根据收到的消息进行解析,并进行相应的操作。

从接收队列中选取消息之后,首先确认消息发出方是参与投票的服务器,如果不是,则在这里不予理会,相应的措施已经在刚刚的WorkerReceiver中完成。

在确认了消息的发出方是参与投票的服务器之后,根据其状态进行相应的操作。

首先如果是looking状态,那么比较消息的轮数与当前服务器的轮数进行比较,如果接收到的消息的轮数大于当前服务器的轮数,那么可能说明当前服务器因为各种原因宕机了一段时间,那么此时说明该服务器应该放弃当前的投票选择,并且将刚刚收到的轮数更大的选票作为自己新一轮要发给所有服务器的选票。这样,选票的内容发生了改变。同时,清空自己用来保存所有已经接收到的选票的Map,重新开始接收选票。

如果接收到的消息的轮数小于当前轮数,那么可以直接忽略了。

如果两者消息的轮数一样,那么通过totalOrderPredicate()方法,进行消息中参数的比较。

protected boolean totalOrderPredicate(long newId, long newZxid, long newEpoch, long curId, long curZxid, long curEpoch) {
    LOG.debug("id: " + newId + ", proposed id: " + curId + ", zxid: 0x" +
            Long.toHexString(newZxid) + ", proposed zxid: 0x" + Long.toHexString(curZxid));
    if(self.getQuorumVerifier().getWeight(newId) == 0){
        return false;
    }

    /*
     * We return true if one of the following three cases hold:
     * 1- New epoch is higher
     * 2- New epoch is the same as current epoch, but new zxid is higher
     * 3- New epoch is the same as current epoch, new zxid is the same
     *  as current zxid, but server id is higher.
     */

    return ((newEpoch > curEpoch) ||
            ((newEpoch == curEpoch) &&
            ((newZxid > curZxid) || ((newZxid == curZxid) && (newId > curId)))));
}

 

首先比较轮数,之后在轮数一样的前提下比较zxid,再再前者一样的前提下比较投票的服务器id大小,在前面三轮,如果接收到的消息先出现较大者,那么更新自己的选票为接收到的选票内容,并发给所有参与选举过程的服务器。

 

 

之后将接收到的消息的发出方的id作为key,收到的选票作为value存储在map中。

 

之后由于一条接收到的消息的处理已经完成,通过termPredicate()方法开始检验是否有必要确认选举结果的产生。

private boolean termPredicate(Map<Long, Vote> votes, Vote vote) {
    SyncedLearnerTracker voteSet = new SyncedLearnerTracker();
    voteSet.addQuorumVerifier(self.getQuorumVerifier());
    if (self.getLastSeenQuorumVerifier() != null
            && self.getLastSeenQuorumVerifier().getVersion() > self
                    .getQuorumVerifier().getVersion()) {
        voteSet.addQuorumVerifier(self.getLastSeenQuorumVerifier());
    }

    /*
     * First make the views consistent. Sometimes peers will have different
     * zxids for a server depending on timing.
     */
    for (Map.Entry<Long, Vote> entry : votes.entrySet()) {
        if (vote.equals(entry.getValue())) {
            voteSet.addAck(entry.getKey());
        }
    }

    return voteSet.hasAllQuorums();
}

 

这里,以自己当前选票中投票给的leader作为参照,遍历接收到的消息集合,如果与自己选择相同的服务器个数超过参与选票的服务器总数,那么就确认了当前服务器的选举结果产生,结果就是自己所投票的那个服务器。

 

 

此时,并不急着结束自己的选举流程,在在一定timeout的情况下去等待相应的时间继续去从接收队列去取,这一期间如果自己的选票被更新,那么就要从新进入循环,把新消息放回队列,继续之前的选举流程,而要是不会更新自己选票的消息,那么无视,继续等待一定的timeout。

 

如果在一定的timeout之后,成功没有接受到新的消息,宣告自己的选举过程结束,如果自己当前的投票对象是自己,那么当前服务器成为leader,否则成为learner。

 

 

之前的情况是发生在接受到的消息发出方是lookong状态的情况下,如果是leading,那么说明此时leader已经被选出,直接根据收到的选票更新自己的角色完成选举流程。

 

 

 

 

 

  • 0
    点赞
  • 0
    收藏
    觉得还不错? 一键收藏
  • 0
    评论

“相关推荐”对你有帮助么?

  • 非常没帮助
  • 没帮助
  • 一般
  • 有帮助
  • 非常有帮助
提交
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值