X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?p=controller.git;a=blobdiff_plain;f=opendaylight%2Fmd-sal%2Fsal-distributed-datastore%2Fsrc%2Ftest%2Fjava%2Forg%2Fopendaylight%2Fcontroller%2Fcluster%2Fdatastore%2FShardTest.java;h=7d4c054b3e9a4e86728feb9e5936ae9550cee888;hp=28330185872b3231be213b6115696a75ddc7b64f;hb=2fd1fa721510a30f58b3bc277deb05fce58badd6;hpb=5aa58404a8ee1ad053742780439823309360a3a1 diff --git a/opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/ShardTest.java b/opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/ShardTest.java index 2833018587..7d4c054b3e 100644 --- a/opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/ShardTest.java +++ b/opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/ShardTest.java @@ -5,24 +5,22 @@ * terms of the Eclipse Public License v1.0 which accompanies this distribution, * and is available at http://www.eclipse.org/legal/epl-v10.html */ - package org.opendaylight.controller.cluster.datastore; import static org.junit.Assert.assertEquals; import static org.junit.Assert.assertFalse; import static org.junit.Assert.assertNotNull; -import static org.junit.Assert.assertNull; import static org.junit.Assert.assertSame; import static org.junit.Assert.assertTrue; -import static org.mockito.Mockito.doReturn; +import static org.junit.Assert.fail; +import static org.mockito.ArgumentMatchers.any; +import static org.mockito.Mockito.doThrow; import static org.mockito.Mockito.inOrder; import static org.mockito.Mockito.mock; -import static org.mockito.Mockito.reset; -import static org.mockito.Mockito.verify; import static org.opendaylight.controller.cluster.datastore.DataStoreVersions.CURRENT_VERSION; + import akka.actor.ActorRef; import akka.actor.ActorSelection; -import akka.actor.PoisonPill; import akka.actor.Props; import akka.actor.Status.Failure; import akka.dispatch.Dispatchers; @@ -32,15 +30,14 @@ import akka.pattern.Patterns; import akka.persistence.SaveSnapshotSuccess; import akka.testkit.TestActorRef; import akka.util.Timeout; -import com.google.common.base.Function; -import com.google.common.base.Optional; -import com.google.common.util.concurrent.Futures; -import com.google.common.util.concurrent.ListenableFuture; +import com.google.common.base.Stopwatch; +import com.google.common.base.Throwables; import com.google.common.util.concurrent.Uninterruptibles; -import java.io.IOException; +import java.time.Duration; import java.util.Collections; import java.util.HashSet; import java.util.Map; +import java.util.Optional; import java.util.Set; import java.util.concurrent.CountDownLatch; import java.util.concurrent.TimeUnit; @@ -50,6 +47,10 @@ import org.junit.Test; import org.mockito.InOrder; import org.opendaylight.controller.cluster.DataPersistenceProvider; import org.opendaylight.controller.cluster.DelegatingPersistentDataProvider; +import org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier; +import org.opendaylight.controller.cluster.access.concepts.MemberName; +import org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier; +import org.opendaylight.controller.cluster.datastore.exceptions.NoShardLeaderException; import org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier; import org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats; import org.opendaylight.controller.cluster.datastore.messages.AbortTransaction; @@ -58,508 +59,287 @@ import org.opendaylight.controller.cluster.datastore.messages.BatchedModificatio import org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply; import org.opendaylight.controller.cluster.datastore.messages.CanCommitTransaction; import org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply; +import org.opendaylight.controller.cluster.datastore.messages.CloseDataTreeNotificationListenerRegistration; +import org.opendaylight.controller.cluster.datastore.messages.CloseDataTreeNotificationListenerRegistrationReply; import org.opendaylight.controller.cluster.datastore.messages.CommitTransaction; import org.opendaylight.controller.cluster.datastore.messages.CommitTransactionReply; import org.opendaylight.controller.cluster.datastore.messages.CreateTransaction; -import org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction; +import org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply; import org.opendaylight.controller.cluster.datastore.messages.PeerAddressResolved; import org.opendaylight.controller.cluster.datastore.messages.ReadData; import org.opendaylight.controller.cluster.datastore.messages.ReadDataReply; import org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction; import org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply; -import org.opendaylight.controller.cluster.datastore.messages.RegisterChangeListener; -import org.opendaylight.controller.cluster.datastore.messages.RegisterChangeListenerReply; import org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener; -import org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListenerReply; +import org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeNotificationListenerReply; import org.opendaylight.controller.cluster.datastore.messages.ShardLeaderStateChanged; import org.opendaylight.controller.cluster.datastore.messages.UpdateSchemaContext; -import org.opendaylight.controller.cluster.datastore.modification.DeleteModification; import org.opendaylight.controller.cluster.datastore.modification.MergeModification; -import org.opendaylight.controller.cluster.datastore.modification.Modification; -import org.opendaylight.controller.cluster.datastore.modification.ModificationPayload; -import org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification; import org.opendaylight.controller.cluster.datastore.modification.WriteModification; -import org.opendaylight.controller.cluster.datastore.utils.MockDataChangeListener; +import org.opendaylight.controller.cluster.datastore.persisted.MetadataShardDataTreeSnapshot; +import org.opendaylight.controller.cluster.datastore.persisted.ShardSnapshotState; import org.opendaylight.controller.cluster.datastore.utils.MockDataTreeChangeListener; -import org.opendaylight.controller.cluster.datastore.utils.SerializationUtils; import org.opendaylight.controller.cluster.notifications.RegisterRoleChangeListener; import org.opendaylight.controller.cluster.notifications.RegisterRoleChangeListenerReply; import org.opendaylight.controller.cluster.raft.RaftActorContext; import org.opendaylight.controller.cluster.raft.ReplicatedLogEntry; -import org.opendaylight.controller.cluster.raft.ReplicatedLogImplEntry; -import org.opendaylight.controller.cluster.raft.Snapshot; -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.ApplySnapshot; import org.opendaylight.controller.cluster.raft.base.messages.ElectionTimeout; import org.opendaylight.controller.cluster.raft.base.messages.FollowerInitialSyncUpStatus; +import org.opendaylight.controller.cluster.raft.base.messages.TimeoutNow; import org.opendaylight.controller.cluster.raft.client.messages.FindLeader; import org.opendaylight.controller.cluster.raft.client.messages.FindLeaderReply; +import org.opendaylight.controller.cluster.raft.client.messages.GetOnDemandRaftState; +import org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState; import org.opendaylight.controller.cluster.raft.messages.RequestVote; +import org.opendaylight.controller.cluster.raft.messages.ServerRemoved; +import org.opendaylight.controller.cluster.raft.persisted.ApplyJournalEntries; +import org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry; +import org.opendaylight.controller.cluster.raft.persisted.Snapshot; +import org.opendaylight.controller.cluster.raft.policy.DisableElectionsRaftPolicy; +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.opendaylight.controller.md.cluster.datastore.model.SchemaContextHelper; import org.opendaylight.controller.md.cluster.datastore.model.TestModel; -import org.opendaylight.controller.md.sal.common.api.data.AsyncDataBroker; -import org.opendaylight.controller.md.sal.common.api.data.ReadFailedException; -import org.opendaylight.controller.protobuff.messages.cohort3pc.ThreePhaseCommitCohortMessages; -import org.opendaylight.controller.protobuff.messages.transaction.ShardTransactionMessages.CreateTransactionReply; -import org.opendaylight.yangtools.yang.common.QName; +import org.opendaylight.yangtools.concepts.Identifier; import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier; -import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.PathArgument; import org.opendaylight.yangtools.yang.data.api.schema.ContainerNode; -import org.opendaylight.yangtools.yang.data.api.schema.DataContainerChild; -import org.opendaylight.yangtools.yang.data.api.schema.MapEntryNode; import org.opendaylight.yangtools.yang.data.api.schema.MapNode; import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode; import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTree; import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTreeCandidate; -import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTreeCandidateNode; -import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTreeCandidateTip; -import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTreeCandidates; +import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTreeConfiguration; import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTreeModification; import org.opendaylight.yangtools.yang.data.api.schema.tree.DataValidationFailedException; -import org.opendaylight.yangtools.yang.data.api.schema.tree.ModificationType; import org.opendaylight.yangtools.yang.data.impl.schema.ImmutableNodes; import org.opendaylight.yangtools.yang.data.impl.schema.builder.impl.ImmutableContainerNodeBuilder; import org.opendaylight.yangtools.yang.data.impl.schema.tree.InMemoryDataTreeFactory; -import org.opendaylight.yangtools.yang.model.api.SchemaContext; import scala.concurrent.Await; import scala.concurrent.Future; import scala.concurrent.duration.FiniteDuration; public class ShardTest extends AbstractShardTest { - private static final QName CARS_QNAME = QName.create("urn:opendaylight:params:xml:ns:yang:controller:md:sal:dom:store:test:cars", "2014-03-13", "cars"); - - private static final String DUMMY_DATA = "Dummy data as snapshot sequence number is set to 0 in InMemorySnapshotStore and journal recovery seq number will start from 1"; - - @Test - public void testRegisterChangeListener() throws Exception { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps(), "testRegisterChangeListener"); - - waitUntilLeader(shard); - - shard.tell(new UpdateSchemaContext(SchemaContextHelper.full()), ActorRef.noSender()); - - final MockDataChangeListener listener = new MockDataChangeListener(1); - final ActorRef dclActor = getSystem().actorOf(DataChangeListener.props(listener), - "testRegisterChangeListener-DataChangeListener"); - - shard.tell(new RegisterChangeListener(TestModel.TEST_PATH, - dclActor, AsyncDataBroker.DataChangeScope.BASE, true), getRef()); - - final RegisterChangeListenerReply reply = expectMsgClass(duration("3 seconds"), - RegisterChangeListenerReply.class); - final String replyPath = reply.getListenerRegistrationPath().toString(); - assertTrue("Incorrect reply path: " + replyPath, replyPath.matches( - "akka:\\/\\/test\\/user\\/testRegisterChangeListener\\/\\$.*")); - - final YangInstanceIdentifier path = TestModel.TEST_PATH; - writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); - - listener.waitForChangeEvents(path); - - dclActor.tell(PoisonPill.getInstance(), ActorRef.noSender()); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; - } - - @SuppressWarnings("serial") - @Test - public void testChangeListenerNotifiedWhenNotTheLeaderOnRegistration() throws Exception { - // This test tests the timing window in which a change listener is registered before the - // shard becomes the leader. We verify that the listener is registered and notified of the - // existing data when the shard becomes the leader. - new ShardTestKit(getSystem()) {{ - // For this test, we want to send the RegisterChangeListener message after the shard - // has recovered from persistence and before it becomes the leader. So we subclass - // Shard to override onReceiveCommand and, when the first ElectionTimeout is received, - // we know that the shard has been initialized to a follower and has started the - // election process. The following 2 CountDownLatches are used to coordinate the - // ElectionTimeout with the sending of the RegisterChangeListener message. - final CountDownLatch onFirstElectionTimeout = new CountDownLatch(1); - final CountDownLatch onChangeListenerRegistered = new CountDownLatch(1); - final Creator creator = new Creator() { - boolean firstElectionTimeout = true; - - @Override - public Shard create() throws Exception { - // Use a non persistent provider because this test actually invokes persist on the journal - // this will cause all other messages to not be queued properly after that. - // The basic issue is that you cannot use TestActorRef with a persistent actor (at least when - // it does do a persist) - return new Shard(shardID, Collections.emptyMap(), - dataStoreContextBuilder.persistent(false).build(), SCHEMA_CONTEXT) { - @Override - public void onReceiveCommand(final Object message) throws Exception { - if(message instanceof ElectionTimeout && firstElectionTimeout) { - // Got the first ElectionTimeout. We don't forward it to the - // base Shard yet until we've sent the RegisterChangeListener - // message. So we signal the onFirstElectionTimeout latch to tell - // the main thread to send the RegisterChangeListener message and - // start a thread to wait on the onChangeListenerRegistered latch, - // which the main thread signals after it has sent the message. - // After the onChangeListenerRegistered is triggered, we send the - // original ElectionTimeout message to proceed with the election. - firstElectionTimeout = false; - final ActorRef self = getSelf(); - new Thread() { - @Override - public void run() { - Uninterruptibles.awaitUninterruptibly( - onChangeListenerRegistered, 5, TimeUnit.SECONDS); - self.tell(message, self); - } - }.start(); - - onFirstElectionTimeout.countDown(); - } else { - super.onReceiveCommand(message); - } - } - }; - } - }; - - final MockDataChangeListener listener = new MockDataChangeListener(1); - final ActorRef dclActor = getSystem().actorOf(DataChangeListener.props(listener), - "testRegisterChangeListenerWhenNotLeaderInitially-DataChangeListener"); - - final TestActorRef shard = TestActorRef.create(getSystem(), - Props.create(new DelegatingShardCreator(creator)).withDispatcher(Dispatchers.DefaultDispatcherId()), - "testRegisterChangeListenerWhenNotLeaderInitially"); - - // Write initial data into the in-memory store. - final YangInstanceIdentifier path = TestModel.TEST_PATH; - writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); - - // Wait until the shard receives the first ElectionTimeout message. - assertEquals("Got first ElectionTimeout", true, - onFirstElectionTimeout.await(5, TimeUnit.SECONDS)); - - // Now send the RegisterChangeListener and wait for the reply. - shard.tell(new RegisterChangeListener(path, dclActor, - AsyncDataBroker.DataChangeScope.SUBTREE, false), getRef()); - - final RegisterChangeListenerReply reply = expectMsgClass(duration("5 seconds"), - RegisterChangeListenerReply.class); - assertNotNull("getListenerRegistrationPath", reply.getListenerRegistrationPath()); - - // Sanity check - verify the shard is not the leader yet. - shard.tell(new FindLeader(), getRef()); - final FindLeaderReply findLeadeReply = - expectMsgClass(duration("5 seconds"), FindLeaderReply.class); - assertNull("Expected the shard not to be the leader", findLeadeReply.getLeaderActor()); - - // Signal the onChangeListenerRegistered latch to tell the thread above to proceed - // with the election process. - onChangeListenerRegistered.countDown(); - - // Wait for the shard to become the leader and notify our listener with the existing - // data in the store. - listener.waitForChangeEvents(path); - - dclActor.tell(PoisonPill.getInstance(), ActorRef.noSender()); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; - } + private static final String DUMMY_DATA = "Dummy data as snapshot sequence number is set to 0 in " + + "InMemorySnapshotStore and journal recovery seq number will start from 1"; @Test public void testRegisterDataTreeChangeListener() throws Exception { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps(), "testRegisterDataTreeChangeListener"); + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testRegisterDataTreeChangeListener"); - waitUntilLeader(shard); + ShardTestKit.waitUntilLeader(shard); - shard.tell(new UpdateSchemaContext(SchemaContextHelper.full()), ActorRef.noSender()); + shard.tell(new UpdateSchemaContext(SchemaContextHelper.full()), ActorRef.noSender()); - final MockDataTreeChangeListener listener = new MockDataTreeChangeListener(1); - final ActorRef dclActor = getSystem().actorOf(DataTreeChangeListenerActor.props(listener), - "testRegisterDataTreeChangeListener-DataTreeChangeListener"); + final MockDataTreeChangeListener listener = new MockDataTreeChangeListener(1); + final ActorRef dclActor = actorFactory.createActor(DataTreeChangeListenerActor.props(listener, + TestModel.TEST_PATH), "testRegisterDataTreeChangeListener-DataTreeChangeListener"); - shard.tell(new RegisterDataTreeChangeListener(TestModel.TEST_PATH, dclActor), getRef()); + shard.tell(new RegisterDataTreeChangeListener(TestModel.TEST_PATH, dclActor, false), testKit.getRef()); - final RegisterDataTreeChangeListenerReply reply = expectMsgClass(duration("3 seconds"), - RegisterDataTreeChangeListenerReply.class); - final String replyPath = reply.getListenerRegistrationPath().toString(); - assertTrue("Incorrect reply path: " + replyPath, replyPath.matches( - "akka:\\/\\/test\\/user\\/testRegisterDataTreeChangeListener\\/\\$.*")); + final RegisterDataTreeNotificationListenerReply reply = testKit.expectMsgClass(Duration.ofSeconds(3), + RegisterDataTreeNotificationListenerReply.class); + final String replyPath = reply.getListenerRegistrationPath().toString(); + assertTrue("Incorrect reply path: " + replyPath, + replyPath.matches("akka:\\/\\/test\\/user\\/testRegisterDataTreeChangeListener\\/\\$.*")); - final YangInstanceIdentifier path = TestModel.TEST_PATH; - writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); + final YangInstanceIdentifier path = TestModel.TEST_PATH; + writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); - listener.waitForChangeEvents(); - - dclActor.tell(PoisonPill.getInstance(), ActorRef.noSender()); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + listener.waitForChangeEvents(); } @SuppressWarnings("serial") @Test public void testDataTreeChangeListenerNotifiedWhenNotTheLeaderOnRegistration() throws Exception { - new ShardTestKit(getSystem()) {{ - final CountDownLatch onFirstElectionTimeout = new CountDownLatch(1); - final CountDownLatch onChangeListenerRegistered = new CountDownLatch(1); - final Creator creator = new Creator() { - boolean firstElectionTimeout = true; - - @Override - public Shard create() throws Exception { - return new Shard(shardID, Collections.emptyMap(), - dataStoreContextBuilder.persistent(false).build(), SCHEMA_CONTEXT) { - @Override - public void onReceiveCommand(final Object message) throws Exception { - if(message instanceof ElectionTimeout && firstElectionTimeout) { - firstElectionTimeout = false; - final ActorRef self = getSelf(); - new Thread() { - @Override - public void run() { - Uninterruptibles.awaitUninterruptibly( - onChangeListenerRegistered, 5, TimeUnit.SECONDS); - self.tell(message, self); - } - }.start(); - - onFirstElectionTimeout.countDown(); - } else { - super.onReceiveCommand(message); - } - } - }; - } - }; + final CountDownLatch onFirstElectionTimeout = new CountDownLatch(1); + final CountDownLatch onChangeListenerRegistered = new CountDownLatch(1); + final Creator creator = new Creator() { + boolean firstElectionTimeout = true; - final MockDataTreeChangeListener listener = new MockDataTreeChangeListener(1); - final ActorRef dclActor = getSystem().actorOf(DataTreeChangeListenerActor.props(listener), - "testDataTreeChangeListenerNotifiedWhenNotTheLeaderOnRegistration-DataChangeListener"); - - final TestActorRef shard = TestActorRef.create(getSystem(), - Props.create(new DelegatingShardCreator(creator)).withDispatcher(Dispatchers.DefaultDispatcherId()), - "testDataTreeChangeListenerNotifiedWhenNotTheLeaderOnRegistration"); + @Override + public Shard create() { + return new Shard(newShardBuilder()) { + @Override + public void handleCommand(final Object message) { + if (message instanceof ElectionTimeout && firstElectionTimeout) { + firstElectionTimeout = false; + final ActorRef self = getSelf(); + new Thread(() -> { + Uninterruptibles.awaitUninterruptibly( + onChangeListenerRegistered, 5, TimeUnit.SECONDS); + self.tell(message, self); + }).start(); + + onFirstElectionTimeout.countDown(); + } else { + super.handleCommand(message); + } + } + }; + } + }; - final YangInstanceIdentifier path = TestModel.TEST_PATH; - writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); + setupInMemorySnapshotStore(); - assertEquals("Got first ElectionTimeout", true, - onFirstElectionTimeout.await(5, TimeUnit.SECONDS)); + final YangInstanceIdentifier path = TestModel.TEST_PATH; + final MockDataTreeChangeListener listener = new MockDataTreeChangeListener(1); + final ActorRef dclActor = actorFactory.createActor(DataTreeChangeListenerActor.props(listener, path), + "testDataTreeChangeListenerNotifiedWhenNotTheLeaderOnRegistration-DataChangeListener"); - shard.tell(new RegisterDataTreeChangeListener(path, dclActor), getRef()); - final RegisterDataTreeChangeListenerReply reply = expectMsgClass(duration("5 seconds"), - RegisterDataTreeChangeListenerReply.class); - assertNotNull("getListenerRegistratioznPath", reply.getListenerRegistrationPath()); + final TestActorRef shard = actorFactory.createTestActor( + Props.create(new DelegatingShardCreator(creator)).withDispatcher(Dispatchers.DefaultDispatcherId()), + "testDataTreeChangeListenerNotifiedWhenNotTheLeaderOnRegistration"); - shard.tell(new FindLeader(), getRef()); - final FindLeaderReply findLeadeReply = - expectMsgClass(duration("5 seconds"), FindLeaderReply.class); - assertNull("Expected the shard not to be the leader", findLeadeReply.getLeaderActor()); + final ShardTestKit testKit = new ShardTestKit(getSystem()); + assertTrue("Got first ElectionTimeout", onFirstElectionTimeout.await(5, TimeUnit.SECONDS)); - writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); + shard.tell(new RegisterDataTreeChangeListener(path, dclActor, false), testKit.getRef()); + final RegisterDataTreeNotificationListenerReply reply = testKit.expectMsgClass(Duration.ofSeconds(5), + RegisterDataTreeNotificationListenerReply.class); + assertNotNull("getListenerRegistratioznPath", reply.getListenerRegistrationPath()); - onChangeListenerRegistered.countDown(); + shard.tell(FindLeader.INSTANCE, testKit.getRef()); + final FindLeaderReply findLeadeReply = testKit.expectMsgClass(Duration.ofSeconds(5), FindLeaderReply.class); + assertFalse("Expected the shard not to be the leader", findLeadeReply.getLeaderActor().isPresent()); - // TODO: investigate why we do not receive data chage events - listener.waitForChangeEvents(); + onChangeListenerRegistered.countDown(); - dclActor.tell(PoisonPill.getInstance(), ActorRef.noSender()); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + // TODO: investigate why we do not receive data chage events + listener.waitForChangeEvents(); } @Test - public void testCreateTransaction(){ - new ShardTestKit(getSystem()) {{ - final ActorRef shard = getSystem().actorOf(newShardProps(), "testCreateTransaction"); - - waitUntilLeader(shard); + public void testCreateTransaction() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final ActorRef shard = actorFactory.createActor(newShardProps(), "testCreateTransaction"); - shard.tell(new UpdateSchemaContext(TestModel.createTestContext()), getRef()); + ShardTestKit.waitUntilLeader(shard); - shard.tell(new CreateTransaction("txn-1", - TransactionType.READ_ONLY.ordinal() ).toSerializable(), getRef()); + shard.tell(new UpdateSchemaContext(TestModel.createTestContext()), testKit.getRef()); - final CreateTransactionReply reply = expectMsgClass(duration("3 seconds"), - CreateTransactionReply.class); + shard.tell(new CreateTransaction(nextTransactionId(), TransactionType.READ_ONLY.ordinal(), + DataStoreVersions.CURRENT_VERSION).toSerializable(), testKit.getRef()); - final String path = reply.getTransactionActorPath().toString(); - assertTrue("Unexpected transaction path " + path, - path.contains("akka://test/user/testCreateTransaction/shard-txn-1")); + final CreateTransactionReply reply = testKit.expectMsgClass(Duration.ofSeconds(3), + CreateTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + final String path = reply.getTransactionPath().toString(); + assertTrue("Unexpected transaction path " + path, path.startsWith(String.format( + "akka://test/user/testCreateTransaction/shard-%s-%s:ShardTransactionTest@0:", + shardID.getShardName(), shardID.getMemberName().getName()))); } @Test - public void testCreateTransactionOnChain(){ - new ShardTestKit(getSystem()) {{ - final ActorRef shard = getSystem().actorOf(newShardProps(), "testCreateTransactionOnChain"); - - waitUntilLeader(shard); + public void testCreateTransactionOnChain() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final ActorRef shard = actorFactory.createActor(newShardProps(), "testCreateTransactionOnChain"); - shard.tell(new CreateTransaction("txn-1", - TransactionType.READ_ONLY.ordinal() , "foobar").toSerializable(), - getRef()); + ShardTestKit.waitUntilLeader(shard); - final CreateTransactionReply reply = expectMsgClass(duration("3 seconds"), - CreateTransactionReply.class); + shard.tell(new CreateTransaction(nextTransactionId(), TransactionType.READ_ONLY.ordinal(), + DataStoreVersions.CURRENT_VERSION).toSerializable(), testKit.getRef()); - final String path = reply.getTransactionActorPath().toString(); - assertTrue("Unexpected transaction path " + path, - path.contains("akka://test/user/testCreateTransactionOnChain/shard-txn-1")); + final CreateTransactionReply reply = testKit.expectMsgClass(Duration.ofSeconds(3), + CreateTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + final String path = reply.getTransactionPath().toString(); + assertTrue("Unexpected transaction path " + path, path.startsWith(String.format( + "akka://test/user/testCreateTransactionOnChain/shard-%s-%s:ShardTransactionTest@0:", + shardID.getShardName(), shardID.getMemberName().getName()))); } - @SuppressWarnings("serial") @Test - public void testPeerAddressResolved() throws Exception { - new ShardTestKit(getSystem()) {{ - final CountDownLatch recoveryComplete = new CountDownLatch(1); - class TestShard extends Shard { - TestShard() { - super(shardID, Collections.singletonMap(shardID.toString(), null), - newDatastoreContext(), SCHEMA_CONTEXT); - } - - String getPeerAddress(String id) { - return getRaftActorContext().getPeerAddress(id); - } - - @Override - protected void onRecoveryComplete() { - try { - super.onRecoveryComplete(); - } finally { - recoveryComplete.countDown(); - } - } - } - - final TestActorRef shard = TestActorRef.create(getSystem(), - Props.create(new DelegatingShardCreator(new Creator() { - @Override - public TestShard create() throws Exception { - return new TestShard(); - } - })), "testPeerAddressResolved"); - - assertEquals("Recovery complete", true, - Uninterruptibles.awaitUninterruptibly(recoveryComplete, 5, TimeUnit.SECONDS)); - - final String address = "akka://foobar"; - shard.underlyingActor().onReceiveCommand(new PeerAddressResolved(shardID.toString(), address)); - - assertEquals("getPeerAddress", address, - ((TestShard) shard.underlyingActor()).getPeerAddress(shardID.toString())); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + public void testPeerAddressResolved() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final ShardIdentifier peerID = ShardIdentifier.create("inventory", MemberName.forName("member-2"), + "config"); + final TestActorRef shard = actorFactory.createTestActor(newShardBuilder() + .peerAddresses(Collections.singletonMap(peerID.toString(), null)) + .props().withDispatcher(Dispatchers.DefaultDispatcherId()), "testPeerAddressResolved"); + + final String address = "akka://foobar"; + shard.tell(new PeerAddressResolved(peerID.toString(), address), ActorRef.noSender()); + + shard.tell(GetOnDemandRaftState.INSTANCE, testKit.getRef()); + final OnDemandRaftState state = testKit.expectMsgClass(OnDemandRaftState.class); + assertEquals("getPeerAddress", address, state.getPeerAddresses().get(peerID.toString())); } @Test public void testApplySnapshot() throws Exception { - ShardTestKit testkit = new ShardTestKit(getSystem()); - - final TestActorRef shard = TestActorRef.create(getSystem(), newShardProps(), - "testApplySnapshot"); + final TestActorRef shard = actorFactory.createTestActor(newShardProps() + .withDispatcher(Dispatchers.DefaultDispatcherId()), "testApplySnapshot"); - testkit.waitUntilLeader(shard); + ShardTestKit.waitUntilLeader(shard); - final DataTree store = InMemoryDataTreeFactory.getInstance().create(); - store.setSchemaContext(SCHEMA_CONTEXT); + final DataTree store = new InMemoryDataTreeFactory().create(DataTreeConfiguration.DEFAULT_OPERATIONAL, + SCHEMA_CONTEXT); final ContainerNode container = ImmutableContainerNodeBuilder.create().withNodeIdentifier( - new YangInstanceIdentifier.NodeIdentifier(TestModel.TEST_QNAME)). - withChild(ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).addChild( + new YangInstanceIdentifier.NodeIdentifier(TestModel.TEST_QNAME)) + .withChild(ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).addChild( ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1)).build()).build(); writeToStore(store, TestModel.TEST_PATH, container); - final YangInstanceIdentifier root = YangInstanceIdentifier.builder().build(); + final YangInstanceIdentifier root = YangInstanceIdentifier.EMPTY; final NormalizedNode expected = readStore(store, root); - final Snapshot snapshot = Snapshot.create(SerializationUtils.serializeNormalizedNode(expected), - Collections.emptyList(), 1, 2, 3, 4); + final Snapshot snapshot = Snapshot.create(new ShardSnapshotState(new MetadataShardDataTreeSnapshot(expected)), + Collections.emptyList(), 1, 2, 3, 4, -1, null, null); - shard.underlyingActor().getRaftActorSnapshotCohort().applySnapshot(snapshot.getState()); + shard.tell(new ApplySnapshot(snapshot), ActorRef.noSender()); - final NormalizedNode actual = readStore(shard, root); + final Stopwatch sw = Stopwatch.createStarted(); + while (sw.elapsed(TimeUnit.SECONDS) <= 5) { + Uninterruptibles.sleepUninterruptibly(75, TimeUnit.MILLISECONDS); - assertEquals("Root node", expected, actual); + try { + assertEquals("Root node", expected, readStore(shard, root)); + return; + } catch (final AssertionError e) { + // try again + } + } - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); + fail("Snapshot was not applied"); } @Test public void testApplyState() throws Exception { + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), "testApplyState"); - ShardTestKit testkit = new ShardTestKit(getSystem()); - - final TestActorRef shard = TestActorRef.create(getSystem(), newShardProps(), "testApplyState"); - - testkit.waitUntilLeader(shard); - - final NormalizedNode node = ImmutableNodes.containerNode(TestModel.TEST_QNAME); - - final ApplyState applyState = new ApplyState(null, "test", new ReplicatedLogImplEntry(1, 2, - newModificationPayload(new WriteModification(TestModel.TEST_PATH, node)))); - - shard.underlyingActor().onReceiveCommand(applyState); - - final NormalizedNode actual = readStore(shard, TestModel.TEST_PATH); - assertEquals("Applied state", node, actual); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - } - - @Test - public void testApplyStateWithCandidatePayload() throws Exception { - - ShardTestKit testkit = new ShardTestKit(getSystem()); - - final TestActorRef shard = TestActorRef.create(getSystem(), newShardProps(), "testApplyState"); - - testkit.waitUntilLeader(shard); - - final NormalizedNode node = ImmutableNodes.containerNode(TestModel.TEST_QNAME); - final DataTreeCandidate candidate = DataTreeCandidates.fromNormalizedNode(TestModel.TEST_PATH, node); - - final ApplyState applyState = new ApplyState(null, "test", new ReplicatedLogImplEntry(1, 2, - DataTreeCandidatePayload.create(candidate))); - - shard.underlyingActor().onReceiveCommand(applyState); + ShardTestKit.waitUntilLeader(shard); - final NormalizedNode actual = readStore(shard, TestModel.TEST_PATH); - assertEquals("Applied state", node, actual); + final DataTree store = new InMemoryDataTreeFactory().create(DataTreeConfiguration.DEFAULT_OPERATIONAL, + SCHEMA_CONTEXT); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - } - - DataTree setupInMemorySnapshotStore() throws DataValidationFailedException { - final DataTree testStore = InMemoryDataTreeFactory.getInstance().create(); - testStore.setSchemaContext(SCHEMA_CONTEXT); + final DataTreeModification writeMod = store.takeSnapshot().newModification(); + final ContainerNode node = ImmutableNodes.containerNode(TestModel.TEST_QNAME); + writeMod.write(TestModel.TEST_PATH, node); + writeMod.ready(); - writeToStore(testStore, TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); + final TransactionIdentifier tx = nextTransactionId(); + shard.underlyingActor().applyState(null, null, payloadForModification(store, writeMod, tx)); - final NormalizedNode root = readStore(testStore, YangInstanceIdentifier.builder().build()); + final Stopwatch sw = Stopwatch.createStarted(); + while (sw.elapsed(TimeUnit.SECONDS) <= 5) { + Uninterruptibles.sleepUninterruptibly(75, TimeUnit.MILLISECONDS); - InMemorySnapshotStore.addSnapshot(shardID.toString(), Snapshot.create( - SerializationUtils.serializeNormalizedNode(root), - Collections.emptyList(), 0, 1, -1, -1)); - return testStore; - } + final NormalizedNode actual = readStore(shard, TestModel.TEST_PATH); + if (actual != null) { + assertEquals("Applied state", node, actual); + return; + } + } - private static DataTreeCandidatePayload payloadForModification(final DataTree source, final DataTreeModification mod) throws DataValidationFailedException { - source.validate(mod); - final DataTreeCandidate candidate = source.prepare(mod); - source.commit(candidate); - return DataTreeCandidatePayload.create(candidate); + fail("State was not applied"); } @Test @@ -573,7 +353,8 @@ public class ShardTest extends AbstractShardTest { InMemoryJournal.addEntry(shardID.toString(), 0, DUMMY_DATA); // Set up the InMemoryJournal. - InMemoryJournal.addEntry(shardID.toString(), 1, new ReplicatedLogImplEntry(0, 1, payloadForModification(source, writeMod))); + InMemoryJournal.addEntry(shardID.toString(), 1, new SimpleReplicatedLogEntry(0, 1, + payloadForModification(source, writeMod, nextTransactionId()))); final int nListEntries = 16; final Set listEntryKeys = new HashSet<>(); @@ -588,8 +369,9 @@ public class ShardTest extends AbstractShardTest { final DataTreeModification mod = source.takeSnapshot().newModification(); mod.merge(path, ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, i)); mod.ready(); - InMemoryJournal.addEntry(shardID.toString(), i+1, new ReplicatedLogImplEntry(i, 1, - payloadForModification(source, mod))); + + InMemoryJournal.addEntry(shardID.toString(), i + 1, new SimpleReplicatedLogEntry(i, 1, + payloadForModification(source, mod, nextTransactionId()))); } InMemoryJournal.addEntry(shardID.toString(), nListEntries + 2, @@ -599,1673 +381,1289 @@ public class ShardTest extends AbstractShardTest { } @Test - public void testModicationRecovery() throws Exception { + @SuppressWarnings("checkstyle:IllegalCatch") + public void testConcurrentThreePhaseCommits() throws Exception { + final AtomicReference caughtEx = new AtomicReference<>(); + final CountDownLatch commitLatch = new CountDownLatch(2); - // Set up the InMemorySnapshotStore. - setupInMemorySnapshotStore(); + final long timeoutSec = 5; + final Duration duration = Duration.ofSeconds(timeoutSec); + final Timeout timeout = Timeout.create(duration); - // Set up the InMemoryJournal. + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testConcurrentThreePhaseCommits"); - InMemoryJournal.addEntry(shardID.toString(), 0, DUMMY_DATA); + class OnFutureComplete extends OnComplete { + private final Class expRespType; - InMemoryJournal.addEntry(shardID.toString(), 1, new ReplicatedLogImplEntry(0, 1, newModificationPayload( - new WriteModification(TestModel.OUTER_LIST_PATH, - ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build())))); + OnFutureComplete(final Class expRespType) { + this.expRespType = expRespType; + } - final int nListEntries = 16; - final Set listEntryKeys = new HashSet<>(); + @Override + public void onComplete(final Throwable error, final Object resp) { + if (error != null) { + caughtEx.set(new AssertionError(getClass().getSimpleName() + " failure", error)); + } else { + try { + assertEquals("Commit response type", expRespType, resp.getClass()); + onSuccess(resp); + } catch (final Exception e) { + caughtEx.set(e); + } + } + } - // Add some ModificationPayload entries - for(int i = 1; i <= nListEntries; i++) { - listEntryKeys.add(Integer.valueOf(i)); - final YangInstanceIdentifier path = YangInstanceIdentifier.builder(TestModel.OUTER_LIST_PATH) - .nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, i).build(); - final Modification mod = new MergeModification(path, - ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, i)); - InMemoryJournal.addEntry(shardID.toString(), i + 1, new ReplicatedLogImplEntry(i, 1, - newModificationPayload(mod))); + void onSuccess(final Object resp) { + } } - InMemoryJournal.addEntry(shardID.toString(), nListEntries + 2, - new ApplyJournalEntries(nListEntries)); - - testRecovery(listEntryKeys); - } + class OnCommitFutureComplete extends OnFutureComplete { + OnCommitFutureComplete() { + super(CommitTransactionReply.class); + } - private static ModificationPayload newModificationPayload(final Modification... mods) throws IOException { - final MutableCompositeModification compMod = new MutableCompositeModification(); - for(final Modification mod: mods) { - compMod.addModification(mod); + @Override + public void onComplete(final Throwable error, final Object resp) { + super.onComplete(error, resp); + commitLatch.countDown(); + } } - return new ModificationPayload(compMod); - } - - @Test - public void testConcurrentThreePhaseCommits() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testConcurrentThreePhaseCommits"); - - waitUntilLeader(shard); - - // Setup 3 simulated transactions with mock cohorts backed by real cohorts. - - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); - - final String transactionID1 = "tx1"; - final MutableCompositeModification modification1 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort1 = setupMockWriteTransaction("cohort1", dataStore, - TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), modification1); - - final String transactionID2 = "tx2"; - final MutableCompositeModification modification2 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort2 = setupMockWriteTransaction("cohort2", dataStore, - TestModel.OUTER_LIST_PATH, - ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(), - modification2); - - final String transactionID3 = "tx3"; - final MutableCompositeModification modification3 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort3 = setupMockWriteTransaction("cohort3", dataStore, - YangInstanceIdentifier.builder(TestModel.OUTER_LIST_PATH) - .nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1).build(), - ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1), - modification3); + class OnCanCommitFutureComplete extends OnFutureComplete { + private final TransactionIdentifier transactionID; - final long timeoutSec = 5; - final FiniteDuration duration = FiniteDuration.create(timeoutSec, TimeUnit.SECONDS); - final Timeout timeout = new Timeout(duration); - - // Simulate the ForwardedReadyTransaction message for the first Tx that would be sent - // by the ShardTransaction. - - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort1, modification1, true, false), getRef()); - final ReadyTransactionReply readyReply = ReadyTransactionReply.fromSerializable( - expectMsgClass(duration, ReadyTransactionReply.class)); - assertEquals("Cohort path", shard.path().toString(), readyReply.getCohortPath()); + OnCanCommitFutureComplete(final TransactionIdentifier transactionID) { + super(CanCommitTransactionReply.class); + this.transactionID = transactionID; + } - // Send the CanCommitTransaction message for the first Tx. + @Override + void onSuccess(final Object resp) { + final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable(resp); + assertTrue("Can commit", canCommitReply.getCanCommit()); - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + final Future commitFuture = Patterns.ask(shard, + new CommitTransaction(transactionID, CURRENT_VERSION).toSerializable(), timeout); + commitFuture.onComplete(new OnCommitFutureComplete(), getSystem().dispatcher()); + } + } - // Send the ForwardedReadyTransaction for the next 2 Tx's. + final ShardTestKit testKit = new ShardTestKit(getSystem()); + ShardTestKit.waitUntilLeader(shard); - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort2, modification2, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + final TransactionIdentifier transactionID1 = nextTransactionId(); + final TransactionIdentifier transactionID2 = nextTransactionId(); + final TransactionIdentifier transactionID3 = nextTransactionId(); - shard.tell(new ForwardedReadyTransaction(transactionID3, CURRENT_VERSION, - cohort3, modification3, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + final Map cohortMap = setupCohortDecorator( + shard.underlyingActor(), transactionID1, transactionID2, transactionID3); + final CapturingShardDataTreeCohort cohort1 = cohortMap.get(transactionID1); + final CapturingShardDataTreeCohort cohort2 = cohortMap.get(transactionID2); + final CapturingShardDataTreeCohort cohort3 = cohortMap.get(transactionID3); - // Send the CanCommitTransaction message for the next 2 Tx's. These should get queued and - // processed after the first Tx completes. + shard.tell(prepareBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), false), testKit.getRef()); + final ReadyTransactionReply readyReply = ReadyTransactionReply + .fromSerializable(testKit.expectMsgClass(duration, ReadyTransactionReply.class)); + assertEquals("Cohort path", shard.path().toString(), readyReply.getCohortPath()); + // Send the CanCommitTransaction message for the first Tx. - final Future canCommitFuture1 = Patterns.ask(shard, - new CanCommitTransaction(transactionID2).toSerializable(), timeout); + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(duration, CanCommitTransactionReply.class)); + assertTrue("Can commit", canCommitReply.getCanCommit()); - final Future canCommitFuture2 = Patterns.ask(shard, - new CanCommitTransaction(transactionID3).toSerializable(), timeout); + // Ready 2 more Tx's. - // Send the CommitTransaction message for the first Tx. After it completes, it should - // trigger the 2nd Tx to proceed which should in turn then trigger the 3rd. + shard.tell(prepareBatchedModifications(transactionID2, TestModel.OUTER_LIST_PATH, + ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(), false), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new CommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); + shard.tell( + prepareBatchedModifications(transactionID3, + YangInstanceIdentifier.builder(TestModel.OUTER_LIST_PATH) + .nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1).build(), + ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1), false), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Wait for the next 2 Tx's to complete. + // Send the CanCommitTransaction message for the next 2 Tx's. + // These should get queued and + // processed after the first Tx completes. - final AtomicReference caughtEx = new AtomicReference<>(); - final CountDownLatch commitLatch = new CountDownLatch(2); + final Future canCommitFuture1 = Patterns.ask(shard, + new CanCommitTransaction(transactionID2, CURRENT_VERSION).toSerializable(), timeout); - class OnFutureComplete extends OnComplete { - private final Class expRespType; + final Future canCommitFuture2 = Patterns.ask(shard, + new CanCommitTransaction(transactionID3, CURRENT_VERSION).toSerializable(), timeout); - OnFutureComplete(final Class expRespType) { - this.expRespType = expRespType; - } + // Send the CommitTransaction message for the first Tx. After it + // completes, it should + // trigger the 2nd Tx to proceed which should in turn then + // trigger the 3rd. - @Override - public void onComplete(final Throwable error, final Object resp) { - if(error != null) { - caughtEx.set(new AssertionError(getClass().getSimpleName() + " failure", error)); - } else { - try { - assertEquals("Commit response type", expRespType, resp.getClass()); - onSuccess(resp); - } catch (final Exception e) { - caughtEx.set(e); - } - } - } + shard.tell(new CommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - void onSuccess(final Object resp) throws Exception { - } - } + // Wait for the next 2 Tx's to complete. - class OnCommitFutureComplete extends OnFutureComplete { - OnCommitFutureComplete() { - super(CommitTransactionReply.SERIALIZABLE_CLASS); - } - - @Override - public void onComplete(final Throwable error, final Object resp) { - super.onComplete(error, resp); - commitLatch.countDown(); - } - } - - class OnCanCommitFutureComplete extends OnFutureComplete { - private final String transactionID; - - OnCanCommitFutureComplete(final String transactionID) { - super(CanCommitTransactionReply.SERIALIZABLE_CLASS); - this.transactionID = transactionID; - } - - @Override - void onSuccess(final Object resp) throws Exception { - final CanCommitTransactionReply canCommitReply = - CanCommitTransactionReply.fromSerializable(resp); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); - - final Future commitFuture = Patterns.ask(shard, - new CommitTransaction(transactionID).toSerializable(), timeout); - commitFuture.onComplete(new OnCommitFutureComplete(), getSystem().dispatcher()); - } - } + canCommitFuture1.onComplete(new OnCanCommitFutureComplete(transactionID2), getSystem().dispatcher()); - canCommitFuture1.onComplete(new OnCanCommitFutureComplete(transactionID2), - getSystem().dispatcher()); + canCommitFuture2.onComplete(new OnCanCommitFutureComplete(transactionID3), getSystem().dispatcher()); - canCommitFuture2.onComplete(new OnCanCommitFutureComplete(transactionID3), - getSystem().dispatcher()); + final boolean done = commitLatch.await(timeoutSec, TimeUnit.SECONDS); - final boolean done = commitLatch.await(timeoutSec, TimeUnit.SECONDS); - - if(caughtEx.get() != null) { - throw caughtEx.get(); - } - - assertEquals("Commits complete", true, done); - - final InOrder inOrder = inOrder(cohort1, cohort2, cohort3); - inOrder.verify(cohort1).canCommit(); - inOrder.verify(cohort1).preCommit(); - inOrder.verify(cohort1).commit(); - inOrder.verify(cohort2).canCommit(); - inOrder.verify(cohort2).preCommit(); - inOrder.verify(cohort2).commit(); - inOrder.verify(cohort3).canCommit(); - inOrder.verify(cohort3).preCommit(); - inOrder.verify(cohort3).commit(); - - // Verify data in the data store. + final Throwable t = caughtEx.get(); + if (t != null) { + Throwables.propagateIfPossible(t, Exception.class); + throw new RuntimeException(t); + } - verifyOuterListEntry(shard, 1); + assertTrue("Commits complete", done); - verifyLastApplied(shard, 2); +// final InOrder inOrder = inOrder(cohort1.getCanCommit(), cohort1.getPreCommit(), cohort1.getCommit(), +// cohort2.getCanCommit(), cohort2.getPreCommit(), cohort2.getCommit(), cohort3.getCanCommit(), +// cohort3.getPreCommit(), cohort3.getCommit()); +// inOrder.verify(cohort1.getCanCommit()).onSuccess(any(Void.class)); +// inOrder.verify(cohort1.getPreCommit()).onSuccess(any(DataTreeCandidate.class)); +// inOrder.verify(cohort2.getCanCommit()).onSuccess(any(Void.class)); +// inOrder.verify(cohort2.getPreCommit()).onSuccess(any(DataTreeCandidate.class)); +// inOrder.verify(cohort3.getCanCommit()).onSuccess(any(Void.class)); +// inOrder.verify(cohort3.getPreCommit()).onSuccess(any(DataTreeCandidate.class)); +// inOrder.verify(cohort1.getCommit()).onSuccess(any(UnsignedLong.class)); +// inOrder.verify(cohort2.getCommit()).onSuccess(any(UnsignedLong.class)); +// inOrder.verify(cohort3.getCommit()).onSuccess(any(UnsignedLong.class)); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; - } + // Verify data in the data store. - private static BatchedModifications newBatchedModifications(final String transactionID, final YangInstanceIdentifier path, - final NormalizedNode data, final boolean ready, final boolean doCommitOnReady, final int messagesSent) { - return newBatchedModifications(transactionID, null, path, data, ready, doCommitOnReady, messagesSent); - } + verifyOuterListEntry(shard, 1); - private static BatchedModifications newBatchedModifications(final String transactionID, final String transactionChainID, - final YangInstanceIdentifier path, final NormalizedNode data, final boolean ready, final boolean doCommitOnReady, - final int messagesSent) { - final BatchedModifications batched = new BatchedModifications(transactionID, CURRENT_VERSION, transactionChainID); - batched.addModification(new WriteModification(path, data)); - batched.setReady(ready); - batched.setDoCommitOnReady(doCommitOnReady); - batched.setTotalMessagesSent(messagesSent); - return batched; + verifyLastApplied(shard, 5); } @Test - public void testBatchedModificationsWithNoCommitOnReady() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testBatchedModificationsWithNoCommitOnReady"); - - waitUntilLeader(shard); - - final String transactionID = "tx"; - final FiniteDuration duration = duration("5 seconds"); - - final AtomicReference mockCohort = new AtomicReference<>(); - final ShardCommitCoordinator.CohortDecorator cohortDecorator = new ShardCommitCoordinator.CohortDecorator() { - @Override - public ShardDataTreeCohort decorate(final String txID, final ShardDataTreeCohort actual) { - if(mockCohort.get() == null) { - mockCohort.set(createDelegatingMockCohort("cohort", actual)); - } - - return mockCohort.get(); - } - }; - - shard.underlyingActor().getCommitCoordinator().setCohortDecorator(cohortDecorator); + public void testBatchedModificationsWithNoCommitOnReady() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testBatchedModificationsWithNoCommitOnReady"); - // Send a BatchedModifications to start a transaction. + ShardTestKit.waitUntilLeader(shard); - shard.tell(newBatchedModifications(transactionID, TestModel.TEST_PATH, - ImmutableNodes.containerNode(TestModel.TEST_QNAME), false, false, 1), getRef()); - expectMsgClass(duration, BatchedModificationsReply.class); + final TransactionIdentifier transactionID = nextTransactionId(); + final Duration duration = Duration.ofSeconds(5); - // Send a couple more BatchedModifications. + // Send a BatchedModifications to start a transaction. - shard.tell(newBatchedModifications(transactionID, TestModel.OUTER_LIST_PATH, - ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(), false, false, 2), getRef()); - expectMsgClass(duration, BatchedModificationsReply.class); + shard.tell(newBatchedModifications(transactionID, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), false, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, BatchedModificationsReply.class); - shard.tell(newBatchedModifications(transactionID, YangInstanceIdentifier.builder( - TestModel.OUTER_LIST_PATH).nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1).build(), - ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1), true, false, 3), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + // Send a couple more BatchedModifications. - // Send the CanCommitTransaction message. + shard.tell(newBatchedModifications(transactionID, TestModel.OUTER_LIST_PATH, + ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(), false, false, 2), + testKit.getRef()); + testKit.expectMsgClass(duration, BatchedModificationsReply.class); - shard.tell(new CanCommitTransaction(transactionID).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + shard.tell(newBatchedModifications(transactionID, + YangInstanceIdentifier.builder(TestModel.OUTER_LIST_PATH) + .nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1).build(), + ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1), true, false, 3), + testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Send the CanCommitTransaction message. + // Send the CanCommitTransaction message. - shard.tell(new CommitTransaction(transactionID).toSerializable(), getRef()); - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); + shard.tell(new CanCommitTransaction(transactionID, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(duration, CanCommitTransactionReply.class)); + assertTrue("Can commit", canCommitReply.getCanCommit()); - final InOrder inOrder = inOrder(mockCohort.get()); - inOrder.verify(mockCohort.get()).canCommit(); - inOrder.verify(mockCohort.get()).preCommit(); - inOrder.verify(mockCohort.get()).commit(); + // Send the CommitTransaction message. - // Verify data in the data store. + shard.tell(new CommitTransaction(transactionID, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - verifyOuterListEntry(shard, 1); + // Verify data in the data store. - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + verifyOuterListEntry(shard, 1); } @Test - public void testBatchedModificationsWithCommitOnReady() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testBatchedModificationsWithCommitOnReady"); - - waitUntilLeader(shard); - - final String transactionID = "tx"; - final FiniteDuration duration = duration("5 seconds"); - - final AtomicReference mockCohort = new AtomicReference<>(); - final ShardCommitCoordinator.CohortDecorator cohortDecorator = new ShardCommitCoordinator.CohortDecorator() { - @Override - public ShardDataTreeCohort decorate(final String txID, final ShardDataTreeCohort actual) { - if(mockCohort.get() == null) { - mockCohort.set(createDelegatingMockCohort("cohort", actual)); - } - - return mockCohort.get(); - } - }; + public void testBatchedModificationsWithCommitOnReady() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testBatchedModificationsWithCommitOnReady"); - shard.underlyingActor().getCommitCoordinator().setCohortDecorator(cohortDecorator); + ShardTestKit.waitUntilLeader(shard); - // Send a BatchedModifications to start a transaction. + final TransactionIdentifier transactionID = nextTransactionId(); + final Duration duration = Duration.ofSeconds(5); - shard.tell(newBatchedModifications(transactionID, TestModel.TEST_PATH, - ImmutableNodes.containerNode(TestModel.TEST_QNAME), false, false, 1), getRef()); - expectMsgClass(duration, BatchedModificationsReply.class); + // Send a BatchedModifications to start a transaction. - // Send a couple more BatchedModifications. + shard.tell(newBatchedModifications(transactionID, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), false, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, BatchedModificationsReply.class); - shard.tell(newBatchedModifications(transactionID, TestModel.OUTER_LIST_PATH, - ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(), false, false, 2), getRef()); - expectMsgClass(duration, BatchedModificationsReply.class); + // Send a couple more BatchedModifications. - shard.tell(newBatchedModifications(transactionID, YangInstanceIdentifier.builder( - TestModel.OUTER_LIST_PATH).nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1).build(), - ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1), true, true, 3), getRef()); + shard.tell(newBatchedModifications(transactionID, TestModel.OUTER_LIST_PATH, + ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(), false, false, 2), + testKit.getRef()); + testKit.expectMsgClass(duration, BatchedModificationsReply.class); - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); + shard.tell(newBatchedModifications(transactionID, + YangInstanceIdentifier.builder(TestModel.OUTER_LIST_PATH) + .nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1).build(), + ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1), true, true, 3), + testKit.getRef()); - final InOrder inOrder = inOrder(mockCohort.get()); - inOrder.verify(mockCohort.get()).canCommit(); - inOrder.verify(mockCohort.get()).preCommit(); - inOrder.verify(mockCohort.get()).commit(); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - // Verify data in the data store. - - verifyOuterListEntry(shard, 1); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + // Verify data in the data store. + verifyOuterListEntry(shard, 1); } - @Test(expected=IllegalStateException.class) - public void testBatchedModificationsReadyWithIncorrectTotalMessageCount() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testBatchedModificationsReadyWithIncorrectTotalMessageCount"); - - waitUntilLeader(shard); + @Test(expected = IllegalStateException.class) + public void testBatchedModificationsReadyWithIncorrectTotalMessageCount() throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testBatchedModificationsReadyWithIncorrectTotalMessageCount"); - final String transactionID = "tx1"; - final BatchedModifications batched = new BatchedModifications(transactionID, DataStoreVersions.CURRENT_VERSION, null); - batched.setReady(true); - batched.setTotalMessagesSent(2); + ShardTestKit.waitUntilLeader(shard); - shard.tell(batched, getRef()); + final TransactionIdentifier transactionID = nextTransactionId(); + final BatchedModifications batched = new BatchedModifications(transactionID, + DataStoreVersions.CURRENT_VERSION); + batched.setReady(); + batched.setTotalMessagesSent(2); - final Failure failure = expectMsgClass(duration("5 seconds"), akka.actor.Status.Failure.class); + shard.tell(batched, testKit.getRef()); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); + final Failure failure = testKit.expectMsgClass(Duration.ofSeconds(5), Failure.class); - if(failure != null) { - throw failure.cause(); - } - }}; + if (failure != null) { + Throwables.propagateIfPossible(failure.cause(), Exception.class); + throw new RuntimeException(failure.cause()); + } } @Test - public void testBatchedModificationsWithOperationFailure() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testBatchedModificationsWithOperationFailure"); - - waitUntilLeader(shard); + public void testBatchedModificationsWithOperationFailure() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testBatchedModificationsWithOperationFailure"); - // Test merge with invalid data. An exception should occur when the merge is applied. Note that - // write will not validate the children for performance reasons. + ShardTestKit.waitUntilLeader(shard); - String transactionID = "tx1"; + // Test merge with invalid data. An exception should occur when + // the merge is applied. Note that + // write will not validate the children for performance reasons. - ContainerNode invalidData = ImmutableContainerNodeBuilder.create().withNodeIdentifier( - new YangInstanceIdentifier.NodeIdentifier(TestModel.TEST_QNAME)). - withChild(ImmutableNodes.leafNode(TestModel.JUNK_QNAME, "junk")).build(); + final TransactionIdentifier transactionID = nextTransactionId(); - BatchedModifications batched = new BatchedModifications(transactionID, CURRENT_VERSION, null); - batched.addModification(new MergeModification(TestModel.TEST_PATH, invalidData)); - shard.tell(batched, getRef()); - Failure failure = expectMsgClass(duration("5 seconds"), akka.actor.Status.Failure.class); + final ContainerNode invalidData = ImmutableContainerNodeBuilder.create() + .withNodeIdentifier(new YangInstanceIdentifier.NodeIdentifier(TestModel.TEST_QNAME)) + .withChild(ImmutableNodes.leafNode(TestModel.JUNK_QNAME, "junk")).build(); - Throwable cause = failure.cause(); + BatchedModifications batched = new BatchedModifications(transactionID, CURRENT_VERSION); + batched.addModification(new MergeModification(TestModel.TEST_PATH, invalidData)); + shard.tell(batched, testKit.getRef()); + Failure failure = testKit.expectMsgClass(Duration.ofSeconds(5), akka.actor.Status.Failure.class); - batched = new BatchedModifications(transactionID, DataStoreVersions.CURRENT_VERSION, null); - batched.setReady(true); - batched.setTotalMessagesSent(2); + final Throwable cause = failure.cause(); - shard.tell(batched, getRef()); + batched = new BatchedModifications(transactionID, DataStoreVersions.CURRENT_VERSION); + batched.setReady(); + batched.setTotalMessagesSent(2); - failure = expectMsgClass(duration("5 seconds"), akka.actor.Status.Failure.class); - assertEquals("Failure cause", cause, failure.cause()); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; - } + shard.tell(batched, testKit.getRef()); - @SuppressWarnings("unchecked") - private static void verifyOuterListEntry(final TestActorRef shard, final Object expIDValue) throws Exception { - final NormalizedNode outerList = readStore(shard, TestModel.OUTER_LIST_PATH); - assertNotNull(TestModel.OUTER_LIST_QNAME.getLocalName() + " not found", outerList); - assertTrue(TestModel.OUTER_LIST_QNAME.getLocalName() + " value is not Iterable", - outerList.getValue() instanceof Iterable); - final Object entry = ((Iterable)outerList.getValue()).iterator().next(); - assertTrue(TestModel.OUTER_LIST_QNAME.getLocalName() + " entry is not MapEntryNode", - entry instanceof MapEntryNode); - final MapEntryNode mapEntry = (MapEntryNode)entry; - final Optional> idLeaf = - mapEntry.getChild(new YangInstanceIdentifier.NodeIdentifier(TestModel.ID_QNAME)); - assertTrue("Missing leaf " + TestModel.ID_QNAME.getLocalName(), idLeaf.isPresent()); - assertEquals(TestModel.ID_QNAME.getLocalName() + " value", expIDValue, idLeaf.get().getValue()); + failure = testKit.expectMsgClass(Duration.ofSeconds(5), akka.actor.Status.Failure.class); + assertEquals("Failure cause", cause, failure.cause()); } @Test - public void testBatchedModificationsOnTransactionChain() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testBatchedModificationsOnTransactionChain"); + public void testBatchedModificationsOnTransactionChain() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testBatchedModificationsOnTransactionChain"); - waitUntilLeader(shard); + ShardTestKit.waitUntilLeader(shard); - final String transactionChainID = "txChain"; - final String transactionID1 = "tx1"; - final String transactionID2 = "tx2"; + final LocalHistoryIdentifier historyId = nextHistoryId(); + final TransactionIdentifier transactionID1 = new TransactionIdentifier(historyId, 0); + final TransactionIdentifier transactionID2 = new TransactionIdentifier(historyId, 1); - final FiniteDuration duration = duration("5 seconds"); + final Duration duration = Duration.ofSeconds(5); - // Send a BatchedModifications to start a chained write transaction and ready it. + // Send a BatchedModifications to start a chained write + // transaction and ready it. - final ContainerNode containerNode = ImmutableNodes.containerNode(TestModel.TEST_QNAME); - final YangInstanceIdentifier path = TestModel.TEST_PATH; - shard.tell(newBatchedModifications(transactionID1, transactionChainID, path, - containerNode, true, false, 1), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + final ContainerNode containerNode = ImmutableNodes.containerNode(TestModel.TEST_QNAME); + final YangInstanceIdentifier path = TestModel.TEST_PATH; + shard.tell(newBatchedModifications(transactionID1, path, containerNode, true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Create a read Tx on the same chain. + // Create a read Tx on the same chain. - shard.tell(new CreateTransaction(transactionID2, TransactionType.READ_ONLY.ordinal() , - transactionChainID).toSerializable(), getRef()); + shard.tell(new CreateTransaction(transactionID2, TransactionType.READ_ONLY.ordinal(), + DataStoreVersions.CURRENT_VERSION).toSerializable(), testKit.getRef()); - final CreateTransactionReply createReply = expectMsgClass(duration("3 seconds"), CreateTransactionReply.class); + final CreateTransactionReply createReply = testKit.expectMsgClass(Duration.ofSeconds(3), + CreateTransactionReply.class); - getSystem().actorSelection(createReply.getTransactionActorPath()).tell(new ReadData(path), getRef()); - final ReadDataReply readReply = expectMsgClass(duration("3 seconds"), ReadDataReply.class); - assertEquals("Read node", containerNode, readReply.getNormalizedNode()); + getSystem().actorSelection(createReply.getTransactionPath()) + .tell(new ReadData(path, DataStoreVersions.CURRENT_VERSION), testKit.getRef()); + final ReadDataReply readReply = testKit.expectMsgClass(Duration.ofSeconds(3), ReadDataReply.class); + assertEquals("Read node", containerNode, readReply.getNormalizedNode()); - // Commit the write transaction. + // Commit the write transaction. - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(duration, CanCommitTransactionReply.class)); + assertTrue("Can commit", canCommitReply.getCanCommit()); - shard.tell(new CommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); + shard.tell(new CommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - // Verify data in the data store. + // Verify data in the data store. - final NormalizedNode actualNode = readStore(shard, path); - assertEquals("Stored node", containerNode, actualNode); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + final NormalizedNode actualNode = readStore(shard, path); + assertEquals("Stored node", containerNode, actualNode); } @Test public void testOnBatchedModificationsWhenNotLeader() { final AtomicBoolean overrideLeaderCalls = new AtomicBoolean(); - new ShardTestKit(getSystem()) {{ - final Creator creator = new Creator() { - private static final long serialVersionUID = 1L; - - @Override - public Shard create() throws Exception { - return new Shard(shardID, Collections.emptyMap(), - newDatastoreContext(), SCHEMA_CONTEXT) { - @Override - protected boolean isLeader() { - return overrideLeaderCalls.get() ? false : super.isLeader(); - } + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final Creator creator = new Creator() { + private static final long serialVersionUID = 1L; - @Override - protected ActorSelection getLeader() { - return overrideLeaderCalls.get() ? getSystem().actorSelection(getRef().path()) : - super.getLeader(); - } - }; - } - }; + @Override + public Shard create() { + return new Shard(newShardBuilder()) { + @Override + protected boolean isLeader() { + return overrideLeaderCalls.get() ? false : super.isLeader(); + } - final TestActorRef shard = TestActorRef.create(getSystem(), - Props.create(new DelegatingShardCreator(creator)), "testOnBatchedModificationsWhenNotLeader"); + @Override + public ActorSelection getLeader() { + return overrideLeaderCalls.get() ? getSystem().actorSelection(testKit.getRef().path()) + : super.getLeader(); + } + }; + } + }; - waitUntilLeader(shard); + final TestActorRef shard = actorFactory.createTestActor(Props + .create(new DelegatingShardCreator(creator)).withDispatcher(Dispatchers.DefaultDispatcherId()), + "testOnBatchedModificationsWhenNotLeader"); - overrideLeaderCalls.set(true); + ShardTestKit.waitUntilLeader(shard); - final BatchedModifications batched = new BatchedModifications("tx", DataStoreVersions.CURRENT_VERSION, ""); + overrideLeaderCalls.set(true); - shard.tell(batched, ActorRef.noSender()); + final BatchedModifications batched = new BatchedModifications(nextTransactionId(), + DataStoreVersions.CURRENT_VERSION); - expectMsgEquals(batched); + shard.tell(batched, ActorRef.noSender()); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + testKit.expectMsgEquals(batched); } @Test - public void testForwardedReadyTransactionWithImmediateCommit() throws Exception{ - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testForwardedReadyTransactionWithImmediateCommit"); - - waitUntilLeader(shard); - - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); - - final String transactionID = "tx1"; - final MutableCompositeModification modification = new MutableCompositeModification(); - final NormalizedNode containerNode = ImmutableNodes.containerNode(TestModel.TEST_QNAME); - final ShardDataTreeCohort cohort = setupMockWriteTransaction("cohort", dataStore, - TestModel.TEST_PATH, containerNode, modification); - - final FiniteDuration duration = duration("5 seconds"); - - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + public void testTransactionMessagesWithNoLeader() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + dataStoreContextBuilder.customRaftPolicyImplementation(DisableElectionsRaftPolicy.class.getName()) + .shardHeartbeatIntervalInMillis(50).shardElectionTimeoutFactor(1); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testTransactionMessagesWithNoLeader"); + + testKit.waitUntilNoLeader(shard); + + final TransactionIdentifier txId = nextTransactionId(); + shard.tell(new BatchedModifications(txId, DataStoreVersions.CURRENT_VERSION), testKit.getRef()); + Failure failure = testKit.expectMsgClass(Failure.class); + assertEquals("Failure cause type", NoShardLeaderException.class, failure.cause().getClass()); + + shard.tell(prepareForwardedReadyTransaction(shard, txId, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true), testKit.getRef()); + failure = testKit.expectMsgClass(Failure.class); + assertEquals("Failure cause type", NoShardLeaderException.class, failure.cause().getClass()); + + shard.tell(new ReadyLocalTransaction(txId, mock(DataTreeModification.class), true, Optional.empty()), + testKit.getRef()); + failure = testKit.expectMsgClass(Failure.class); + assertEquals("Failure cause type", NoShardLeaderException.class, failure.cause().getClass()); + } - shard.tell(new ForwardedReadyTransaction(transactionID, CURRENT_VERSION, - cohort, modification, true, true), getRef()); + @Test + public void testReadyWithReadWriteImmediateCommit() { + testReadyWithImmediateCommit(true); + } - expectMsgClass(duration, ThreePhaseCommitCohortMessages.CommitTransactionReply.class); + @Test + public void testReadyWithWriteOnlyImmediateCommit() { + testReadyWithImmediateCommit(false); + } - final InOrder inOrder = inOrder(cohort); - inOrder.verify(cohort).canCommit(); - inOrder.verify(cohort).preCommit(); - inOrder.verify(cohort).commit(); + private void testReadyWithImmediateCommit(final boolean readWrite) { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testReadyWithImmediateCommit-" + readWrite); + + ShardTestKit.waitUntilLeader(shard); + + final TransactionIdentifier transactionID = nextTransactionId(); + final NormalizedNode containerNode = ImmutableNodes.containerNode(TestModel.TEST_QNAME); + if (readWrite) { + shard.tell(prepareForwardedReadyTransaction(shard, transactionID, TestModel.TEST_PATH, containerNode, true), + testKit.getRef()); + } else { + shard.tell(prepareBatchedModifications(transactionID, TestModel.TEST_PATH, containerNode, true), + testKit.getRef()); + } - final NormalizedNode actualNode = readStore(shard, TestModel.TEST_PATH); - assertEquals(TestModel.TEST_QNAME.getLocalName(), containerNode, actualNode); + testKit.expectMsgClass(Duration.ofSeconds(5), CommitTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + final NormalizedNode actualNode = readStore(shard, TestModel.TEST_PATH); + assertEquals(TestModel.TEST_QNAME.getLocalName(), containerNode, actualNode); } @Test - public void testReadyLocalTransactionWithImmediateCommit() throws Exception{ - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testReadyLocalTransactionWithImmediateCommit"); - - waitUntilLeader(shard); + public void testReadyLocalTransactionWithImmediateCommit() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testReadyLocalTransactionWithImmediateCommit"); - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); + ShardTestKit.waitUntilLeader(shard); - final DataTreeModification modification = dataStore.getDataTree().takeSnapshot().newModification(); + final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); - final ContainerNode writeData = ImmutableNodes.containerNode(TestModel.TEST_QNAME); - new WriteModification(TestModel.TEST_PATH, writeData).apply(modification); - final MapNode mergeData = ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(); - new MergeModification(TestModel.OUTER_LIST_PATH, mergeData).apply(modification); + final DataTreeModification modification = dataStore.newModification(); - final String txId = "tx1"; - modification.ready(); - final ReadyLocalTransaction readyMessage = new ReadyLocalTransaction(txId, modification, true); + final ContainerNode writeData = ImmutableNodes.containerNode(TestModel.TEST_QNAME); + new WriteModification(TestModel.TEST_PATH, writeData).apply(modification); + final MapNode mergeData = ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME) + .addChild(ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 42)) + .build(); + new MergeModification(TestModel.OUTER_LIST_PATH, mergeData).apply(modification); - shard.tell(readyMessage, getRef()); + final TransactionIdentifier txId = nextTransactionId(); + modification.ready(); + final ReadyLocalTransaction readyMessage = + new ReadyLocalTransaction(txId, modification, true, Optional.empty()); - expectMsgClass(CommitTransactionReply.SERIALIZABLE_CLASS); + shard.tell(readyMessage, testKit.getRef()); - final NormalizedNode actualNode = readStore(shard, TestModel.OUTER_LIST_PATH); - assertEquals(TestModel.OUTER_LIST_QNAME.getLocalName(), mergeData, actualNode); + testKit.expectMsgClass(CommitTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + final NormalizedNode actualNode = readStore(shard, TestModel.OUTER_LIST_PATH); + assertEquals(TestModel.OUTER_LIST_QNAME.getLocalName(), mergeData, actualNode); } @Test - public void testReadyLocalTransactionWithThreePhaseCommit() throws Exception{ - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testReadyLocalTransactionWithThreePhaseCommit"); - - waitUntilLeader(shard); + public void testReadyLocalTransactionWithThreePhaseCommit() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testReadyLocalTransactionWithThreePhaseCommit"); - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); + ShardTestKit.waitUntilLeader(shard); - final DataTreeModification modification = dataStore.getDataTree().takeSnapshot().newModification(); + final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); - final ContainerNode writeData = ImmutableNodes.containerNode(TestModel.TEST_QNAME); - new WriteModification(TestModel.TEST_PATH, writeData).apply(modification); - final MapNode mergeData = ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(); - new MergeModification(TestModel.OUTER_LIST_PATH, mergeData).apply(modification); + final DataTreeModification modification = dataStore.newModification(); - final String txId = "tx1"; - modification.ready(); - final ReadyLocalTransaction readyMessage = new ReadyLocalTransaction(txId, modification, false); + final ContainerNode writeData = ImmutableNodes.containerNode(TestModel.TEST_QNAME); + new WriteModification(TestModel.TEST_PATH, writeData).apply(modification); + final MapNode mergeData = ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME) + .addChild(ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 42)) + .build(); + new MergeModification(TestModel.OUTER_LIST_PATH, mergeData).apply(modification); - shard.tell(readyMessage, getRef()); + final TransactionIdentifier txId = nextTransactionId(); + modification.ready(); + final ReadyLocalTransaction readyMessage = + new ReadyLocalTransaction(txId, modification, false, Optional.empty()); - expectMsgClass(ReadyTransactionReply.class); + shard.tell(readyMessage, testKit.getRef()); - // Send the CanCommitTransaction message. + testKit.expectMsgClass(ReadyTransactionReply.class); - shard.tell(new CanCommitTransaction(txId).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + // Send the CanCommitTransaction message. - // Send the CanCommitTransaction message. + shard.tell(new CanCommitTransaction(txId, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(CanCommitTransactionReply.class)); + assertTrue("Can commit", canCommitReply.getCanCommit()); - shard.tell(new CommitTransaction(txId).toSerializable(), getRef()); - expectMsgClass(CommitTransactionReply.SERIALIZABLE_CLASS); + // Send the CanCommitTransaction message. - final NormalizedNode actualNode = readStore(shard, TestModel.OUTER_LIST_PATH); - assertEquals(TestModel.OUTER_LIST_QNAME.getLocalName(), mergeData, actualNode); + shard.tell(new CommitTransaction(txId, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(CommitTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + final NormalizedNode actualNode = readStore(shard, TestModel.OUTER_LIST_PATH); + assertEquals(TestModel.OUTER_LIST_QNAME.getLocalName(), mergeData, actualNode); } @Test - public void testCommitWithPersistenceDisabled() throws Throwable { + public void testReadWriteCommitWithPersistenceDisabled() { dataStoreContextBuilder.persistent(false); - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testCommitWithPersistenceDisabled"); - - waitUntilLeader(shard); - - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); - - // Setup a simulated transactions with a mock cohort. - - final String transactionID = "tx"; - final MutableCompositeModification modification = new MutableCompositeModification(); - final NormalizedNode containerNode = ImmutableNodes.containerNode(TestModel.TEST_QNAME); - final ShardDataTreeCohort cohort = setupMockWriteTransaction("cohort", dataStore, - TestModel.TEST_PATH, containerNode, modification); - - final FiniteDuration duration = duration("5 seconds"); + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testCommitWithPersistenceDisabled"); - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + ShardTestKit.waitUntilLeader(shard); - shard.tell(new ForwardedReadyTransaction(transactionID, CURRENT_VERSION, - cohort, modification, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + // Setup a simulated transactions with a mock cohort. - // Send the CanCommitTransaction message. + final Duration duration = Duration.ofSeconds(5); - shard.tell(new CanCommitTransaction(transactionID).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + final TransactionIdentifier transactionID = nextTransactionId(); + final NormalizedNode containerNode = ImmutableNodes.containerNode(TestModel.TEST_QNAME); + shard.tell(prepareBatchedModifications(transactionID, TestModel.TEST_PATH, containerNode, false), + testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Send the CanCommitTransaction message. + // Send the CanCommitTransaction message. - shard.tell(new CommitTransaction(transactionID).toSerializable(), getRef()); - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); + shard.tell(new CanCommitTransaction(transactionID, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(duration, CanCommitTransactionReply.class)); + assertTrue("Can commit", canCommitReply.getCanCommit()); - final InOrder inOrder = inOrder(cohort); - inOrder.verify(cohort).canCommit(); - inOrder.verify(cohort).preCommit(); - inOrder.verify(cohort).commit(); + // Send the CanCommitTransaction message. - final NormalizedNode actualNode = readStore(shard, TestModel.TEST_PATH); - assertEquals(TestModel.TEST_QNAME.getLocalName(), containerNode, actualNode); + shard.tell(new CommitTransaction(transactionID, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; - } - - private static DataTreeCandidateTip mockCandidate(final String name) { - final DataTreeCandidateTip mockCandidate = mock(DataTreeCandidateTip.class, name); - final DataTreeCandidateNode mockCandidateNode = mock(DataTreeCandidateNode.class, name + "-node"); - doReturn(ModificationType.WRITE).when(mockCandidateNode).getModificationType(); - doReturn(Optional.of(ImmutableNodes.containerNode(CARS_QNAME))).when(mockCandidateNode).getDataAfter(); - doReturn(YangInstanceIdentifier.builder().build()).when(mockCandidate).getRootPath(); - doReturn(mockCandidateNode).when(mockCandidate).getRootNode(); - return mockCandidate; - } - - private static DataTreeCandidateTip mockUnmodifiedCandidate(final String name) { - final DataTreeCandidateTip mockCandidate = mock(DataTreeCandidateTip.class, name); - final DataTreeCandidateNode mockCandidateNode = mock(DataTreeCandidateNode.class, name + "-node"); - doReturn(ModificationType.UNMODIFIED).when(mockCandidateNode).getModificationType(); - doReturn(YangInstanceIdentifier.builder().build()).when(mockCandidate).getRootPath(); - doReturn(mockCandidateNode).when(mockCandidate).getRootNode(); - return mockCandidate; + final NormalizedNode actualNode = readStore(shard, TestModel.TEST_PATH); + assertEquals(TestModel.TEST_QNAME.getLocalName(), containerNode, actualNode); } @Test - public void testCommitWhenTransactionHasNoModifications(){ - // Note that persistence is enabled which would normally result in the entry getting written to the journal - // but here that need not happen - new ShardTestKit(getSystem()) { - { - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testCommitWhenTransactionHasNoModifications"); - - waitUntilLeader(shard); - - final String transactionID = "tx1"; - final MutableCompositeModification modification = new MutableCompositeModification(); - final ShardDataTreeCohort cohort = mock(ShardDataTreeCohort.class, "cohort1"); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).canCommit(); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).preCommit(); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).commit(); - doReturn(mockUnmodifiedCandidate("cohort1-candidate")).when(cohort).getCandidate(); - - final FiniteDuration duration = duration("5 seconds"); - - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. - - shard.tell(new ForwardedReadyTransaction(transactionID, CURRENT_VERSION, - cohort, modification, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); - - // Send the CanCommitTransaction message. - - shard.tell(new CanCommitTransaction(transactionID).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); - - shard.tell(new CommitTransaction(transactionID).toSerializable(), getRef()); - expectMsgClass(duration, ThreePhaseCommitCohortMessages.CommitTransactionReply.class); - - final InOrder inOrder = inOrder(cohort); - inOrder.verify(cohort).canCommit(); - inOrder.verify(cohort).preCommit(); - inOrder.verify(cohort).commit(); - - shard.tell(Shard.GET_SHARD_MBEAN_MESSAGE, getRef()); - final ShardStats shardStats = expectMsgClass(duration, ShardStats.class); - - // Use MBean for verification - // Committed transaction count should increase as usual - assertEquals(1,shardStats.getCommittedTransactionsCount()); - - // Commit index should not advance because this does not go into the journal - assertEquals(-1, shardStats.getCommitIndex()); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - - } - }; + public void testReadWriteCommitWhenTransactionHasModifications() throws Exception { + testCommitWhenTransactionHasModifications(true); } @Test - public void testCommitWhenTransactionHasModifications(){ - new ShardTestKit(getSystem()) { - { - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testCommitWhenTransactionHasModifications"); - - waitUntilLeader(shard); + public void testWriteOnlyCommitWhenTransactionHasModifications() throws Exception { + testCommitWhenTransactionHasModifications(false); + } - final String transactionID = "tx1"; - final MutableCompositeModification modification = new MutableCompositeModification(); - modification.addModification(new DeleteModification(YangInstanceIdentifier.builder().build())); - final ShardDataTreeCohort cohort = mock(ShardDataTreeCohort.class, "cohort1"); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).canCommit(); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).preCommit(); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).commit(); - doReturn(mockCandidate("cohort1-candidate")).when(cohort).getCandidate(); + private void testCommitWhenTransactionHasModifications(final boolean readWrite) throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final DataTree dataTree = createDelegatingMockDataTree(); + final TestActorRef shard = actorFactory.createTestActor( + newShardBuilder().dataTree(dataTree).props().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testCommitWhenTransactionHasModifications-" + readWrite); - final FiniteDuration duration = duration("5 seconds"); + ShardTestKit.waitUntilLeader(shard); - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + final Duration duration = Duration.ofSeconds(5); + final TransactionIdentifier transactionID = nextTransactionId(); - shard.tell(new ForwardedReadyTransaction(transactionID, CURRENT_VERSION, - cohort, modification, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + if (readWrite) { + shard.tell(prepareForwardedReadyTransaction(shard, transactionID, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), false), testKit.getRef()); + } else { + shard.tell(prepareBatchedModifications(transactionID, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), false), testKit.getRef()); + } - // Send the CanCommitTransaction message. + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new CanCommitTransaction(transactionID).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + // Send the CanCommitTransaction message. - shard.tell(new CommitTransaction(transactionID).toSerializable(), getRef()); - expectMsgClass(duration, ThreePhaseCommitCohortMessages.CommitTransactionReply.class); + shard.tell(new CanCommitTransaction(transactionID, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(duration, CanCommitTransactionReply.class)); + assertTrue("Can commit", canCommitReply.getCanCommit()); - final InOrder inOrder = inOrder(cohort); - inOrder.verify(cohort).canCommit(); - inOrder.verify(cohort).preCommit(); - inOrder.verify(cohort).commit(); + shard.tell(new CommitTransaction(transactionID, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - shard.tell(Shard.GET_SHARD_MBEAN_MESSAGE, getRef()); - final ShardStats shardStats = expectMsgClass(duration, ShardStats.class); + final InOrder inOrder = inOrder(dataTree); + inOrder.verify(dataTree).validate(any(DataTreeModification.class)); + inOrder.verify(dataTree).prepare(any(DataTreeModification.class)); + inOrder.verify(dataTree).commit(any(DataTreeCandidate.class)); - // Use MBean for verification - // Committed transaction count should increase as usual - assertEquals(1, shardStats.getCommittedTransactionsCount()); + // Purge request is scheduled as asynchronous, wait for two heartbeats to let it propagate into + // the journal + Thread.sleep(HEARTBEAT_MILLIS * 2); - // Commit index should advance as we do not have an empty modification - assertEquals(0, shardStats.getCommitIndex()); + shard.tell(Shard.GET_SHARD_MBEAN_MESSAGE, testKit.getRef()); + final ShardStats shardStats = testKit.expectMsgClass(duration, ShardStats.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); + // Use MBean for verification + // Committed transaction count should increase as usual + assertEquals(1, shardStats.getCommittedTransactionsCount()); - } - }; + // Commit index should advance as we do not have an empty + // modification + assertEquals(1, shardStats.getCommitIndex()); } @Test - public void testCommitPhaseFailure() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testCommitPhaseFailure"); - - waitUntilLeader(shard); + public void testCommitPhaseFailure() throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final DataTree dataTree = createDelegatingMockDataTree(); + final TestActorRef shard = actorFactory.createTestActor( + newShardBuilder().dataTree(dataTree).props().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testCommitPhaseFailure"); - // Setup 2 simulated transactions with mock cohorts. The first one fails in the - // commit phase. + ShardTestKit.waitUntilLeader(shard); - final String transactionID1 = "tx1"; - final MutableCompositeModification modification1 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort1 = mock(ShardDataTreeCohort.class, "cohort1"); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort1).canCommit(); - doReturn(Futures.immediateFuture(null)).when(cohort1).preCommit(); - doReturn(Futures.immediateFailedFuture(new IllegalStateException("mock"))).when(cohort1).commit(); - doReturn(mockCandidate("cohort1-candidate")).when(cohort1).getCandidate(); + final Duration duration = Duration.ofSeconds(5); + final Timeout timeout = Timeout.create(duration); - final String transactionID2 = "tx2"; - final MutableCompositeModification modification2 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort2 = mock(ShardDataTreeCohort.class, "cohort2"); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort2).canCommit(); + // Setup 2 simulated transactions with mock cohorts. The first + // one fails in the + // commit phase. - final FiniteDuration duration = duration("5 seconds"); - final Timeout timeout = new Timeout(duration); + doThrow(new RuntimeException("mock commit failure")).when(dataTree) + .commit(any(DataTreeCandidate.class)); - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + final TransactionIdentifier transactionID1 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort1, modification1, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + final TransactionIdentifier transactionID2 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort2, modification2, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + // Send the CanCommitTransaction message for the first Tx. - // Send the CanCommitTransaction message for the first Tx. + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(duration, CanCommitTransactionReply.class)); + assertTrue("Can commit", canCommitReply.getCanCommit()); - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + // Send the CanCommitTransaction message for the 2nd Tx. This + // should get queued and + // processed after the first Tx completes. - // Send the CanCommitTransaction message for the 2nd Tx. This should get queued and - // processed after the first Tx completes. + final Future canCommitFuture = Patterns.ask(shard, + new CanCommitTransaction(transactionID2, CURRENT_VERSION).toSerializable(), timeout); - final Future canCommitFuture = Patterns.ask(shard, - new CanCommitTransaction(transactionID2).toSerializable(), timeout); + // Send the CommitTransaction message for the first Tx. This + // should send back an error + // and trigger the 2nd Tx to proceed. - // Send the CommitTransaction message for the first Tx. This should send back an error - // and trigger the 2nd Tx to proceed. + shard.tell(new CommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, akka.actor.Status.Failure.class); - shard.tell(new CommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, akka.actor.Status.Failure.class); + // Wait for the 2nd Tx to complete the canCommit phase. - // Wait for the 2nd Tx to complete the canCommit phase. + final CountDownLatch latch = new CountDownLatch(1); + canCommitFuture.onComplete(new OnComplete() { + @Override + public void onComplete(final Throwable failure, final Object resp) { + latch.countDown(); + } + }, getSystem().dispatcher()); - final CountDownLatch latch = new CountDownLatch(1); - canCommitFuture.onComplete(new OnComplete() { - @Override - public void onComplete(final Throwable t, final Object resp) { - latch.countDown(); - } - }, getSystem().dispatcher()); + assertTrue("2nd CanCommit complete", latch.await(5, TimeUnit.SECONDS)); - assertEquals("2nd CanCommit complete", true, latch.await(5, TimeUnit.SECONDS)); + final InOrder inOrder = inOrder(dataTree); + inOrder.verify(dataTree).validate(any(DataTreeModification.class)); + inOrder.verify(dataTree).prepare(any(DataTreeModification.class)); - final InOrder inOrder = inOrder(cohort1, cohort2); - inOrder.verify(cohort1).canCommit(); - inOrder.verify(cohort1).preCommit(); - inOrder.verify(cohort1).commit(); - inOrder.verify(cohort2).canCommit(); + // FIXME: this invocation is done on the result of validate(). To test it, we need to make sure mock + // validate performs wrapping and we capture that mock + // inOrder.verify(dataTree).validate(any(DataTreeModification.class)); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + inOrder.verify(dataTree).commit(any(DataTreeCandidate.class)); } @Test - public void testPreCommitPhaseFailure() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testPreCommitPhaseFailure"); - - waitUntilLeader(shard); + public void testPreCommitPhaseFailure() throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final DataTree dataTree = createDelegatingMockDataTree(); + final TestActorRef shard = actorFactory.createTestActor( + newShardBuilder().dataTree(dataTree).props().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testPreCommitPhaseFailure"); - final String transactionID1 = "tx1"; - final MutableCompositeModification modification1 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort1 = mock(ShardDataTreeCohort.class, "cohort1"); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort1).canCommit(); - doReturn(Futures.immediateFailedFuture(new IllegalStateException("mock"))).when(cohort1).preCommit(); + ShardTestKit.waitUntilLeader(shard); - final String transactionID2 = "tx2"; - final MutableCompositeModification modification2 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort2 = mock(ShardDataTreeCohort.class, "cohort2"); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort2).canCommit(); + final Duration duration = Duration.ofSeconds(5); + final Timeout timeout = Timeout.create(duration); - final FiniteDuration duration = duration("5 seconds"); - final Timeout timeout = new Timeout(duration); + doThrow(new RuntimeException("mock preCommit failure")).when(dataTree) + .prepare(any(DataTreeModification.class)); - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + final TransactionIdentifier transactionID1 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort1, modification1, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + final TransactionIdentifier transactionID2 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort2, modification2, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + // Send the CanCommitTransaction message for the first Tx. - // Send the CanCommitTransaction message for the first Tx. + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(duration, CanCommitTransactionReply.class)); + assertTrue("Can commit", canCommitReply.getCanCommit()); - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + // Send the CanCommitTransaction message for the 2nd Tx. This + // should get queued and + // processed after the first Tx completes. - // Send the CanCommitTransaction message for the 2nd Tx. This should get queued and - // processed after the first Tx completes. + final Future canCommitFuture = Patterns.ask(shard, + new CanCommitTransaction(transactionID2, CURRENT_VERSION).toSerializable(), timeout); - final Future canCommitFuture = Patterns.ask(shard, - new CanCommitTransaction(transactionID2).toSerializable(), timeout); + // Send the CommitTransaction message for the first Tx. This + // should send back an error + // and trigger the 2nd Tx to proceed. - // Send the CommitTransaction message for the first Tx. This should send back an error - // and trigger the 2nd Tx to proceed. + shard.tell(new CommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, akka.actor.Status.Failure.class); - shard.tell(new CommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, akka.actor.Status.Failure.class); + // Wait for the 2nd Tx to complete the canCommit phase. - // Wait for the 2nd Tx to complete the canCommit phase. - - final CountDownLatch latch = new CountDownLatch(1); - canCommitFuture.onComplete(new OnComplete() { - @Override - public void onComplete(final Throwable t, final Object resp) { - latch.countDown(); - } - }, getSystem().dispatcher()); - - assertEquals("2nd CanCommit complete", true, latch.await(5, TimeUnit.SECONDS)); + final CountDownLatch latch = new CountDownLatch(1); + canCommitFuture.onComplete(new OnComplete() { + @Override + public void onComplete(final Throwable failure, final Object resp) { + latch.countDown(); + } + }, getSystem().dispatcher()); - final InOrder inOrder = inOrder(cohort1, cohort2); - inOrder.verify(cohort1).canCommit(); - inOrder.verify(cohort1).preCommit(); - inOrder.verify(cohort2).canCommit(); + assertTrue("2nd CanCommit complete", latch.await(5, TimeUnit.SECONDS)); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + final InOrder inOrder = inOrder(dataTree); + inOrder.verify(dataTree).validate(any(DataTreeModification.class)); + inOrder.verify(dataTree).prepare(any(DataTreeModification.class)); + inOrder.verify(dataTree).validate(any(DataTreeModification.class)); } @Test - public void testCanCommitPhaseFailure() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testCanCommitPhaseFailure"); - - waitUntilLeader(shard); + public void testCanCommitPhaseFailure() throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final DataTree dataTree = createDelegatingMockDataTree(); + final TestActorRef shard = actorFactory.createTestActor( + newShardBuilder().dataTree(dataTree).props().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testCanCommitPhaseFailure"); - final FiniteDuration duration = duration("5 seconds"); + ShardTestKit.waitUntilLeader(shard); - final String transactionID1 = "tx1"; - final MutableCompositeModification modification = new MutableCompositeModification(); - final ShardDataTreeCohort cohort = mock(ShardDataTreeCohort.class, "cohort1"); - doReturn(Futures.immediateFailedFuture(new IllegalStateException("mock"))).when(cohort).canCommit(); + final Duration duration = Duration.ofSeconds(5); + final TransactionIdentifier transactionID1 = nextTransactionId(); - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + doThrow(new DataValidationFailedException(YangInstanceIdentifier.EMPTY, "mock canCommit failure")) + .doNothing().when(dataTree).validate(any(DataTreeModification.class)); - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort, modification, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + shard.tell(newBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Send the CanCommitTransaction message. + // Send the CanCommitTransaction message. - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, akka.actor.Status.Failure.class); + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, akka.actor.Status.Failure.class); - // Send another can commit to ensure the failed one got cleaned up. + // Send another can commit to ensure the failed one got cleaned + // up. - reset(cohort); + final TransactionIdentifier transactionID2 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - final String transactionID2 = "tx2"; - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).canCommit(); - - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort, modification, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); - - shard.tell(new CanCommitTransaction(transactionID2).toSerializable(), getRef()); - final CanCommitTransactionReply reply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("getCanCommit", true, reply.getCanCommit()); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + shard.tell(new CanCommitTransaction(transactionID2, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final CanCommitTransactionReply reply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(CanCommitTransactionReply.class)); + assertTrue("getCanCommit", reply.getCanCommit()); } @Test - public void testCanCommitPhaseFalseResponse() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testCanCommitPhaseFalseResponse"); - - waitUntilLeader(shard); - - final FiniteDuration duration = duration("5 seconds"); - - final String transactionID1 = "tx1"; - final MutableCompositeModification modification = new MutableCompositeModification(); - final ShardDataTreeCohort cohort = mock(ShardDataTreeCohort.class, "cohort1"); - doReturn(Futures.immediateFuture(Boolean.FALSE)).when(cohort).canCommit(); + public void testImmediateCommitWithCanCommitPhaseFailure() throws Exception { + testImmediateCommitWithCanCommitPhaseFailure(true); + testImmediateCommitWithCanCommitPhaseFailure(false); + } - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + private void testImmediateCommitWithCanCommitPhaseFailure(final boolean readWrite) throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final DataTree dataTree = createDelegatingMockDataTree(); + final TestActorRef shard = actorFactory.createTestActor( + newShardBuilder().dataTree(dataTree).props().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testImmediateCommitWithCanCommitPhaseFailure-" + readWrite); - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort, modification, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + ShardTestKit.waitUntilLeader(shard); - // Send the CanCommitTransaction message. + doThrow(new DataValidationFailedException(YangInstanceIdentifier.EMPTY, "mock canCommit failure")) + .doNothing().when(dataTree).validate(any(DataTreeModification.class)); - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - CanCommitTransactionReply reply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("getCanCommit", false, reply.getCanCommit()); + final Duration duration = Duration.ofSeconds(5); - // Send another can commit to ensure the failed one got cleaned up. + final TransactionIdentifier transactionID1 = nextTransactionId(); - reset(cohort); + if (readWrite) { + shard.tell(prepareForwardedReadyTransaction(shard, transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true), testKit.getRef()); + } else { + shard.tell(prepareBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true), testKit.getRef()); + } - final String transactionID2 = "tx2"; - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).canCommit(); + testKit.expectMsgClass(duration, akka.actor.Status.Failure.class); - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort, modification, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + // Send another can commit to ensure the failed one got cleaned + // up. - shard.tell(new CanCommitTransaction(transactionID2).toSerializable(), getRef()); - reply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("getCanCommit", true, reply.getCanCommit()); + final TransactionIdentifier transactionID2 = nextTransactionId(); + if (readWrite) { + shard.tell(prepareForwardedReadyTransaction(shard, transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true), testKit.getRef()); + } else { + shard.tell(prepareBatchedModifications(transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true), testKit.getRef()); + } - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + testKit.expectMsgClass(duration, CommitTransactionReply.class); } @Test - public void testImmediateCommitWithCanCommitPhaseFailure() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testImmediateCommitWithCanCommitPhaseFailure"); - - waitUntilLeader(shard); - - final FiniteDuration duration = duration("5 seconds"); - - final String transactionID1 = "tx1"; - final MutableCompositeModification modification = new MutableCompositeModification(); - final ShardDataTreeCohort cohort = mock(ShardDataTreeCohort.class, "cohort1"); - doReturn(Futures.immediateFailedFuture(new IllegalStateException("mock"))).when(cohort).canCommit(); + public void testAbortWithCommitPending() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final Creator creator = () -> new Shard(newShardBuilder()) { + @Override + void persistPayload(final Identifier id, final Payload payload, + final boolean batchHint) { + // Simulate an AbortTransaction message occurring during + // replication, after + // persisting and before finishing the commit to the + // in-memory store. + + doAbortTransaction(id, null); + super.persistPayload(id, payload, batchHint); + } + }; - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + final TestActorRef shard = actorFactory.createTestActor(Props + .create(new DelegatingShardCreator(creator)).withDispatcher(Dispatchers.DefaultDispatcherId()), + "testAbortWithCommitPending"); - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort, modification, true, true), getRef()); + ShardTestKit.waitUntilLeader(shard); - expectMsgClass(duration, akka.actor.Status.Failure.class); + final Duration duration = Duration.ofSeconds(5); - // Send another can commit to ensure the failed one got cleaned up. + final TransactionIdentifier transactionID = nextTransactionId(); - reset(cohort); + shard.tell(prepareBatchedModifications(transactionID, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), false), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - final String transactionID2 = "tx2"; - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).canCommit(); - doReturn(Futures.immediateFuture(null)).when(cohort).preCommit(); - doReturn(Futures.immediateFuture(null)).when(cohort).commit(); - final DataTreeCandidateTip candidate = mock(DataTreeCandidateTip.class); - final DataTreeCandidateNode candidateRoot = mock(DataTreeCandidateNode.class); - doReturn(ModificationType.UNMODIFIED).when(candidateRoot).getModificationType(); - doReturn(candidateRoot).when(candidate).getRootNode(); - doReturn(candidate).when(cohort).getCandidate(); + shard.tell(new CanCommitTransaction(transactionID, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CanCommitTransactionReply.class); - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort, modification, true, true), getRef()); + shard.tell(new CommitTransaction(transactionID, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); + final NormalizedNode node = readStore(shard, TestModel.TEST_PATH); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + // Since we're simulating an abort occurring during replication + // and before finish commit, + // the data should still get written to the in-memory store + // since we've gotten past + // canCommit and preCommit and persisted the data. + assertNotNull(TestModel.TEST_QNAME.getLocalName() + " not found", node); } @Test - public void testImmediateCommitWithCanCommitPhaseFalseResponse() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testImmediateCommitWithCanCommitPhaseFalseResponse"); - - waitUntilLeader(shard); - - final FiniteDuration duration = duration("5 seconds"); - - final String transactionID = "tx1"; - final MutableCompositeModification modification = new MutableCompositeModification(); - final ShardDataTreeCohort cohort = mock(ShardDataTreeCohort.class, "cohort1"); - doReturn(Futures.immediateFuture(Boolean.FALSE)).when(cohort).canCommit(); + public void testTransactionCommitTimeout() throws Exception { + dataStoreContextBuilder.shardTransactionCommitTimeoutInSeconds(1); + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testTransactionCommitTimeout"); - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + ShardTestKit.waitUntilLeader(shard); - shard.tell(new ForwardedReadyTransaction(transactionID, CURRENT_VERSION, - cohort, modification, true, true), getRef()); + final Duration duration = Duration.ofSeconds(5); - expectMsgClass(duration, akka.actor.Status.Failure.class); + writeToStore(shard, TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); + writeToStore(shard, TestModel.OUTER_LIST_PATH, + ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build()); - // Send another can commit to ensure the failed one got cleaned up. + // Ready 2 Tx's - the first will timeout - reset(cohort); + final TransactionIdentifier transactionID1 = nextTransactionId(); + shard.tell( + prepareBatchedModifications(transactionID1, + YangInstanceIdentifier.builder(TestModel.OUTER_LIST_PATH) + .nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1).build(), + ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1), false), + testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - final String transactionID2 = "tx2"; - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort).canCommit(); - doReturn(Futures.immediateFuture(null)).when(cohort).preCommit(); - doReturn(Futures.immediateFuture(null)).when(cohort).commit(); - final DataTreeCandidateTip candidate = mock(DataTreeCandidateTip.class); - final DataTreeCandidateNode candidateRoot = mock(DataTreeCandidateNode.class); - doReturn(ModificationType.UNMODIFIED).when(candidateRoot).getModificationType(); - doReturn(candidateRoot).when(candidate).getRootNode(); - doReturn(candidate).when(cohort).getCandidate(); + final TransactionIdentifier transactionID2 = nextTransactionId(); + final YangInstanceIdentifier listNodePath = YangInstanceIdentifier.builder(TestModel.OUTER_LIST_PATH) + .nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 2).build(); + shard.tell( + prepareBatchedModifications(transactionID2, listNodePath, + ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 2), false), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort, modification, true, true), getRef()); + // canCommit 1st Tx. We don't send the commit so it should + // timeout. - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CanCommitTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; - } + // canCommit the 2nd Tx - it should complete after the 1st Tx + // times out. - @Test - public void testAbortBeforeFinishCommit() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testAbortBeforeFinishCommit"); - - waitUntilLeader(shard); - - final FiniteDuration duration = duration("5 seconds"); - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); - - final String transactionID = "tx1"; - final Function> preCommit = - new Function>() { - @Override - public ListenableFuture apply(final ShardDataTreeCohort cohort) { - final ListenableFuture preCommitFuture = cohort.preCommit(); - - // Simulate an AbortTransaction message occurring during replication, after - // persisting and before finishing the commit to the in-memory store. - // We have no followers so due to optimizations in the RaftActor, it does not - // attempt replication and thus we can't send an AbortTransaction message b/c - // it would be processed too late after CommitTransaction completes. So we'll - // simulate an AbortTransaction message occurring during replication by calling - // the shard directly. - // - shard.underlyingActor().doAbortTransaction(transactionID, null); - - return preCommitFuture; - } - }; + shard.tell(new CanCommitTransaction(transactionID2, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CanCommitTransactionReply.class); - final MutableCompositeModification modification = new MutableCompositeModification(); - final ShardDataTreeCohort cohort = setupMockWriteTransaction("cohort1", dataStore, - TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), - modification, preCommit); + // Try to commit the 1st Tx - should fail as it's not the + // current Tx. - shard.tell(new ForwardedReadyTransaction(transactionID, CURRENT_VERSION, - cohort, modification, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + shard.tell(new CommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, akka.actor.Status.Failure.class); - shard.tell(new CanCommitTransaction(transactionID).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + // Commit the 2nd Tx. - shard.tell(new CommitTransaction(transactionID).toSerializable(), getRef()); - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); + shard.tell(new CommitTransaction(transactionID2, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - final NormalizedNode node = readStore(shard, TestModel.TEST_PATH); - - // Since we're simulating an abort occurring during replication and before finish commit, - // the data should still get written to the in-memory store since we've gotten past - // canCommit and preCommit and persisted the data. - assertNotNull(TestModel.TEST_QNAME.getLocalName() + " not found", node); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + final NormalizedNode node = readStore(shard, listNodePath); + assertNotNull(listNodePath + " not found", node); } +// @Test +// @Ignore +// public void testTransactionCommitQueueCapacityExceeded() throws Throwable { +// dataStoreContextBuilder.shardTransactionCommitQueueCapacity(2); +// +// new ShardTestKit(getSystem()) {{ +// final TestActorRef shard = actorFactory.createTestActor( +// newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), +// "testTransactionCommitQueueCapacityExceeded"); +// +// waitUntilLeader(shard); +// +// final FiniteDuration duration = duration("5 seconds"); +// +// final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); +// +// final TransactionIdentifier transactionID1 = nextTransactionId(); +// final MutableCompositeModification modification1 = new MutableCompositeModification(); +// final ShardDataTreeCohort cohort1 = setupMockWriteTransaction("cohort1", dataStore, +// TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), transactionID1, +// modification1); +// +// final TransactionIdentifier transactionID2 = nextTransactionId(); +// final MutableCompositeModification modification2 = new MutableCompositeModification(); +// final ShardDataTreeCohort cohort2 = setupMockWriteTransaction("cohort2", dataStore, +// TestModel.OUTER_LIST_PATH, +// ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(), transactionID2, +// modification2); +// +// final TransactionIdentifier transactionID3 = nextTransactionId(); +// final MutableCompositeModification modification3 = new MutableCompositeModification(); +// final ShardDataTreeCohort cohort3 = setupMockWriteTransaction("cohort3", dataStore, +// TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), transactionID3, +// modification3); +// +// // Ready the Tx's +// +// shard.tell(prepareReadyTransactionMessage(false, shard.underlyingActor(), cohort1, transactionID1, +// modification1), getRef()); +// expectMsgClass(duration, ReadyTransactionReply.class); +// +// shard.tell(prepareReadyTransactionMessage(false, shard.underlyingActor(), cohort2, transactionID2, +// modification2), getRef()); +// expectMsgClass(duration, ReadyTransactionReply.class); +// +// // The 3rd Tx should exceed queue capacity and fail. +// +// shard.tell(prepareReadyTransactionMessage(false, shard.underlyingActor(), cohort3, transactionID3, +// modification3), getRef()); +// expectMsgClass(duration, akka.actor.Status.Failure.class); +// +// // canCommit 1st Tx. +// +// shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), getRef()); +// expectMsgClass(duration, CanCommitTransactionReply.class); +// +// // canCommit the 2nd Tx - it should get queued. +// +// shard.tell(new CanCommitTransaction(transactionID2, CURRENT_VERSION).toSerializable(), getRef()); +// +// // canCommit the 3rd Tx - should exceed queue capacity and fail. +// +// shard.tell(new CanCommitTransaction(transactionID3, CURRENT_VERSION).toSerializable(), getRef()); +// expectMsgClass(duration, akka.actor.Status.Failure.class); +// }}; +// } + @Test - public void testTransactionCommitTimeout() throws Throwable { + public void testTransactionCommitWithPriorExpiredCohortEntries() { dataStoreContextBuilder.shardTransactionCommitTimeoutInSeconds(1); + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testTransactionCommitWithPriorExpiredCohortEntries"); - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testTransactionCommitTimeout"); - - waitUntilLeader(shard); - - final FiniteDuration duration = duration("5 seconds"); + ShardTestKit.waitUntilLeader(shard); - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); + final Duration duration = Duration.ofSeconds(5); - writeToStore(shard, TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); - writeToStore(shard, TestModel.OUTER_LIST_PATH, - ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build()); + final TransactionIdentifier transactionID1 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Create 1st Tx - will timeout + final TransactionIdentifier transactionID2 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - final String transactionID1 = "tx1"; - final MutableCompositeModification modification1 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort1 = setupMockWriteTransaction("cohort1", dataStore, - YangInstanceIdentifier.builder(TestModel.OUTER_LIST_PATH) - .nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1).build(), - ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 1), - modification1); + final TransactionIdentifier transactionID3 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID3, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Create 2nd Tx + // All Tx's are readied. We'll send canCommit for the last one + // but not the others. The others + // should expire from the queue and the last one should be + // processed. - final String transactionID2 = "tx3"; - final MutableCompositeModification modification2 = new MutableCompositeModification(); - final YangInstanceIdentifier listNodePath = YangInstanceIdentifier.builder(TestModel.OUTER_LIST_PATH) - .nodeWithKey(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 2).build(); - final ShardDataTreeCohort cohort2 = setupMockWriteTransaction("cohort3", dataStore, - listNodePath, - ImmutableNodes.mapEntry(TestModel.OUTER_LIST_QNAME, TestModel.ID_QNAME, 2), - modification2); - - // Ready the Tx's - - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort1, modification1, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); - - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort2, modification2, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); - - // canCommit 1st Tx. We don't send the commit so it should timeout. - - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS); - - // canCommit the 2nd Tx - it should complete after the 1st Tx times out. - - shard.tell(new CanCommitTransaction(transactionID2).toSerializable(), getRef()); - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS); - - // Try to commit the 1st Tx - should fail as it's not the current Tx. - - shard.tell(new CommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, akka.actor.Status.Failure.class); - - // Commit the 2nd Tx. - - shard.tell(new CommitTransaction(transactionID2).toSerializable(), getRef()); - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); - - final NormalizedNode node = readStore(shard, listNodePath); - assertNotNull(listNodePath + " not found", node); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + shard.tell(new CanCommitTransaction(transactionID3, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CanCommitTransactionReply.class); } @Test - public void testTransactionCommitQueueCapacityExceeded() throws Throwable { - dataStoreContextBuilder.shardTransactionCommitQueueCapacity(2); - - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testTransactionCommitQueueCapacityExceeded"); - - waitUntilLeader(shard); - - final FiniteDuration duration = duration("5 seconds"); - - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); + public void testTransactionCommitWithSubsequentExpiredCohortEntry() { + dataStoreContextBuilder.shardTransactionCommitTimeoutInSeconds(1); + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testTransactionCommitWithSubsequentExpiredCohortEntry"); - final String transactionID1 = "tx1"; - final MutableCompositeModification modification1 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort1 = setupMockWriteTransaction("cohort1", dataStore, - TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), modification1); + ShardTestKit.waitUntilLeader(shard); - final String transactionID2 = "tx2"; - final MutableCompositeModification modification2 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort2 = setupMockWriteTransaction("cohort2", dataStore, - TestModel.OUTER_LIST_PATH, - ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(), - modification2); + final Duration duration = Duration.ofSeconds(5); - final String transactionID3 = "tx3"; - final MutableCompositeModification modification3 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort3 = setupMockWriteTransaction("cohort3", dataStore, - TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), modification3); + final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); - // Ready the Tx's + final TransactionIdentifier transactionID1 = nextTransactionId(); + shard.tell(prepareBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), false), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort1, modification1, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + // CanCommit the first Tx so it's the current in-progress Tx. - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort2, modification2, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CanCommitTransactionReply.class); - // The 3rd Tx should exceed queue capacity and fail. + // Ready the second Tx. - shard.tell(new ForwardedReadyTransaction(transactionID3, CURRENT_VERSION, - cohort3, modification3, true, false), getRef()); - expectMsgClass(duration, akka.actor.Status.Failure.class); + final TransactionIdentifier transactionID2 = nextTransactionId(); + shard.tell(prepareBatchedModifications(transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), false), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // canCommit 1st Tx. + // Ready the third Tx. - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS); + final TransactionIdentifier transactionID3 = nextTransactionId(); + final DataTreeModification modification3 = dataStore.newModification(); + new WriteModification(TestModel.TEST2_PATH, ImmutableNodes.containerNode(TestModel.TEST2_QNAME)) + .apply(modification3); + modification3.ready(); + final ReadyLocalTransaction readyMessage = new ReadyLocalTransaction(transactionID3, modification3, + true, Optional.empty()); + shard.tell(readyMessage, testKit.getRef()); - // canCommit the 2nd Tx - it should get queued. + // Commit the first Tx. After completing, the second should + // expire from the queue and the third + // Tx committed. - shard.tell(new CanCommitTransaction(transactionID2).toSerializable(), getRef()); + shard.tell(new CommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - // canCommit the 3rd Tx - should exceed queue capacity and fail. + // Expect commit reply from the third Tx. - shard.tell(new CanCommitTransaction(transactionID3).toSerializable(), getRef()); - expectMsgClass(duration, akka.actor.Status.Failure.class); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + final NormalizedNode node = readStore(shard, TestModel.TEST2_PATH); + assertNotNull(TestModel.TEST2_PATH + " not found", node); } @Test - public void testTransactionCommitWithPriorExpiredCohortEntries() throws Throwable { - dataStoreContextBuilder.shardCommitQueueExpiryTimeoutInMillis(1300).shardTransactionCommitTimeoutInSeconds(1); - - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testTransactionCommitWithPriorExpiredCohortEntries"); - - waitUntilLeader(shard); - - final FiniteDuration duration = duration("5 seconds"); - - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); - - final String transactionID1 = "tx1"; - final MutableCompositeModification modification1 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort1 = setupMockWriteTransaction("cohort1", dataStore, - TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), modification1); - - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort1, modification1, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); - - final String transactionID2 = "tx2"; - final MutableCompositeModification modification2 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort2 = setupMockWriteTransaction("cohort2", dataStore, - TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), modification2); - - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort2, modification2, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); - - final String transactionID3 = "tx3"; - final MutableCompositeModification modification3 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort3 = setupMockWriteTransaction("cohort3", dataStore, - TestModel.TEST2_PATH, ImmutableNodes.containerNode(TestModel.TEST2_QNAME), modification3); - - shard.tell(new ForwardedReadyTransaction(transactionID3, CURRENT_VERSION, - cohort3, modification3, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); - - // All Tx's are readied. We'll send canCommit for the last one but not the others. The others - // should expire from the queue and the last one should be processed. - - shard.tell(new CanCommitTransaction(transactionID3).toSerializable(), getRef()); - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + public void testCanCommitBeforeReadyFailure() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testCanCommitBeforeReadyFailure"); + + shard.tell(new CanCommitTransaction(nextTransactionId(), CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(Duration.ofSeconds(5), akka.actor.Status.Failure.class); } @Test - public void testTransactionCommitWithSubsequentExpiredCohortEntry() throws Throwable { - dataStoreContextBuilder.shardCommitQueueExpiryTimeoutInMillis(1300).shardTransactionCommitTimeoutInSeconds(1); - - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testTransactionCommitWithSubsequentExpiredCohortEntry"); - - waitUntilLeader(shard); - - final FiniteDuration duration = duration("5 seconds"); + public void testAbortAfterCanCommit() throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), "testAbortAfterCanCommit"); - final ShardDataTree dataStore = shard.underlyingActor().getDataStore(); + ShardTestKit.waitUntilLeader(shard); - final String transactionID1 = "tx1"; - final MutableCompositeModification modification1 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort1 = setupMockWriteTransaction("cohort1", dataStore, - TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), modification1); + final Duration duration = Duration.ofSeconds(5); + final Timeout timeout = Timeout.create(duration); - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort1, modification1, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + // Ready 2 transactions - the first one will be aborted. - // CanCommit the first one so it's the current in-progress CohortEntry. + final TransactionIdentifier transactionID1 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS); + final TransactionIdentifier transactionID2 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Ready the second Tx. + // Send the CanCommitTransaction message for the first Tx. - final String transactionID2 = "tx2"; - final MutableCompositeModification modification2 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort2 = setupMockWriteTransaction("cohort2", dataStore, - TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME), modification2); + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + CanCommitTransactionReply canCommitReply = CanCommitTransactionReply + .fromSerializable(testKit.expectMsgClass(duration, CanCommitTransactionReply.class)); + assertTrue("Can commit", canCommitReply.getCanCommit()); - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort2, modification2, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + // Send the CanCommitTransaction message for the 2nd Tx. This + // should get queued and + // processed after the first Tx completes. - // Ready the third Tx. + final Future canCommitFuture = Patterns.ask(shard, + new CanCommitTransaction(transactionID2, CURRENT_VERSION).toSerializable(), timeout); - final String transactionID3 = "tx3"; - final DataTreeModification modification3 = dataStore.getDataTree().takeSnapshot().newModification(); - new WriteModification(TestModel.TEST2_PATH, ImmutableNodes.containerNode(TestModel.TEST2_QNAME)) - .apply(modification3); - modification3.ready(); - final ReadyLocalTransaction readyMessage = new ReadyLocalTransaction(transactionID3, modification3, true); + // Send the AbortTransaction message for the first Tx. This + // should trigger the 2nd + // Tx to proceed. - shard.tell(readyMessage, getRef()); + shard.tell(new AbortTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, AbortTransactionReply.class); - // Commit the first Tx. After completing, the second should expire from the queue and the third - // Tx committed. + // Wait for the 2nd Tx to complete the canCommit phase. - shard.tell(new CommitTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); - - // Expect commit reply from the third Tx. - - expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS); - - final NormalizedNode node = readStore(shard, TestModel.TEST2_PATH); - assertNotNull(TestModel.TEST2_PATH + " not found", node); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + canCommitReply = (CanCommitTransactionReply) Await.result(canCommitFuture, + FiniteDuration.create(5, TimeUnit.SECONDS)); + assertTrue("Can commit", canCommitReply.getCanCommit()); } @Test - public void testCanCommitBeforeReadyFailure() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testCanCommitBeforeReadyFailure"); - - shard.tell(new CanCommitTransaction("tx").toSerializable(), getRef()); - expectMsgClass(duration("5 seconds"), akka.actor.Status.Failure.class); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; - } - - @Test - public void testAbortCurrentTransaction() throws Throwable { - new ShardTestKit(getSystem()) {{ - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testAbortCurrentTransaction"); - - waitUntilLeader(shard); - - // Setup 2 simulated transactions with mock cohorts. The first one will be aborted. - - final String transactionID1 = "tx1"; - final MutableCompositeModification modification1 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort1 = mock(ShardDataTreeCohort.class, "cohort1"); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort1).canCommit(); - doReturn(Futures.immediateFuture(null)).when(cohort1).abort(); - - final String transactionID2 = "tx2"; - final MutableCompositeModification modification2 = new MutableCompositeModification(); - final ShardDataTreeCohort cohort2 = mock(ShardDataTreeCohort.class, "cohort2"); - doReturn(Futures.immediateFuture(Boolean.TRUE)).when(cohort2).canCommit(); - - final FiniteDuration duration = duration("5 seconds"); - final Timeout timeout = new Timeout(duration); - - // Simulate the ForwardedReadyTransaction messages that would be sent - // by the ShardTransaction. + public void testAbortAfterReady() { + dataStoreContextBuilder.shardTransactionCommitTimeoutInSeconds(1); + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), "testAbortAfterReady"); - shard.tell(new ForwardedReadyTransaction(transactionID1, CURRENT_VERSION, - cohort1, modification1, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + ShardTestKit.waitUntilLeader(shard); - shard.tell(new ForwardedReadyTransaction(transactionID2, CURRENT_VERSION, - cohort2, modification2, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + final Duration duration = Duration.ofSeconds(5); - // Send the CanCommitTransaction message for the first Tx. + // Ready a tx. - shard.tell(new CanCommitTransaction(transactionID1).toSerializable(), getRef()); - final CanCommitTransactionReply canCommitReply = CanCommitTransactionReply.fromSerializable( - expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS)); - assertEquals("Can commit", true, canCommitReply.getCanCommit()); + final TransactionIdentifier transactionID1 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Send the CanCommitTransaction message for the 2nd Tx. This should get queued and - // processed after the first Tx completes. + // Send the AbortTransaction message. - final Future canCommitFuture = Patterns.ask(shard, - new CanCommitTransaction(transactionID2).toSerializable(), timeout); + shard.tell(new AbortTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, AbortTransactionReply.class); - // Send the AbortTransaction message for the first Tx. This should trigger the 2nd - // Tx to proceed. + assertEquals("getPendingTxCommitQueueSize", 0, shard.underlyingActor().getPendingTxCommitQueueSize()); - shard.tell(new AbortTransaction(transactionID1).toSerializable(), getRef()); - expectMsgClass(duration, AbortTransactionReply.SERIALIZABLE_CLASS); + // Now send CanCommitTransaction - should fail. - // Wait for the 2nd Tx to complete the canCommit phase. + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + final Throwable failure = testKit.expectMsgClass(duration, akka.actor.Status.Failure.class).cause(); + assertTrue("Failure type", failure instanceof IllegalStateException); - Await.ready(canCommitFuture, duration); + // Ready and CanCommit another and verify success. - final InOrder inOrder = inOrder(cohort1, cohort2); - inOrder.verify(cohort1).canCommit(); - inOrder.verify(cohort2).canCommit(); + final TransactionIdentifier transactionID2 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + shard.tell(new CanCommitTransaction(transactionID2, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CanCommitTransactionReply.class); } @Test - public void testAbortQueuedTransaction() throws Throwable { - dataStoreContextBuilder.shardTransactionCommitTimeoutInSeconds(1); - new ShardTestKit(getSystem()) {{ - final AtomicReference cleaupCheckLatch = new AtomicReference<>(); - @SuppressWarnings("serial") - final Creator creator = new Creator() { - @Override - public Shard create() throws Exception { - return new Shard(shardID, Collections.emptyMap(), - dataStoreContextBuilder.build(), SCHEMA_CONTEXT) { - @Override - public void onReceiveCommand(final Object message) throws Exception { - super.onReceiveCommand(message); - if(message.equals(TX_COMMIT_TIMEOUT_CHECK_MESSAGE)) { - if(cleaupCheckLatch.get() != null) { - cleaupCheckLatch.get().countDown(); - } - } - } - }; - } - }; - - final TestActorRef shard = TestActorRef.create(getSystem(), - Props.create(new DelegatingShardCreator(creator)).withDispatcher( - Dispatchers.DefaultDispatcherId()), "testAbortQueuedTransaction"); - - waitUntilLeader(shard); - - final String transactionID = "tx1"; - - final MutableCompositeModification modification = new MutableCompositeModification(); - final ShardDataTreeCohort cohort = mock(ShardDataTreeCohort.class, "cohort"); - doReturn(Futures.immediateFuture(null)).when(cohort).abort(); + public void testAbortQueuedTransaction() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), "testAbortAfterReady"); - final FiniteDuration duration = duration("5 seconds"); + ShardTestKit.waitUntilLeader(shard); - // Ready the tx. + final Duration duration = Duration.ofSeconds(5); - shard.tell(new ForwardedReadyTransaction(transactionID, CURRENT_VERSION, - cohort, modification, true, false), getRef()); - expectMsgClass(duration, ReadyTransactionReply.class); + // Ready 3 tx's. - assertEquals("getPendingTxCommitQueueSize", 1, shard.underlyingActor().getPendingTxCommitQueueSize()); + final TransactionIdentifier transactionID1 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID1, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - // Send the AbortTransaction message. + final TransactionIdentifier transactionID2 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID2, TestModel.TEST_PATH, + ImmutableNodes.containerNode(TestModel.TEST_QNAME), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - shard.tell(new AbortTransaction(transactionID).toSerializable(), getRef()); - expectMsgClass(duration, AbortTransactionReply.SERIALIZABLE_CLASS); + final TransactionIdentifier transactionID3 = nextTransactionId(); + shard.tell(newBatchedModifications(transactionID3, TestModel.OUTER_LIST_PATH, + ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build(), true, false, 1), testKit.getRef()); + testKit.expectMsgClass(duration, ReadyTransactionReply.class); - verify(cohort).abort(); + // Abort the second tx while it's queued. - // Verify the tx cohort is removed from queue at the cleanup check interval. + shard.tell(new AbortTransaction(transactionID2, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, AbortTransactionReply.class); - cleaupCheckLatch.set(new CountDownLatch(1)); - assertEquals("TX_COMMIT_TIMEOUT_CHECK_MESSAGE received", true, - cleaupCheckLatch.get().await(5, TimeUnit.SECONDS)); + // Commit the other 2. - assertEquals("getPendingTxCommitQueueSize", 0, shard.underlyingActor().getPendingTxCommitQueueSize()); + shard.tell(new CanCommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CanCommitTransactionReply.class); - // Now send CanCommitTransaction - should fail. + shard.tell(new CommitTransaction(transactionID1, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - shard.tell(new CanCommitTransaction(transactionID).toSerializable(), getRef()); + shard.tell(new CanCommitTransaction(transactionID3, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CanCommitTransactionReply.class); - Throwable failure = expectMsgClass(duration, akka.actor.Status.Failure.class).cause(); - assertTrue("Failure type", failure instanceof IllegalStateException); + shard.tell(new CommitTransaction(transactionID3, CURRENT_VERSION).toSerializable(), testKit.getRef()); + testKit.expectMsgClass(duration, CommitTransactionReply.class); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; - } - - @Test - public void testCreateSnapshot() throws Exception { - testCreateSnapshot(true, "testCreateSnapshot"); + assertEquals("getPendingTxCommitQueueSize", 0, shard.underlyingActor().getPendingTxCommitQueueSize()); } @Test @@ -2273,9 +1671,12 @@ public class ShardTest extends AbstractShardTest { testCreateSnapshot(false, "testCreateSnapshotWithNonPersistentData"); } - @SuppressWarnings("serial") - public void testCreateSnapshot(final boolean persistent, final String shardActorName) throws Exception{ + @Test + public void testCreateSnapshot() throws Exception { + testCreateSnapshot(true, "testCreateSnapshot"); + } + private void testCreateSnapshot(final boolean persistent, final String shardActorName) throws Exception { final AtomicReference latch = new AtomicReference<>(new CountDownLatch(1)); final AtomicReference savedSnapshot = new AtomicReference<>(); @@ -2285,98 +1686,82 @@ public class ShardTest extends AbstractShardTest { } @Override - public void saveSnapshot(final Object o) { - savedSnapshot.set(o); - super.saveSnapshot(o); + public void saveSnapshot(final Object obj) { + savedSnapshot.set(obj); + super.saveSnapshot(obj); } } dataStoreContextBuilder.persistent(persistent); - new ShardTestKit(getSystem()) {{ - class TestShard extends Shard { - - protected TestShard(final ShardIdentifier name, final Map peerAddresses, - final DatastoreContext datastoreContext, final SchemaContext schemaContext) { - super(name, peerAddresses, datastoreContext, schemaContext); - setPersistence(new TestPersistentDataProvider(super.persistence())); - } + class TestShard extends Shard { - @Override - public void handleCommand(final Object message) { - super.handleCommand(message); + protected TestShard(final AbstractBuilder builder) { + super(builder); + setPersistence(new TestPersistentDataProvider(super.persistence())); + } - if (message instanceof SaveSnapshotSuccess || message.equals("commit_snapshot")) { - latch.get().countDown(); - } - } + @Override + public void handleCommand(final Object message) { + super.handleCommand(message); - @Override - public RaftActorContext getRaftActorContext() { - return super.getRaftActorContext(); + // XXX: commit_snapshot equality check references RaftActorSnapshotMessageSupport.COMMIT_SNAPSHOT + if (message instanceof SaveSnapshotSuccess || "commit_snapshot".equals(message.toString())) { + latch.get().countDown(); } } - final Creator creator = new Creator() { - @Override - public Shard create() throws Exception { - return new TestShard(shardID, Collections.emptyMap(), - newDatastoreContext(), SCHEMA_CONTEXT); - } - }; - - final TestActorRef shard = TestActorRef.create(getSystem(), - Props.create(new DelegatingShardCreator(creator)), shardActorName); - - waitUntilLeader(shard); - - writeToStore(shard, TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); - - final NormalizedNode expectedRoot = readStore(shard, YangInstanceIdentifier.builder().build()); - - // Trigger creation of a snapshot by ensuring - final RaftActorContext raftActorContext = ((TestShard) shard.underlyingActor()).getRaftActorContext(); - raftActorContext.getSnapshotManager().capture(mock(ReplicatedLogEntry.class), -1); - - assertEquals("Snapshot saved", true, latch.get().await(5, TimeUnit.SECONDS)); + @Override + public RaftActorContext getRaftActorContext() { + return super.getRaftActorContext(); + } + } - assertTrue("Invalid saved snapshot " + savedSnapshot.get(), - savedSnapshot.get() instanceof Snapshot); + final Creator creator = () -> new TestShard(newShardBuilder()); - verifySnapshot((Snapshot)savedSnapshot.get(), expectedRoot); + final TestActorRef shard = actorFactory.createTestActor(Props + .create(new DelegatingShardCreator(creator)).withDispatcher(Dispatchers.DefaultDispatcherId()), + shardActorName); - latch.set(new CountDownLatch(1)); - savedSnapshot.set(null); + ShardTestKit.waitUntilLeader(shard); + writeToStore(shard, TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); - raftActorContext.getSnapshotManager().capture(mock(ReplicatedLogEntry.class), -1); + final NormalizedNode expectedRoot = readStore(shard, YangInstanceIdentifier.EMPTY); - assertEquals("Snapshot saved", true, latch.get().await(5, TimeUnit.SECONDS)); + // Trigger creation of a snapshot by ensuring + final RaftActorContext raftActorContext = ((TestShard) shard.underlyingActor()).getRaftActorContext(); + raftActorContext.getSnapshotManager().capture(mock(ReplicatedLogEntry.class), -1); + awaitAndValidateSnapshot(latch, savedSnapshot, expectedRoot); - assertTrue("Invalid saved snapshot " + savedSnapshot.get(), - savedSnapshot.get() instanceof Snapshot); + raftActorContext.getSnapshotManager().capture(mock(ReplicatedLogEntry.class), -1); + awaitAndValidateSnapshot(latch, savedSnapshot, expectedRoot); + } - verifySnapshot((Snapshot)savedSnapshot.get(), expectedRoot); + private static void awaitAndValidateSnapshot(final AtomicReference latch, + final AtomicReference savedSnapshot, final NormalizedNode expectedRoot) + throws InterruptedException { + assertTrue("Snapshot saved", latch.get().await(5, TimeUnit.SECONDS)); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - } + assertTrue("Invalid saved snapshot " + savedSnapshot.get(), savedSnapshot.get() instanceof Snapshot); - private void verifySnapshot(final Snapshot snapshot, final NormalizedNode expectedRoot) { + verifySnapshot((Snapshot) savedSnapshot.get(), expectedRoot); - final NormalizedNode actual = SerializationUtils.deserializeNormalizedNode(snapshot.getState()); - assertEquals("Root node", expectedRoot, actual); + latch.set(new CountDownLatch(1)); + savedSnapshot.set(null); + } - }}; + private static void verifySnapshot(final Snapshot snapshot, final NormalizedNode expectedRoot) { + final NormalizedNode actual = ((ShardSnapshotState)snapshot.getState()).getSnapshot().getRootNode().get(); + assertEquals("Root node", expectedRoot, actual); } /** - * This test simply verifies that the applySnapShot logic will work - * @throws ReadFailedException - * @throws DataValidationFailedException + * This test simply verifies that the applySnapShot logic will work. */ @Test - public void testInMemoryDataTreeRestore() throws ReadFailedException, DataValidationFailedException { - final DataTree store = InMemoryDataTreeFactory.getInstance().create(); - store.setSchemaContext(SCHEMA_CONTEXT); + public void testInMemoryDataTreeRestore() throws DataValidationFailedException { + final DataTree store = new InMemoryDataTreeFactory().create(DataTreeConfiguration.DEFAULT_OPERATIONAL, + SCHEMA_CONTEXT); final DataTreeModification putTransaction = store.takeSnapshot().newModification(); putTransaction.write(TestModel.TEST_PATH, @@ -2384,280 +1769,230 @@ public class ShardTest extends AbstractShardTest { commitTransaction(store, putTransaction); - final NormalizedNode expected = readStore(store, YangInstanceIdentifier.builder().build()); + final NormalizedNode expected = readStore(store, YangInstanceIdentifier.EMPTY); final DataTreeModification writeTransaction = store.takeSnapshot().newModification(); - writeTransaction.delete(YangInstanceIdentifier.builder().build()); - writeTransaction.write(YangInstanceIdentifier.builder().build(), expected); + writeTransaction.delete(YangInstanceIdentifier.EMPTY); + writeTransaction.write(YangInstanceIdentifier.EMPTY, expected); commitTransaction(store, writeTransaction); - final NormalizedNode actual = readStore(store, YangInstanceIdentifier.builder().build()); + final NormalizedNode actual = readStore(store, YangInstanceIdentifier.EMPTY); assertEquals(expected, actual); } @Test - public void testRecoveryApplicable(){ + public void testRecoveryApplicable() { - final DatastoreContext persistentContext = DatastoreContext.newBuilder(). - shardJournalRecoveryLogBatchSize(3).shardSnapshotBatchCount(5000).persistent(true).build(); + final DatastoreContext persistentContext = DatastoreContext.newBuilder() + .shardJournalRecoveryLogBatchSize(3).shardSnapshotBatchCount(5000).persistent(true).build(); - final Props persistentProps = Shard.props(shardID, Collections.emptyMap(), - persistentContext, SCHEMA_CONTEXT); + final Props persistentProps = Shard.builder().id(shardID).datastoreContext(persistentContext) + .schemaContextProvider(() -> SCHEMA_CONTEXT).props(); - final DatastoreContext nonPersistentContext = DatastoreContext.newBuilder(). - shardJournalRecoveryLogBatchSize(3).shardSnapshotBatchCount(5000).persistent(false).build(); + final DatastoreContext nonPersistentContext = DatastoreContext.newBuilder() + .shardJournalRecoveryLogBatchSize(3).shardSnapshotBatchCount(5000).persistent(false).build(); - final Props nonPersistentProps = Shard.props(shardID, Collections.emptyMap(), - nonPersistentContext, SCHEMA_CONTEXT); + final Props nonPersistentProps = Shard.builder().id(shardID).datastoreContext(nonPersistentContext) + .schemaContextProvider(() -> SCHEMA_CONTEXT).props(); - new ShardTestKit(getSystem()) {{ - final TestActorRef shard1 = TestActorRef.create(getSystem(), - persistentProps, "testPersistence1"); + final TestActorRef shard1 = actorFactory.createTestActor(persistentProps, "testPersistence1"); - assertTrue("Recovery Applicable", shard1.underlyingActor().persistence().isRecoveryApplicable()); + assertTrue("Recovery Applicable", shard1.underlyingActor().persistence().isRecoveryApplicable()); - shard1.tell(PoisonPill.getInstance(), ActorRef.noSender()); - - final TestActorRef shard2 = TestActorRef.create(getSystem(), - nonPersistentProps, "testPersistence2"); - - assertFalse("Recovery Not Applicable", shard2.underlyingActor().persistence().isRecoveryApplicable()); - - shard2.tell(PoisonPill.getInstance(), ActorRef.noSender()); - - }}; + final TestActorRef shard2 = actorFactory.createTestActor(nonPersistentProps, "testPersistence2"); + assertFalse("Recovery Not Applicable", shard2.underlyingActor().persistence().isRecoveryApplicable()); } @Test public void testOnDatastoreContext() { - new ShardTestKit(getSystem()) {{ - dataStoreContextBuilder.persistent(true); - - final TestActorRef shard = TestActorRef.create(getSystem(), newShardProps(), "testOnDatastoreContext"); + dataStoreContextBuilder.persistent(true); - assertEquals("isRecoveryApplicable", true, - shard.underlyingActor().persistence().isRecoveryApplicable()); + final TestActorRef shard = actorFactory.createTestActor(newShardProps(), "testOnDatastoreContext"); - waitUntilLeader(shard); + assertTrue("isRecoveryApplicable", shard.underlyingActor().persistence().isRecoveryApplicable()); - shard.tell(dataStoreContextBuilder.persistent(false).build(), ActorRef.noSender()); + ShardTestKit.waitUntilLeader(shard); - assertEquals("isRecoveryApplicable", false, - shard.underlyingActor().persistence().isRecoveryApplicable()); + shard.tell(dataStoreContextBuilder.persistent(false).build(), ActorRef.noSender()); - shard.tell(dataStoreContextBuilder.persistent(true).build(), ActorRef.noSender()); + assertFalse("isRecoveryApplicable", shard.underlyingActor().persistence().isRecoveryApplicable()); - assertEquals("isRecoveryApplicable", true, - shard.underlyingActor().persistence().isRecoveryApplicable()); + shard.tell(dataStoreContextBuilder.persistent(true).build(), ActorRef.noSender()); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + assertTrue("isRecoveryApplicable", shard.underlyingActor().persistence().isRecoveryApplicable()); } @Test - public void testRegisterRoleChangeListener() throws Exception { - new ShardTestKit(getSystem()) { - { - final TestActorRef shard = TestActorRef.create(getSystem(), - newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), - "testRegisterRoleChangeListener"); + public void testRegisterRoleChangeListener() { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final TestActorRef shard = actorFactory.createTestActor( + newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testRegisterRoleChangeListener"); - waitUntilLeader(shard); + ShardTestKit.waitUntilLeader(shard); - final TestActorRef listener = - TestActorRef.create(getSystem(), Props.create(MessageCollectorActor.class)); + final ActorRef listener = getSystem().actorOf(MessageCollectorActor.props()); - shard.tell(new RegisterRoleChangeListener(), listener); + shard.tell(new RegisterRoleChangeListener(), listener); - MessageCollectorActor.expectFirstMatching(listener, RegisterRoleChangeListenerReply.class); + MessageCollectorActor.expectFirstMatching(listener, RegisterRoleChangeListenerReply.class); - ShardLeaderStateChanged leaderStateChanged = MessageCollectorActor.expectFirstMatching(listener, - ShardLeaderStateChanged.class); - assertEquals("getLocalShardDataTree present", true, - leaderStateChanged.getLocalShardDataTree().isPresent()); - assertSame("getLocalShardDataTree", shard.underlyingActor().getDataStore().getDataTree(), - leaderStateChanged.getLocalShardDataTree().get()); + ShardLeaderStateChanged leaderStateChanged = MessageCollectorActor.expectFirstMatching(listener, + ShardLeaderStateChanged.class); + assertTrue("getLocalShardDataTree present", leaderStateChanged.getLocalShardDataTree().isPresent()); + assertSame("getLocalShardDataTree", shard.underlyingActor().getDataStore().getDataTree(), + leaderStateChanged.getLocalShardDataTree().get()); - MessageCollectorActor.clearMessages(listener); + MessageCollectorActor.clearMessages(listener); - // Force a leader change + // Force a leader change - shard.tell(new RequestVote(10000, "member2", 50, 50), getRef()); + shard.tell(new RequestVote(10000, "member2", 50, 50), testKit.getRef()); - leaderStateChanged = MessageCollectorActor.expectFirstMatching(listener, - ShardLeaderStateChanged.class); - assertEquals("getLocalShardDataTree present", false, - leaderStateChanged.getLocalShardDataTree().isPresent()); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - } - }; + leaderStateChanged = MessageCollectorActor.expectFirstMatching(listener, ShardLeaderStateChanged.class); + assertFalse("getLocalShardDataTree present", leaderStateChanged.getLocalShardDataTree().isPresent()); } @Test - public void testFollowerInitialSyncStatus() throws Exception { - final TestActorRef shard = TestActorRef.create(getSystem(), + public void testFollowerInitialSyncStatus() { + final TestActorRef shard = actorFactory.createTestActor( newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()), "testFollowerInitialSyncStatus"); - shard.underlyingActor().onReceiveCommand(new FollowerInitialSyncUpStatus(false, "member-1-shard-inventory-operational")); + shard.underlyingActor().handleNonRaftCommand(new FollowerInitialSyncUpStatus(false, + "member-1-shard-inventory-operational")); - assertEquals(false, shard.underlyingActor().getShardMBean().getFollowerInitialSyncStatus()); + assertFalse(shard.underlyingActor().getShardMBean().getFollowerInitialSyncStatus()); - shard.underlyingActor().onReceiveCommand(new FollowerInitialSyncUpStatus(true, "member-1-shard-inventory-operational")); - - assertEquals(true, shard.underlyingActor().getShardMBean().getFollowerInitialSyncStatus()); - - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - } + shard.underlyingActor().handleNonRaftCommand(new FollowerInitialSyncUpStatus(true, + "member-1-shard-inventory-operational")); - private static void commitTransaction(final DataTree store, final DataTreeModification modification) throws DataValidationFailedException { - modification.ready(); - store.validate(modification); - store.commit(store.prepare(modification)); + assertTrue(shard.underlyingActor().getShardMBean().getFollowerInitialSyncStatus()); } @Test - public void testClusteredDataChangeListernerDelayedRegistration() throws Exception { - new ShardTestKit(getSystem()) {{ - final CountDownLatch onFirstElectionTimeout = new CountDownLatch(1); - final CountDownLatch onChangeListenerRegistered = new CountDownLatch(1); - final Creator creator = new Creator() { - boolean firstElectionTimeout = true; - - @Override - public Shard create() throws Exception { - return new Shard(shardID, Collections.emptyMap(), - dataStoreContextBuilder.persistent(false).build(), SCHEMA_CONTEXT) { - @Override - public void onReceiveCommand(final Object message) throws Exception { - if(message instanceof ElectionTimeout && firstElectionTimeout) { - firstElectionTimeout = false; - final ActorRef self = getSelf(); - new Thread() { - @Override - public void run() { - Uninterruptibles.awaitUninterruptibly( - onChangeListenerRegistered, 5, TimeUnit.SECONDS); - self.tell(message, self); - } - }.start(); - - onFirstElectionTimeout.countDown(); - } else { - super.onReceiveCommand(message); - } - } - }; - } - }; - - final MockDataChangeListener listener = new MockDataChangeListener(1); - final ActorRef dclActor = getSystem().actorOf(DataChangeListener.props(listener), - "testDataChangeListenerOnFollower-DataChangeListener"); - - final TestActorRef shard = TestActorRef.create(getSystem(), - Props.create(new DelegatingShardCreator(creator)).withDispatcher(Dispatchers.DefaultDispatcherId()). - withDispatcher(Dispatchers.DefaultDispatcherId()),"testDataChangeListenerOnFollower"); - - assertEquals("Got first ElectionTimeout", true, - onFirstElectionTimeout.await(5, TimeUnit.SECONDS)); + public void testClusteredDataTreeChangeListenerWithDelayedRegistration() throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final String testName = "testClusteredDataTreeChangeListenerWithDelayedRegistration"; + dataStoreContextBuilder.shardElectionTimeoutFactor(1000) + .customRaftPolicyImplementation(DisableElectionsRaftPolicy.class.getName()); - shard.tell(new FindLeader(), getRef()); - final FindLeaderReply findLeadeReply = - expectMsgClass(duration("5 seconds"), FindLeaderReply.class); - assertNull("Expected the shard not to be the leader", findLeadeReply.getLeaderActor()); + final MockDataTreeChangeListener listener = new MockDataTreeChangeListener(1); + final ActorRef dclActor = actorFactory.createActor(DataTreeChangeListenerActor.props(listener, + TestModel.TEST_PATH), actorFactory.generateActorId(testName + "-DataTreeChangeListener")); - final YangInstanceIdentifier path = TestModel.TEST_PATH; + setupInMemorySnapshotStore(); - shard.tell(new RegisterChangeListener(path, dclActor, AsyncDataBroker.DataChangeScope.BASE, true), getRef()); - final RegisterChangeListenerReply reply = expectMsgClass(duration("5 seconds"), - RegisterChangeListenerReply.class); - assertNotNull("getListenerRegistratioznPath", reply.getListenerRegistrationPath()); + final TestActorRef shard = actorFactory.createTestActor( + newShardBuilder().props().withDispatcher(Dispatchers.DefaultDispatcherId()), + actorFactory.generateActorId(testName + "-shard")); - writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); + testKit.waitUntilNoLeader(shard); - onChangeListenerRegistered.countDown(); + shard.tell(new RegisterDataTreeChangeListener(TestModel.TEST_PATH, dclActor, true), testKit.getRef()); + final RegisterDataTreeNotificationListenerReply reply = testKit.expectMsgClass(Duration.ofSeconds(5), + RegisterDataTreeNotificationListenerReply.class); + assertNotNull("getListenerRegistrationPath", reply.getListenerRegistrationPath()); - listener.waitForChangeEvents(); + shard.tell(DatastoreContext.newBuilderFrom(dataStoreContextBuilder.build()) + .customRaftPolicyImplementation(null).build(), ActorRef.noSender()); - dclActor.tell(PoisonPill.getInstance(), ActorRef.noSender()); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + listener.waitForChangeEvents(); } @Test - public void testClusteredDataChangeListernerRegistration() throws Exception { - new ShardTestKit(getSystem()) {{ - final ShardIdentifier member1ShardID = ShardIdentifier.builder().memberName("member-1") - .shardName("inventory").type("config").build(); - - final ShardIdentifier member2ShardID = ShardIdentifier.builder().memberName("member-2") - .shardName("inventory").type("config").build(); - final Creator followerShardCreator = new Creator() { - - @Override - public Shard create() throws Exception { - return new Shard(member1ShardID, Collections.singletonMap(member2ShardID.toString(), - "akka://test/user/" + member2ShardID.toString()), - dataStoreContextBuilder.persistent(false).build(), SCHEMA_CONTEXT) { - @Override - public void onReceiveCommand(final Object message) throws Exception { - - if(!(message instanceof ElectionTimeout)) { - super.onReceiveCommand(message); - } - } - }; - } - }; + public void testClusteredDataTreeChangeListenerWithDelayedRegistrationClosed() throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final String testName = "testClusteredDataTreeChangeListenerWithDelayedRegistrationClosed"; + dataStoreContextBuilder.shardElectionTimeoutFactor(1000) + .customRaftPolicyImplementation(DisableElectionsRaftPolicy.class.getName()); - final Creator leaderShardCreator = new Creator() { + final MockDataTreeChangeListener listener = new MockDataTreeChangeListener(0); + final ActorRef dclActor = actorFactory.createActor(DataTreeChangeListenerActor.props(listener, + TestModel.TEST_PATH), actorFactory.generateActorId(testName + "-DataTreeChangeListener")); - @Override - public Shard create() throws Exception { - return new Shard(member2ShardID, Collections.singletonMap(member1ShardID.toString(), - "akka://test/user/" + member1ShardID.toString()), - dataStoreContextBuilder.persistent(false).build(), SCHEMA_CONTEXT) { }; - } - }; + setupInMemorySnapshotStore(); + final TestActorRef shard = actorFactory.createTestActor( + newShardBuilder().props().withDispatcher(Dispatchers.DefaultDispatcherId()), + actorFactory.generateActorId(testName + "-shard")); - final TestActorRef shard = TestActorRef.create(getSystem(), - Props.create(new DelegatingShardCreator(followerShardCreator)), - member1ShardID.toString()); + testKit.waitUntilNoLeader(shard); - final TestActorRef shardLeader = TestActorRef.create(getSystem(), - Props.create(new DelegatingShardCreator(leaderShardCreator)).withDispatcher(Dispatchers.DefaultDispatcherId()), - member2ShardID.toString()); - // Sleep to let election happen - Uninterruptibles.sleepUninterruptibly(2, TimeUnit.SECONDS); + shard.tell(new RegisterDataTreeChangeListener(TestModel.TEST_PATH, dclActor, true), testKit.getRef()); + final RegisterDataTreeNotificationListenerReply reply = testKit.expectMsgClass(Duration.ofSeconds(5), + RegisterDataTreeNotificationListenerReply.class); + assertNotNull("getListenerRegistrationPath", reply.getListenerRegistrationPath()); - shard.tell(new FindLeader(), getRef()); - final FindLeaderReply findLeaderReply = - expectMsgClass(duration("5 seconds"), FindLeaderReply.class); - assertEquals("Shard leader does not match", shardLeader.path().toString(), findLeaderReply.getLeaderActor()); + final ActorSelection regActor = getSystem().actorSelection(reply.getListenerRegistrationPath()); + regActor.tell(CloseDataTreeNotificationListenerRegistration.getInstance(), testKit.getRef()); + testKit.expectMsgClass(CloseDataTreeNotificationListenerRegistrationReply.class); - final YangInstanceIdentifier path = TestModel.TEST_PATH; - final MockDataChangeListener listener = new MockDataChangeListener(1); - final ActorRef dclActor = getSystem().actorOf(DataChangeListener.props(listener), - "testDataChangeListenerOnFollower-DataChangeListener"); + shard.tell(DatastoreContext.newBuilderFrom(dataStoreContextBuilder.build()) + .customRaftPolicyImplementation(null).build(), ActorRef.noSender()); - shard.tell(new RegisterChangeListener(path, dclActor, AsyncDataBroker.DataChangeScope.BASE, true), getRef()); - final RegisterChangeListenerReply reply = expectMsgClass(duration("5 seconds"), - RegisterChangeListenerReply.class); - assertNotNull("getListenerRegistratioznPath", reply.getListenerRegistrationPath()); + listener.expectNoMoreChanges("Received unexpected change after close"); + } + + @Test + public void testClusteredDataTreeChangeListenerRegistration() throws Exception { + final ShardTestKit testKit = new ShardTestKit(getSystem()); + final String testName = "testClusteredDataTreeChangeListenerRegistration"; + final ShardIdentifier followerShardID = ShardIdentifier.create("inventory", + MemberName.forName(actorFactory.generateActorId(testName + "-follower")), "config"); + + final ShardIdentifier leaderShardID = ShardIdentifier.create("inventory", + MemberName.forName(actorFactory.generateActorId(testName + "-leader")), "config"); + + final TestActorRef followerShard = actorFactory + .createTestActor(Shard.builder().id(followerShardID) + .datastoreContext(dataStoreContextBuilder.shardElectionTimeoutFactor(1000).build()) + .peerAddresses(Collections.singletonMap(leaderShardID.toString(), + "akka://test/user/" + leaderShardID.toString())) + .schemaContextProvider(() -> SCHEMA_CONTEXT).props() + .withDispatcher(Dispatchers.DefaultDispatcherId()), followerShardID.toString()); + + final TestActorRef leaderShard = actorFactory + .createTestActor(Shard.builder().id(leaderShardID).datastoreContext(newDatastoreContext()) + .peerAddresses(Collections.singletonMap(followerShardID.toString(), + "akka://test/user/" + followerShardID.toString())) + .schemaContextProvider(() -> SCHEMA_CONTEXT).props() + .withDispatcher(Dispatchers.DefaultDispatcherId()), leaderShardID.toString()); + + leaderShard.tell(TimeoutNow.INSTANCE, ActorRef.noSender()); + final String leaderPath = ShardTestKit.waitUntilLeader(followerShard); + assertEquals("Shard leader path", leaderShard.path().toString(), leaderPath); + + final YangInstanceIdentifier path = TestModel.TEST_PATH; + final MockDataTreeChangeListener listener = new MockDataTreeChangeListener(1); + final ActorRef dclActor = actorFactory.createActor(DataTreeChangeListenerActor.props(listener, path), + actorFactory.generateActorId(testName + "-DataTreeChangeListener")); + + followerShard.tell(new RegisterDataTreeChangeListener(TestModel.TEST_PATH, dclActor, true), testKit.getRef()); + final RegisterDataTreeNotificationListenerReply reply = testKit.expectMsgClass(Duration.ofSeconds(5), + RegisterDataTreeNotificationListenerReply.class); + assertNotNull("getListenerRegistrationPath", reply.getListenerRegistrationPath()); + + writeToStore(followerShard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); + + listener.waitForChangeEvents(); + } + + @Test + public void testServerRemoved() { + final TestActorRef parent = actorFactory.createTestActor(MessageCollectorActor.props() + .withDispatcher(Dispatchers.DefaultDispatcherId())); - writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME)); + final ActorRef shard = parent.underlyingActor().context().actorOf( + newShardBuilder().props().withDispatcher(Dispatchers.DefaultDispatcherId()), + "testServerRemoved"); - listener.waitForChangeEvents(); + shard.tell(new ServerRemoved("test"), ActorRef.noSender()); - dclActor.tell(PoisonPill.getInstance(), ActorRef.noSender()); - shard.tell(PoisonPill.getInstance(), ActorRef.noSender()); - }}; + MessageCollectorActor.expectFirstMatching(parent, ServerRemoved.class); } }