X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?p=controller.git;a=blobdiff_plain;f=opendaylight%2Fmd-sal%2Fsal-akka-raft%2Fsrc%2Ftest%2Fjava%2Forg%2Fopendaylight%2Fcontroller%2Fcluster%2Fraft%2FAbstractRaftActorIntegrationTest.java;h=ac970c64e479558236fd6e03392d5cd86b074ec6;hp=343febbcfd534afeba21ab76cfcfdeab66cd394b;hb=e9fc7e7ed2b13d274518d6a872ab67749ef4507a;hpb=9d5ec5cdd146a56bc03e35b6718e9492a5c8410a diff --git a/opendaylight/md-sal/sal-akka-raft/src/test/java/org/opendaylight/controller/cluster/raft/AbstractRaftActorIntegrationTest.java b/opendaylight/md-sal/sal-akka-raft/src/test/java/org/opendaylight/controller/cluster/raft/AbstractRaftActorIntegrationTest.java index 343febbcfd..ac970c64e4 100644 --- a/opendaylight/md-sal/sal-akka-raft/src/test/java/org/opendaylight/controller/cluster/raft/AbstractRaftActorIntegrationTest.java +++ b/opendaylight/md-sal/sal-akka-raft/src/test/java/org/opendaylight/controller/cluster/raft/AbstractRaftActorIntegrationTest.java @@ -7,31 +7,45 @@ */ package org.opendaylight.controller.cluster.raft; +import static akka.pattern.Patterns.ask; import static org.junit.Assert.assertEquals; import static org.junit.Assert.assertNotNull; + import akka.actor.ActorRef; import akka.actor.InvalidActorNameException; import akka.actor.PoisonPill; import akka.actor.Terminated; import akka.dispatch.Dispatchers; -import akka.testkit.JavaTestKit; +import akka.dispatch.Mailboxes; import akka.testkit.TestActorRef; +import akka.testkit.javadsl.TestKit; +import akka.util.Timeout; +import com.google.common.base.Stopwatch; import com.google.common.collect.ImmutableMap; import com.google.common.util.concurrent.Uninterruptibles; +import java.io.OutputStream; import java.util.ArrayList; import java.util.Collections; import java.util.List; import java.util.Map; +import java.util.Optional; import java.util.concurrent.ConcurrentHashMap; import java.util.concurrent.TimeUnit; +import java.util.function.Consumer; +import java.util.function.Predicate; +import org.apache.commons.lang3.SerializationUtils; import org.junit.After; +import org.opendaylight.controller.cluster.raft.MockRaftActor.MockSnapshotState; import org.opendaylight.controller.cluster.raft.MockRaftActorContext.MockPayload; -import org.opendaylight.controller.cluster.raft.base.messages.ApplyJournalEntries; import org.opendaylight.controller.cluster.raft.base.messages.ApplyState; import org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshotReply; import org.opendaylight.controller.cluster.raft.base.messages.SendHeartBeat; import org.opendaylight.controller.cluster.raft.behaviors.RaftActorBehavior; +import org.opendaylight.controller.cluster.raft.client.messages.GetOnDemandRaftState; +import org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState; +import org.opendaylight.controller.cluster.raft.persisted.ApplyJournalEntries; import org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload; +import org.opendaylight.controller.cluster.raft.persisted.Snapshot; 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; @@ -40,6 +54,7 @@ import org.opendaylight.yangtools.concepts.Identifier; import org.opendaylight.yangtools.util.AbstractStringIdentifier; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import scala.concurrent.Await; import scala.concurrent.duration.FiniteDuration; /** @@ -52,7 +67,7 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest private static final class MockIdentifier extends AbstractStringIdentifier { private static final long serialVersionUID = 1L; - protected MockIdentifier(String string) { + protected MockIdentifier(final String string) { super(string); } } @@ -61,7 +76,7 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest private final String peerId; private final String peerAddress; - public SetPeerAddress(String peerId, String peerAddress) { + public SetPeerAddress(final String peerId, final String peerAddress) { this.peerId = peerId; this.peerAddress = peerAddress; } @@ -77,19 +92,23 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest public static class TestRaftActor extends MockRaftActor { - private final TestActorRef collectorActor; - private final Map, Boolean> dropMessages = new ConcurrentHashMap<>(); + private final ActorRef collectorActor; + private final Map, Predicate> dropMessages = new ConcurrentHashMap<>(); - private TestRaftActor(Builder builder) { + TestRaftActor(final Builder builder) { super(builder); this.collectorActor = builder.collectorActor; } - public void startDropMessages(Class msgClass) { - dropMessages.put(msgClass, Boolean.TRUE); + public void startDropMessages(final Class msgClass) { + dropMessages.put(msgClass, msg -> true); + } + + void startDropMessages(final Class msgClass, final Predicate filter) { + dropMessages.put(msgClass, filter); } - public void stopDropMessages(Class msgClass) { + public void stopDropMessages(final Class msgClass) { dropMessages.remove(msgClass); } @@ -97,31 +116,33 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest getRaftActorContext().setTotalMemoryRetriever(mockTotalMemory > 0 ? () -> mockTotalMemory : null); } + @SuppressWarnings({ "rawtypes", "unchecked", "checkstyle:IllegalCatch" }) @Override - public void handleCommand(Object message) { - if(message instanceof MockPayload) { - MockPayload payload = (MockPayload)message; - super.persistData(collectorActor, new MockIdentifier(payload.toString()), payload); + public void handleCommand(final Object message) { + if (message instanceof MockPayload) { + MockPayload payload = (MockPayload) message; + super.persistData(collectorActor, new MockIdentifier(payload.toString()), payload, false); return; } - if(message instanceof ServerConfigurationPayload) { - super.persistData(collectorActor, new MockIdentifier("serverConfig"), (Payload)message); + if (message instanceof ServerConfigurationPayload) { + super.persistData(collectorActor, new MockIdentifier("serverConfig"), (Payload) message, false); return; } - if(message instanceof SetPeerAddress) { - setPeerAddress(((SetPeerAddress) message).getPeerId().toString(), + if (message instanceof SetPeerAddress) { + setPeerAddress(((SetPeerAddress) message).getPeerId(), ((SetPeerAddress) message).getPeerAddress()); return; } try { - if(!dropMessages.containsKey(message.getClass())) { + Predicate drop = dropMessages.get(message.getClass()); + if (drop == null || !drop.test(message)) { super.handleCommand(message); } } finally { - if(!(message instanceof SendHeartBeat)) { + if (!(message instanceof SendHeartBeat)) { try { collectorActor.tell(message, ActorRef.noSender()); } catch (Exception e) { @@ -132,12 +153,14 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest } @Override - public void createSnapshot(ActorRef actorRef) { - try { - actorRef.tell(new CaptureSnapshotReply(RaftActorTest.fromObject(getState()).toByteArray()), actorRef); - } catch (Exception e) { - e.printStackTrace(); + @SuppressWarnings("checkstyle:IllegalCatch") + public void createSnapshot(final ActorRef actorRef, final Optional installSnapshotStream) { + MockSnapshotState snapshotState = new MockSnapshotState(new ArrayList<>(getState())); + if (installSnapshotStream.isPresent()) { + SerializationUtils.serialize(snapshotState, installSnapshotStream.get()); } + + actorRef.tell(new CaptureSnapshotReply(snapshotState, installSnapshotStream), actorRef); } public ActorRef collectorActor() { @@ -149,15 +172,15 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest } public static class Builder extends AbstractBuilder { - private TestActorRef collectorActor; + private ActorRef collectorActor; - public Builder collectorActor(TestActorRef collectorActor) { - this.collectorActor = collectorActor; - return this; + Builder() { + super(TestRaftActor.class); } - private Builder() { - super(TestRaftActor.class); + public Builder collectorActor(final ActorRef newCollectorActor) { + this.collectorActor = newCollectorActor; + return this; } } } @@ -193,6 +216,7 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest protected long currentTerm; protected int snapshotBatchCount = 4; + protected int snapshotChunkSize = SNAPSHOT_CHUNK_SIZE; protected List expSnapshotState = new ArrayList<>(); @@ -206,11 +230,11 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest protected DefaultConfigParamsImpl newLeaderConfigParams() { DefaultConfigParamsImpl configParams = new DefaultConfigParamsImpl(); configParams.setHeartBeatInterval(new FiniteDuration(100, TimeUnit.MILLISECONDS)); - configParams.setElectionTimeoutFactor(1); + configParams.setElectionTimeoutFactor(4); configParams.setSnapshotBatchCount(snapshotBatchCount); configParams.setSnapshotDataThresholdPercentage(70); configParams.setIsolatedLeaderCheckInterval(new FiniteDuration(1, TimeUnit.DAYS)); - configParams.setSnapshotChunkSize(SNAPSHOT_CHUNK_SIZE); + configParams.setSnapshotChunkSize(snapshotChunkSize); return configParams; } @@ -221,25 +245,25 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest return configParams; } - protected void waitUntilLeader(ActorRef actorRef) { + protected void waitUntilLeader(final ActorRef actorRef) { RaftActorTestKit.waitUntilLeader(actorRef); } - protected TestActorRef newTestRaftActor(String id, Map peerAddresses, - ConfigParams configParams) { - return newTestRaftActor(id, TestRaftActor.newBuilder().peerAddresses(peerAddresses != null ? peerAddresses : - Collections.emptyMap()).config(configParams)); + protected TestActorRef newTestRaftActor(final String id, final Map newPeerAddresses, + final ConfigParams configParams) { + return newTestRaftActor(id, TestRaftActor.newBuilder().peerAddresses(newPeerAddresses != null + ? newPeerAddresses : Collections.emptyMap()).config(configParams)); } - protected TestActorRef newTestRaftActor(String id, TestRaftActor.Builder builder) { - builder.collectorActor(factory.createTestActor( - MessageCollectorActor.props().withDispatcher(Dispatchers.DefaultDispatcherId()), - factory.generateActorId(id + "-collector"))).id(id); + protected TestActorRef newTestRaftActor(final String id, final TestRaftActor.Builder builder) { + builder.collectorActor(factory.createActor( + MessageCollectorActor.props(), factory.generateActorId(id + "-collector"))).id(id); InvalidActorNameException lastEx = null; - for(int i = 0; i < 10; i++) { + for (int i = 0; i < 10; i++) { try { - return factory.createTestActor(builder.props().withDispatcher(Dispatchers.DefaultDispatcherId()), id); + return factory.createTestActor(builder.props().withDispatcher(Dispatchers.DefaultDispatcherId()) + .withMailbox(Mailboxes.DefaultMailboxId()), id); } catch (InvalidActorNameException e) { lastEx = e; Uninterruptibles.sleepUninterruptibly(100, TimeUnit.MILLISECONDS); @@ -250,65 +274,66 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest throw lastEx; } - protected void killActor(TestActorRef leaderActor) { - JavaTestKit testkit = new JavaTestKit(getSystem()); - testkit.watch(leaderActor); + protected void killActor(final TestActorRef actor) { + TestKit testkit = new TestKit(getSystem()); + testkit.watch(actor); - leaderActor.tell(PoisonPill.getInstance(), null); - testkit.expectMsgClass(JavaTestKit.duration("5 seconds"), Terminated.class); + actor.tell(PoisonPill.getInstance(), null); + testkit.expectMsgClass(testkit.duration("5 seconds"), Terminated.class); - testkit.unwatch(leaderActor); + testkit.unwatch(actor); } - protected void verifyApplyJournalEntries(ActorRef actor, final long expIndex) { - MessageCollectorActor.expectFirstMatching(actor, ApplyJournalEntries.class, msg -> msg.getToIndex() == expIndex); + protected void verifyApplyJournalEntries(final ActorRef actor, final long expIndex) { + MessageCollectorActor.expectFirstMatching(actor, ApplyJournalEntries.class, + msg -> msg.getToIndex() == expIndex); } - @SuppressWarnings("unchecked") - protected void verifySnapshot(String prefix, Snapshot snapshot, long lastAppliedTerm, - long lastAppliedIndex, long lastTerm, long lastIndex) + protected void verifySnapshot(final String prefix, final Snapshot snapshot, final long lastAppliedTerm, + final long lastAppliedIndex, final long lastTerm, final long lastIndex) throws Exception { assertEquals(prefix + " Snapshot getLastAppliedTerm", lastAppliedTerm, snapshot.getLastAppliedTerm()); assertEquals(prefix + " Snapshot getLastAppliedIndex", lastAppliedIndex, snapshot.getLastAppliedIndex()); assertEquals(prefix + " Snapshot getLastTerm", lastTerm, snapshot.getLastTerm()); assertEquals(prefix + " Snapshot getLastIndex", lastIndex, snapshot.getLastIndex()); - List actualState = (List)MockRaftActor.toObject(snapshot.getState()); + List actualState = ((MockSnapshotState)snapshot.getState()).getState(); assertEquals(String.format("%s Snapshot getState size. Expected %s: . Actual: %s", prefix, expSnapshotState, actualState), expSnapshotState.size(), actualState.size()); - for(int i = 0; i < expSnapshotState.size(); i++) { + for (int i = 0; i < expSnapshotState.size(); i++) { assertEquals(prefix + " Snapshot state " + i, expSnapshotState.get(i), actualState.get(i)); } } - protected void verifyPersistedJournal(String persistenceId, List expJournal) { + protected void verifyPersistedJournal(final String persistenceId, + final List expJournal) { List journal = InMemoryJournal.get(persistenceId, ReplicatedLogEntry.class); assertEquals("Journal ReplicatedLogEntry count", expJournal.size(), journal.size()); - for(int i = 0; i < expJournal.size(); i++) { + for (int i = 0; i < expJournal.size(); i++) { ReplicatedLogEntry expected = expJournal.get(i); ReplicatedLogEntry actual = journal.get(i); verifyReplicatedLogEntry(expected, actual.getTerm(), actual.getIndex(), actual.getData()); } } - protected MockPayload sendPayloadData(ActorRef leaderActor, String data) { - return sendPayloadData(leaderActor, data, 0); + protected MockPayload sendPayloadData(final ActorRef actor, final String data) { + return sendPayloadData(actor, data, 0); } - protected MockPayload sendPayloadData(ActorRef leaderActor, String data, int size) { + protected MockPayload sendPayloadData(final ActorRef actor, final String data, final int size) { MockPayload payload; - if(size > 0) { + if (size > 0) { payload = new MockPayload(data, size); } else { payload = new MockPayload(data); } - leaderActor.tell(payload, ActorRef.noSender()); + actor.tell(payload, ActorRef.noSender()); return payload; } - protected void verifyApplyState(ApplyState applyState, ActorRef expClientActor, - String expId, long expTerm, long expIndex, Payload payload) { + protected void verifyApplyState(final ApplyState applyState, final ActorRef expClientActor, + final String expId, final long expTerm, final long expIndex, final Payload payload) { assertEquals("ApplyState getClientActor", expClientActor, applyState.getClientActor()); final Identifier id = expId == null ? null : new MockIdentifier(expId); @@ -317,31 +342,32 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest verifyReplicatedLogEntry(replicatedLogEntry, expTerm, expIndex, payload); } - protected void verifyReplicatedLogEntry(ReplicatedLogEntry replicatedLogEntry, long expTerm, long expIndex, - Payload payload) { + protected void verifyReplicatedLogEntry(final ReplicatedLogEntry replicatedLogEntry, final long expTerm, + final long expIndex, final Payload payload) { assertEquals("ReplicatedLogEntry getTerm", expTerm, replicatedLogEntry.getTerm()); assertEquals("ReplicatedLogEntry getIndex", expIndex, replicatedLogEntry.getIndex()); assertEquals("ReplicatedLogEntry getData", payload, replicatedLogEntry.getData()); } - protected String testActorPath(String id){ + protected String testActorPath(final String id) { return factory.createTestActorPath(id); } - protected void verifyLeadersTrimmedLog(long lastIndex) { + protected void verifyLeadersTrimmedLog(final long lastIndex) { verifyTrimmedLog("Leader", leaderActor, lastIndex, lastIndex - 1); } - protected void verifyLeadersTrimmedLog(long lastIndex, long replicatedToAllIndex) { + protected void verifyLeadersTrimmedLog(final long lastIndex, final long replicatedToAllIndex) { verifyTrimmedLog("Leader", leaderActor, lastIndex, replicatedToAllIndex); } - protected void verifyFollowersTrimmedLog(int num, TestActorRef actorRef, long lastIndex) { + protected void verifyFollowersTrimmedLog(final int num, final TestActorRef actorRef, + final long lastIndex) { verifyTrimmedLog("Follower " + num, actorRef, lastIndex, lastIndex - 1); } - protected void verifyTrimmedLog(String name, TestActorRef actorRef, long lastIndex, - long replicatedToAllIndex) { + protected void verifyTrimmedLog(final String name, final TestActorRef actorRef, final long lastIndex, + final long replicatedToAllIndex) { TestRaftActor actor = actorRef.underlyingActor(); RaftActorContext context = actor.getRaftActorContext(); long snapshotIndex = lastIndex - 1; @@ -355,4 +381,27 @@ public abstract class AbstractRaftActorIntegrationTest extends AbstractActorTest assertEquals(name + " replicatedToAllIndex", replicatedToAllIndex, actor.getCurrentBehavior().getReplicatedToAllIndex()); } + + @SuppressWarnings("checkstyle:IllegalCatch") + static void verifyRaftState(final ActorRef raftActor, final Consumer verifier) { + Timeout timeout = new Timeout(500, TimeUnit.MILLISECONDS); + AssertionError lastError = null; + Stopwatch sw = Stopwatch.createStarted(); + while (sw.elapsed(TimeUnit.SECONDS) <= 5) { + try { + OnDemandRaftState raftState = (OnDemandRaftState)Await.result(ask(raftActor, + GetOnDemandRaftState.INSTANCE, timeout), timeout.duration()); + verifier.accept(raftState); + return; + } catch (AssertionError e) { + lastError = e; + Uninterruptibles.sleepUninterruptibly(50, TimeUnit.MILLISECONDS); + } catch (Exception e) { + lastError = new AssertionError("OnDemandRaftState failed", e); + Uninterruptibles.sleepUninterruptibly(50, TimeUnit.MILLISECONDS); + } + } + + throw lastError; + } }