use of org.neo4j.causalclustering.core.consensus.outcome.Outcome in project neo4j by neo4j.
the class LeaderTest method leaderShouldIgnoreSuccessResponseThatIndicatesLaggingWhileLocalStateIndicatesFollowerIsCaughtUp.
@Test
public void leaderShouldIgnoreSuccessResponseThatIndicatesLaggingWhileLocalStateIndicatesFollowerIsCaughtUp() throws Exception {
// given
/*
* A leader who
* - has an append index of 100
* - knows about instance 2
* - assumes that instance 2 is fully caught up
*/
Leader leader = new Leader();
MemberId instance2 = member(2);
int j = 100;
FollowerState instance2State = createArtificialFollowerState(j);
ReadableRaftState state = mock(ReadableRaftState.class);
FollowerStates<MemberId> followerState = new FollowerStates<>();
followerState = new FollowerStates<>(followerState, instance2, instance2State);
ReadableRaftLog logMock = mock(ReadableRaftLog.class);
when(logMock.appendIndex()).thenReturn(100L);
// with commit requests in this test
when(state.commitIndex()).thenReturn(-1L);
when(state.entryLog()).thenReturn(logMock);
when(state.followerStates()).thenReturn(followerState);
// both leader and follower are in the same term
when(state.term()).thenReturn(4L);
// when that leader is asked to handle a response from that follower that says that the follower is still
// missing things
RaftMessages.AppendEntries.Response response = appendEntriesResponse().success().matchIndex(80).term(4).from(instance2).build();
Outcome outcome = leader.handle(response, state, mock(Log.class));
// then the leader should not send anything, since this is a delayed, out of order response to a previous append
// request
assertTrue(outcome.getOutgoingMessages().isEmpty());
// The follower state should not be touched
FollowerStates<MemberId> updatedFollowerStates = outcome.getFollowerStates();
assertEquals(100, updatedFollowerStates.get(instance2).getMatchIndex());
}
use of org.neo4j.causalclustering.core.consensus.outcome.Outcome in project neo4j by neo4j.
the class LeaderTest method leaderShouldRejectAppendEntriesResponseWithNewerTermAndBecomeAFollower.
@Test
public void leaderShouldRejectAppendEntriesResponseWithNewerTermAndBecomeAFollower() throws Exception {
// given
RaftState state = raftState().myself(myself).build();
Leader leader = new Leader();
// when
AppendEntries.Response message = appendEntriesResponse().from(member1).term(state.term() + 1).build();
Outcome outcome = leader.handle(message, state, log());
// then
assertEquals(0, count(outcome.getOutgoingMessages()));
assertEquals(FOLLOWER, outcome.getRole());
assertEquals(0, count(outcome.getLogCommands()));
assertEquals(state.term() + 1, outcome.getTerm());
}
use of org.neo4j.causalclustering.core.consensus.outcome.Outcome in project neo4j by neo4j.
the class LeaderTest method leaderShouldSendHeartbeatsToAllClusterMembersOnReceiptOfHeartbeatTick.
// TODO: test that shows we don't commit for previous terms
@Test
public void leaderShouldSendHeartbeatsToAllClusterMembersOnReceiptOfHeartbeatTick() throws Exception {
// given
RaftState state = raftState().votingMembers(myself, member1, member2).replicationMembers(myself, member1, member2).build();
Leader leader = new Leader();
// make sure it has quorum.
leader.handle(new RaftMessages.HeartbeatResponse(member1), state, log());
// when
Outcome outcome = leader.handle(new Heartbeat(myself), state, log());
// then
assertTrue(messageFor(outcome, member1) instanceof RaftMessages.Heartbeat);
assertTrue(messageFor(outcome, member2) instanceof RaftMessages.Heartbeat);
}
use of org.neo4j.causalclustering.core.consensus.outcome.Outcome in project neo4j by neo4j.
the class LeaderTest method leaderShouldCommitOnMajorityResponse.
@Test
public void leaderShouldCommitOnMajorityResponse() throws Exception {
// given
InMemoryRaftLog raftLog = new InMemoryRaftLog();
raftLog.append(new RaftLogEntry(0, new ReplicatedString("lalalala")));
RaftState state = raftState().votingMembers(member1, member2).term(0).lastLogIndexBeforeWeBecameLeader(-1).leader(myself).leaderCommit(-1).entryLog(raftLog).messagesSentToFollower(member1, raftLog.appendIndex() + 1).messagesSentToFollower(member2, raftLog.appendIndex() + 1).build();
Leader leader = new Leader();
// when a single instance responds (plus self == 2 out of 3 instances)
Outcome outcome = leader.handle(new RaftMessages.AppendEntries.Response(member1, 0, true, 0, 0), state, log());
// then
assertEquals(0L, outcome.getCommitIndex());
assertEquals(0L, outcome.getLeaderCommit());
}
use of org.neo4j.causalclustering.core.consensus.outcome.Outcome in project neo4j by neo4j.
the class LeaderTest method leaderShouldCommitAllPreviouslyAppendedEntriesWhenCommittingLaterEntryInSameTerm.
// TODO move this someplace else, since log no longer holds the commit
@Test
public void leaderShouldCommitAllPreviouslyAppendedEntriesWhenCommittingLaterEntryInSameTerm() throws Exception {
// given
InMemoryRaftLog raftLog = new InMemoryRaftLog();
raftLog.append(new RaftLogEntry(0, new ReplicatedString("first!")));
raftLog.append(new RaftLogEntry(0, new ReplicatedString("second")));
raftLog.append(new RaftLogEntry(0, new ReplicatedString("third")));
RaftState state = raftState().votingMembers(myself, member1, member2).term(0).entryLog(raftLog).messagesSentToFollower(member1, raftLog.appendIndex() + 1).messagesSentToFollower(member2, raftLog.appendIndex() + 1).build();
Leader leader = new Leader();
// when
Outcome outcome = leader.handle(new AppendEntries.Response(member1, 0, true, 2, 2), state, log());
state.update(outcome);
// then
assertEquals(2, state.commitIndex());
}
Aggregations