X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?a=blobdiff_plain;ds=sidebyside;f=opendaylight%2Fmd-sal%2Fsal-akka-raft%2Fsrc%2Ftest%2Fjava%2Forg%2Fopendaylight%2Fcontroller%2Fcluster%2Fraft%2Fbehaviors%2FAbstractRaftActorBehaviorTest.java;h=3dba8d240fe1f4eb7f0d12967a1ce817455eae1f;hb=283929615619b09a664fd46bd13e19cdb163ec4d;hp=b5be834fec064d21d0c40a10000c413c9fd64f60;hpb=f276ae33b951d173b51c467bb7bb1a5f5cf9a1e6;p=controller.git diff --git a/opendaylight/md-sal/sal-akka-raft/src/test/java/org/opendaylight/controller/cluster/raft/behaviors/AbstractRaftActorBehaviorTest.java b/opendaylight/md-sal/sal-akka-raft/src/test/java/org/opendaylight/controller/cluster/raft/behaviors/AbstractRaftActorBehaviorTest.java index b5be834fec..3dba8d240f 100644 --- a/opendaylight/md-sal/sal-akka-raft/src/test/java/org/opendaylight/controller/cluster/raft/behaviors/AbstractRaftActorBehaviorTest.java +++ b/opendaylight/md-sal/sal-akka-raft/src/test/java/org/opendaylight/controller/cluster/raft/behaviors/AbstractRaftActorBehaviorTest.java @@ -11,6 +11,7 @@ package org.opendaylight.controller.cluster.raft.behaviors; import static org.junit.Assert.assertEquals; import static org.junit.Assert.assertFalse; import static org.junit.Assert.assertNull; + import akka.actor.ActorRef; import akka.actor.Props; import akka.testkit.TestActorRef; @@ -29,15 +30,17 @@ import org.opendaylight.controller.cluster.raft.MockRaftActorContext; import org.opendaylight.controller.cluster.raft.RaftActorContext; import org.opendaylight.controller.cluster.raft.RaftState; import org.opendaylight.controller.cluster.raft.ReplicatedLogEntry; -import org.opendaylight.controller.cluster.raft.SerializationUtils; import org.opendaylight.controller.cluster.raft.TestActorFactory; import org.opendaylight.controller.cluster.raft.messages.AppendEntries; import org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply; import org.opendaylight.controller.cluster.raft.messages.RaftRPC; import org.opendaylight.controller.cluster.raft.messages.RequestVote; import org.opendaylight.controller.cluster.raft.messages.RequestVoteReply; +import org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry; import org.opendaylight.controller.cluster.raft.policy.RaftPolicy; import org.opendaylight.controller.cluster.raft.protobuff.client.messages.Payload; +import org.opendaylight.controller.cluster.raft.utils.InMemoryJournal; +import org.opendaylight.controller.cluster.raft.utils.InMemorySnapshotStore; import org.opendaylight.controller.cluster.raft.utils.MessageCollectorActor; import org.slf4j.LoggerFactory; @@ -52,18 +55,19 @@ public abstract class AbstractRaftActorBehaviorTest @After public void tearDown() throws Exception { - if(behavior != null) { + if (behavior != null) { behavior.close(); } actorFactory.close(); + + InMemoryJournal.clear(); + InMemorySnapshotStore.clear(); } /** * This test checks that when a new Raft RPC message is received with a newer * term the RaftActor gets into the Follower state. - * - * @throws Exception */ @Test public void testHandleRaftRPCWithNewerTerm() throws Exception { @@ -86,9 +90,7 @@ public abstract class AbstractRaftActorBehaviorTest /** * This test verifies that when an AppendEntries is received with a term that * is less that the currentTerm of the RaftActor then the RaftActor does not - * change it's state and it responds back with a failure - * - * @throws Exception + * change it's state and it responds back with a failure. */ @Test public void testHandleAppendEntriesSenderTermLessThanReceiverTerm() throws Exception { @@ -130,9 +132,9 @@ public abstract class AbstractRaftActorBehaviorTest setLastLogEntry(context, 2, 0, payload); List entries = new ArrayList<>(); - entries.add(new MockRaftActorContext.MockReplicatedLogEntry(2, 0, payload)); + entries.add(new SimpleReplicatedLogEntry(0, 2, payload)); - AppendEntries appendEntries = new AppendEntries(2, "leader-1", -1, -1, entries, 2, -1, (short)0); + final AppendEntries appendEntries = new AppendEntries(2, "leader-1", -1, -1, entries, 2, -1, (short)0); behavior = createBehavior(context); @@ -182,7 +184,7 @@ public abstract class AbstractRaftActorBehaviorTest /** * This test verifies that when a RaftActor receives a RequestVote message * with a term that is greater than it's currentTerm but a less up-to-date - * log then the receiving RaftActor will not grant the vote to the sender + * log then the receiving RaftActor will not grant the vote to the sender. */ @Test public void testHandleRequestVoteWhenSenderLogLessUptoDate() { @@ -210,7 +212,7 @@ public abstract class AbstractRaftActorBehaviorTest /** * This test verifies that the receiving RaftActor will not grant a vote * to a sender if the sender's term is lesser than the currentTerm of the - * recipient RaftActor + * recipient RaftActor. */ @Test public void testHandleRequestVoteWhenSenderTermLessThanCurrentTerm() { @@ -258,7 +260,8 @@ public abstract class AbstractRaftActorBehaviorTest assertEquals(0, abstractBehavior.getReplicatedToAllIndex()); assertEquals(1, context.getReplicatedLog().size()); - //5 entries, lastApplied =2 and replicatedIndex = 3, but since we want to keep the lastapplied, indices 0 and 1 will only get purged + // 5 entries, lastApplied =2 and replicatedIndex = 3, but since we want to keep the lastapplied, indices 0 and + // 1 will only get purged context.setReplicatedLog(new MockRaftActorContext.MockReplicatedLogBuilder().createEntries(0, 5, 1).build()); context.setLastApplied(2); abstractBehavior.performSnapshotWithoutCapture(3); @@ -277,8 +280,8 @@ public abstract class AbstractRaftActorBehaviorTest protected void assertStateChangesToFollowerWhenRaftRPCHasNewerTerm(MockRaftActorContext actorContext, ActorRef actorRef, RaftRPC rpc) throws Exception { - Payload p = new MockRaftActorContext.MockPayload(""); - setLastLogEntry(actorContext, 1, 0, p); + Payload payload = new MockRaftActorContext.MockPayload(""); + setLastLogEntry(actorContext, 1, 0, payload); actorContext.getTermInformation().update(1, "test"); RaftActorBehavior origBehavior = createBehavior(actorContext); @@ -293,8 +296,7 @@ public abstract class AbstractRaftActorBehaviorTest protected MockRaftActorContext.SimpleReplicatedLog setLastLogEntry( MockRaftActorContext actorContext, long term, long index, Payload data) { - return setLastLogEntry(actorContext, - new MockRaftActorContext.MockReplicatedLogEntry(term, index, data)); + return setLastLogEntry(actorContext, new SimpleReplicatedLogEntry(index, term, data)); } protected MockRaftActorContext.SimpleReplicatedLog setLastLogEntry(MockRaftActorContext actorContext, @@ -342,13 +344,9 @@ public abstract class AbstractRaftActorBehaviorTest return new RequestVoteReply(100, false); } - protected Object fromSerializableMessage(Object serializable){ - return SerializationUtils.fromSerializable(serializable); - } - protected ByteString toByteString(Map state) { ByteArrayOutputStream bos = new ByteArrayOutputStream(); - try(ObjectOutputStream oos = new ObjectOutputStream(bos)) { + try (ObjectOutputStream oos = new ObjectOutputStream(bos)) { oos.writeObject(state); return ByteString.copyFrom(bos.toByteArray()); } catch (IOException e) { @@ -357,11 +355,11 @@ public abstract class AbstractRaftActorBehaviorTest } protected void logStart(String name) { - LoggerFactory.getLogger(LeaderTest.class).info("Starting " + name); + LoggerFactory.getLogger(getClass()).info("Starting " + name); } protected RaftPolicy createRaftPolicy(final boolean automaticElectionsEnabled, - final boolean applyModificationToStateBeforeConsensus){ + final boolean applyModificationToStateBeforeConsensus) { return new RaftPolicy() { @Override public boolean automaticElectionsEnabled() {