Complete Candidate behavior implementation
[controller.git] / opendaylight / md-sal / sal-akka-raft / src / main / java / org / opendaylight / controller / cluster / raft / behaviors / Leader.java
1 /*
2  * Copyright (c) 2014 Cisco Systems, Inc. and others.  All rights reserved.
3  *
4  * This program and the accompanying materials are made available under the
5  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
6  * and is available at http://www.eclipse.org/legal/epl-v10.html
7  */
8
9 package org.opendaylight.controller.cluster.raft.behaviors;
10
11 import akka.actor.ActorRef;
12 import akka.actor.ActorSelection;
13 import akka.actor.Cancellable;
14 import com.google.common.base.Preconditions;
15 import org.opendaylight.controller.cluster.raft.FollowerLogInformation;
16 import org.opendaylight.controller.cluster.raft.FollowerLogInformationImpl;
17 import org.opendaylight.controller.cluster.raft.RaftActorContext;
18 import org.opendaylight.controller.cluster.raft.RaftState;
19 import org.opendaylight.controller.cluster.raft.internal.messages.SendHeartBeat;
20 import org.opendaylight.controller.cluster.raft.messages.AppendEntries;
21 import org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply;
22 import org.opendaylight.controller.cluster.raft.messages.RequestVote;
23 import org.opendaylight.controller.cluster.raft.messages.RequestVoteReply;
24 import scala.concurrent.duration.FiniteDuration;
25
26 import java.util.Collections;
27 import java.util.HashMap;
28 import java.util.List;
29 import java.util.Map;
30 import java.util.concurrent.TimeUnit;
31 import java.util.concurrent.atomic.AtomicLong;
32
33 /**
34  * The behavior of a RaftActor when it is in the Leader state
35  * <p/>
36  * Leaders:
37  * <ul>
38  * <li> Upon election: send initial empty AppendEntries RPCs
39  * (heartbeat) to each server; repeat during idle periods to
40  * prevent election timeouts (§5.2)
41  * <li> If command received from client: append entry to local log,
42  * respond after entry applied to state machine (§5.3)
43  * <li> If last log index ≥ nextIndex for a follower: send
44  * AppendEntries RPC with log entries starting at nextIndex
45  * <ul>
46  * <li> If successful: update nextIndex and matchIndex for
47  * follower (§5.3)
48  * <li> If AppendEntries fails because of log inconsistency:
49  * decrement nextIndex and retry (§5.3)
50  * </ul>
51  * <li> If there exists an N such that N > commitIndex, a majority
52  * of matchIndex[i] ≥ N, and log[N].term == currentTerm:
53  * set commitIndex = N (§5.3, §5.4).
54  */
55 public class Leader extends AbstractRaftActorBehavior {
56
57     /**
58      * The interval at which a heart beat message will be sent to the remote
59      * RaftActor
60      * <p/>
61      * Since this is set to 100 milliseconds the Election timeout should be
62      * at least 200 milliseconds
63      */
64     public static final FiniteDuration HEART_BEAT_INTERVAL =
65         new FiniteDuration(100, TimeUnit.MILLISECONDS);
66
67     private final Map<String, FollowerLogInformation> followerToLog =
68         new HashMap();
69
70     private final Map<String, ActorSelection> followerToActor = new HashMap<>();
71
72     private Cancellable heartbeatCancel = null;
73
74     public Leader(RaftActorContext context, List<String> followePaths) {
75         super(context);
76
77         for (String followerPath : followePaths) {
78             FollowerLogInformation followerLogInformation =
79                 new FollowerLogInformationImpl(followerPath,
80                     new AtomicLong(0),
81                     new AtomicLong(0));
82
83             followerToActor.put(followerPath,
84                 context.actorSelection(followerLogInformation.getId()));
85             followerToLog.put(followerPath, followerLogInformation);
86
87         }
88
89         // Immediately schedule a heartbeat
90         // Upon election: send initial empty AppendEntries RPCs
91         // (heartbeat) to each server; repeat during idle periods to
92         // prevent election timeouts (§5.2)
93         scheduleHeartBeat(new FiniteDuration(0, TimeUnit.SECONDS));
94
95
96     }
97
98     @Override protected RaftState handleAppendEntries(ActorRef sender,
99         AppendEntries appendEntries, RaftState suggestedState) {
100         return suggestedState;
101     }
102
103     @Override protected RaftState handleAppendEntriesReply(ActorRef sender,
104         AppendEntriesReply appendEntriesReply, RaftState suggestedState) {
105         return suggestedState;
106     }
107
108     @Override protected RaftState handleRequestVote(ActorRef sender,
109         RequestVote requestVote, RaftState suggestedState) {
110         return suggestedState;
111     }
112
113     @Override protected RaftState handleRequestVoteReply(ActorRef sender,
114         RequestVoteReply requestVoteReply, RaftState suggestedState) {
115         return suggestedState;
116     }
117
118     @Override protected RaftState state() {
119         return RaftState.Leader;
120     }
121
122     @Override public RaftState handleMessage(ActorRef sender, Object message) {
123         Preconditions.checkNotNull(sender, "sender should not be null");
124
125         scheduleHeartBeat(HEART_BEAT_INTERVAL);
126
127         if (message instanceof SendHeartBeat) {
128             for (ActorSelection follower : followerToActor.values()) {
129                 follower.tell(new AppendEntries(
130                     context.getTermInformation().getCurrentTerm().get(),
131                     context.getId(),
132                     context.getReplicatedLog().last().getIndex(),
133                     context.getReplicatedLog().last().getTerm(),
134                     Collections.EMPTY_LIST, context.getCommitIndex().get()),
135                     context.getActor());
136             }
137             return state();
138         }
139         return super.handleMessage(sender, message);
140     }
141
142     private void scheduleHeartBeat(FiniteDuration interval) {
143         if (heartbeatCancel != null && !heartbeatCancel.isCancelled()) {
144             heartbeatCancel.cancel();
145         }
146
147         // Schedule a heartbeat. When the scheduler triggers a SendHeartbeat
148         // message is sent to itself.
149         // Scheduling the heartbeat only once here because heartbeats do not
150         // need to be sent if there are other messages being sent to the remote
151         // actor.
152         heartbeatCancel =
153             context.getActorSystem().scheduler().scheduleOnce(interval,
154                 context.getActor(), new SendHeartBeat(),
155                 context.getActorSystem().dispatcher(), context.getActor());
156     }
157
158 }