Use ActorFactory in ShardTest 73/32473/5
authorTom Pantelis <tpanteli@brocade.com>
Tue, 12 Jan 2016 20:43:09 +0000 (15:43 -0500)
committerGerrit Code Review <gerrit@opendaylight.org>
Tue, 19 Jan 2016 19:10:47 +0000 (19:10 +0000)
And other minor refactoring.

Change-Id: Ic8c23aff6f0109e16f9175577efa1219bd6a07a5
Signed-off-by: Tom Pantelis <tpanteli@brocade.com>
opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/AbstractShardTest.java
opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/ShardTest.java

index 9d313a5a7897b39991efa0fdbe4cec5d32980170..2442548f13551cec05ad09d90298716cd73fcda3 100644 (file)
@@ -27,6 +27,7 @@ import com.google.common.base.Function;
 import com.google.common.base.Optional;
 import com.google.common.util.concurrent.ListenableFuture;
 import com.google.common.util.concurrent.Uninterruptibles;
+import java.util.Collections;
 import java.util.Set;
 import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.ExecutionException;
@@ -43,9 +44,13 @@ import org.opendaylight.controller.cluster.datastore.messages.BatchedModificatio
 import org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction;
 import org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification;
 import org.opendaylight.controller.cluster.datastore.modification.WriteModification;
+import org.opendaylight.controller.cluster.datastore.utils.SerializationUtils;
+import org.opendaylight.controller.cluster.raft.ReplicatedLogEntry;
+import org.opendaylight.controller.cluster.raft.Snapshot;
 import org.opendaylight.controller.cluster.raft.TestActorFactory;
 import org.opendaylight.controller.cluster.raft.utils.InMemoryJournal;
 import org.opendaylight.controller.cluster.raft.utils.InMemorySnapshotStore;
+import org.opendaylight.controller.md.cluster.datastore.model.CarsModel;
 import org.opendaylight.controller.md.cluster.datastore.model.TestModel;
 import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
 import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.PathArgument;
@@ -54,9 +59,14 @@ import org.opendaylight.yangtools.yang.data.api.schema.MapEntryNode;
 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.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.api.schema.tree.TreeType;
+import org.opendaylight.yangtools.yang.data.impl.schema.ImmutableNodes;
+import org.opendaylight.yangtools.yang.data.impl.schema.tree.InMemoryDataTreeFactory;
 import org.opendaylight.yangtools.yang.model.api.SchemaContext;
 
 /**
@@ -357,6 +367,84 @@ public abstract class AbstractShardTest extends AbstractActorTest{
         store.commit(candidate);
     }
 
+    DataTree setupInMemorySnapshotStore() throws DataValidationFailedException {
+        final DataTree testStore = InMemoryDataTreeFactory.getInstance().create(TreeType.OPERATIONAL);
+        testStore.setSchemaContext(SCHEMA_CONTEXT);
+
+        writeToStore(testStore, TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME));
+
+        final NormalizedNode<?, ?> root = readStore(testStore, YangInstanceIdentifier.builder().build());
+
+        InMemorySnapshotStore.addSnapshot(shardID.toString(), Snapshot.create(
+                SerializationUtils.serializeNormalizedNode(root),
+                Collections.<ReplicatedLogEntry>emptyList(), 0, 1, -1, -1));
+        return testStore;
+    }
+
+    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);
+    }
+
+    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);
+    }
+
+    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;
+    }
+
+    @SuppressWarnings("unchecked")
+    static void verifyOuterListEntry(final TestActorRef<Shard> 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<Object>)outerList.getValue()).iterator().next();
+        assertTrue(TestModel.OUTER_LIST_QNAME.getLocalName() + " entry is not MapEntryNode",
+                entry instanceof MapEntryNode);
+        final MapEntryNode mapEntry = (MapEntryNode)entry;
+        final Optional<DataContainerChild<? extends PathArgument, ?>> 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());
+    }
+
+    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(CarsModel.CARS_QNAME))).when(mockCandidateNode).getDataAfter();
+        doReturn(YangInstanceIdentifier.builder().build()).when(mockCandidate).getRootPath();
+        doReturn(mockCandidateNode).when(mockCandidate).getRootNode();
+        return mockCandidate;
+    }
+
+    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;
+    }
+
+    static void commitTransaction(final DataTree store, final DataTreeModification modification) throws DataValidationFailedException {
+        modification.ready();
+        store.validate(modification);
+        store.commit(store.prepare(modification));
+    }
+
     @SuppressWarnings("serial")
     public static final class DelegatingShardCreator implements Creator<Shard> {
         private final Creator<Shard> delegate;
index 0121a15338a2ed807e910a793e6655a062ba35de..23a200f6bcda05b11afcd24b248ed8145f400122 100644 (file)
@@ -22,7 +22,6 @@ 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;
@@ -33,7 +32,6 @@ 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.util.concurrent.Uninterruptibles;
@@ -73,7 +71,6 @@ import org.opendaylight.controller.cluster.datastore.messages.ShardLeaderStateCh
 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.MutableCompositeModification;
 import org.opendaylight.controller.cluster.datastore.modification.WriteModification;
 import org.opendaylight.controller.cluster.datastore.utils.MockDataChangeListener;
@@ -95,7 +92,6 @@ import org.opendaylight.controller.cluster.raft.messages.RequestVote;
 import org.opendaylight.controller.cluster.raft.messages.ServerRemoved;
 import org.opendaylight.controller.cluster.raft.policy.DisableElectionsRaftPolicy;
 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;
@@ -105,14 +101,10 @@ import org.opendaylight.controller.protobuff.messages.cohort3pc.ThreePhaseCommit
 import org.opendaylight.controller.protobuff.messages.transaction.ShardTransactionMessages.CreateTransactionReply;
 import org.opendaylight.yangtools.yang.common.QName;
 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.DataTreeModification;
@@ -134,7 +126,7 @@ public class ShardTest extends AbstractShardTest {
     @Test
     public void testRegisterChangeListener() throws Exception {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps(),  "testRegisterChangeListener");
 
             waitUntilLeader(shard);
@@ -142,7 +134,7 @@ public class ShardTest extends AbstractShardTest {
             shard.tell(new UpdateSchemaContext(SchemaContextHelper.full()), ActorRef.noSender());
 
             final MockDataChangeListener listener = new MockDataChangeListener(1);
-            final ActorRef dclActor = getSystem().actorOf(DataChangeListener.props(listener),
+            final ActorRef dclActor = actorFactory.createActor(DataChangeListener.props(listener),
                     "testRegisterChangeListener-DataChangeListener");
 
             shard.tell(new RegisterChangeListener(TestModel.TEST_PATH,
@@ -158,9 +150,6 @@ public class ShardTest extends AbstractShardTest {
             writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME));
 
             listener.waitForChangeEvents(path);
-
-            dclActor.tell(PoisonPill.getInstance(), ActorRef.noSender());
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -221,10 +210,10 @@ public class ShardTest extends AbstractShardTest {
             };
 
             final MockDataChangeListener listener = new MockDataChangeListener(1);
-            final ActorRef dclActor = getSystem().actorOf(DataChangeListener.props(listener),
+            final ActorRef dclActor = actorFactory.createActor(DataChangeListener.props(listener),
                     "testRegisterChangeListenerWhenNotLeaderInitially-DataChangeListener");
 
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     Props.create(new DelegatingShardCreator(creator)).withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testRegisterChangeListenerWhenNotLeaderInitially");
 
@@ -257,16 +246,13 @@ public class ShardTest extends AbstractShardTest {
             // 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());
         }};
     }
 
     @Test
     public void testRegisterDataTreeChangeListener() throws Exception {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps(), "testRegisterDataTreeChangeListener");
 
             waitUntilLeader(shard);
@@ -274,7 +260,7 @@ public class ShardTest extends AbstractShardTest {
             shard.tell(new UpdateSchemaContext(SchemaContextHelper.full()), ActorRef.noSender());
 
             final MockDataTreeChangeListener listener = new MockDataTreeChangeListener(1);
-            final ActorRef dclActor = getSystem().actorOf(DataTreeChangeListenerActor.props(listener),
+            final ActorRef dclActor = actorFactory.createActor(DataTreeChangeListenerActor.props(listener),
                     "testRegisterDataTreeChangeListener-DataTreeChangeListener");
 
             shard.tell(new RegisterDataTreeChangeListener(TestModel.TEST_PATH, dclActor, false), getRef());
@@ -289,9 +275,6 @@ public class ShardTest extends AbstractShardTest {
             writeToStore(shard, path, ImmutableNodes.containerNode(TestModel.TEST_QNAME));
 
             listener.waitForChangeEvents();
-
-            dclActor.tell(PoisonPill.getInstance(), ActorRef.noSender());
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -332,10 +315,10 @@ public class ShardTest extends AbstractShardTest {
             };
 
             final MockDataTreeChangeListener listener = new MockDataTreeChangeListener(1);
-            final ActorRef dclActor = getSystem().actorOf(DataTreeChangeListenerActor.props(listener),
+            final ActorRef dclActor = actorFactory.createActor(DataTreeChangeListenerActor.props(listener),
                     "testDataTreeChangeListenerNotifiedWhenNotTheLeaderOnRegistration-DataChangeListener");
 
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     Props.create(new DelegatingShardCreator(creator)).withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testDataTreeChangeListenerNotifiedWhenNotTheLeaderOnRegistration");
 
@@ -361,16 +344,13 @@ public class ShardTest extends AbstractShardTest {
 
             // TODO: investigate why we do not receive data chage events
             listener.waitForChangeEvents();
-
-            dclActor.tell(PoisonPill.getInstance(), ActorRef.noSender());
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
     @Test
     public void testCreateTransaction(){
         new ShardTestKit(getSystem()) {{
-            final ActorRef shard = getSystem().actorOf(newShardProps(), "testCreateTransaction");
+            final ActorRef shard = actorFactory.createActor(newShardProps(), "testCreateTransaction");
 
             waitUntilLeader(shard);
 
@@ -385,15 +365,13 @@ public class ShardTest extends AbstractShardTest {
             final String path = reply.getTransactionActorPath().toString();
             assertTrue("Unexpected transaction path " + path,
                     path.contains("akka://test/user/testCreateTransaction/shard-txn-1"));
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
     @Test
     public void testCreateTransactionOnChain(){
         new ShardTestKit(getSystem()) {{
-            final ActorRef shard = getSystem().actorOf(newShardProps(), "testCreateTransactionOnChain");
+            final ActorRef shard = actorFactory.createActor(newShardProps(), "testCreateTransactionOnChain");
 
             waitUntilLeader(shard);
 
@@ -407,8 +385,6 @@ public class ShardTest extends AbstractShardTest {
             final String path = reply.getTransactionActorPath().toString();
             assertTrue("Unexpected transaction path " + path,
                     path.contains("akka://test/user/testCreateTransactionOnChain/shard-txn-1"));
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -438,7 +414,7 @@ public class ShardTest extends AbstractShardTest {
                 }
             }
 
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     Props.create(new DelegatingShardCreator(new Creator<Shard>() {
                         @Override
                         public TestShard create() throws Exception {
@@ -454,16 +430,13 @@ public class ShardTest extends AbstractShardTest {
 
             assertEquals("getPeerAddress", address,
                 ((TestShard) shard.underlyingActor()).getPeerAddress(shardID.toString()));
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
     @Test
     public void testApplySnapshot() throws Exception {
 
-        final TestActorRef<Shard> shard = TestActorRef.create(getSystem(), newShardProps(),
-                "testApplySnapshot");
+        final TestActorRef<Shard> shard = actorFactory.createTestActor(newShardProps(), "testApplySnapshot");
 
         ShardTestKit.waitUntilLeader(shard);
 
@@ -488,48 +461,27 @@ public class ShardTest extends AbstractShardTest {
         final NormalizedNode<?,?> actual = readStore(shard, root);
 
         assertEquals("Root node", expected, actual);
-
-        shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
     }
 
     @Test
     public void testApplyState() throws Exception {
-        final TestActorRef<Shard> shard = TestActorRef.create(getSystem(), newShardProps(), "testApplyState");
+        final TestActorRef<Shard> shard = actorFactory.createTestActor(newShardProps(), "testApplyState");
 
         ShardTestKit.waitUntilLeader(shard);
 
-        final NormalizedNode<?, ?> node = ImmutableNodes.containerNode(TestModel.TEST_QNAME);
+        final DataTree source = setupInMemorySnapshotStore();
+        final DataTreeModification writeMod = source.takeSnapshot().newModification();
+        ContainerNode node = ImmutableNodes.containerNode(TestModel.TEST_QNAME);
+        writeMod.write(TestModel.TEST_PATH, node);
+        writeMod.ready();
 
         final ApplyState applyState = new ApplyState(null, "test", new ReplicatedLogImplEntry(1, 2,
-                newDataTreeCandidatePayload(new WriteModification(TestModel.TEST_PATH, node))));
+                payloadForModification(source, writeMod)));
 
         shard.underlyingActor().onReceiveCommand(applyState);
 
         final NormalizedNode<?,?> actual = readStore(shard, TestModel.TEST_PATH);
         assertEquals("Applied state", node, actual);
-
-        shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
-    }
-
-    DataTree setupInMemorySnapshotStore() throws DataValidationFailedException {
-        final DataTree testStore = InMemoryDataTreeFactory.getInstance().create(TreeType.OPERATIONAL);
-        testStore.setSchemaContext(SCHEMA_CONTEXT);
-
-        writeToStore(testStore, TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME));
-
-        final NormalizedNode<?, ?> root = readStore(testStore, YangInstanceIdentifier.builder().build());
-
-        InMemorySnapshotStore.addSnapshot(shardID.toString(), Snapshot.create(
-                SerializationUtils.serializeNormalizedNode(root),
-                Collections.<ReplicatedLogEntry>emptyList(), 0, 1, -1, -1));
-        return testStore;
-    }
-
-    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);
     }
 
     @Test
@@ -568,68 +520,16 @@ public class ShardTest extends AbstractShardTest {
         testRecovery(listEntryKeys);
     }
 
-    @Test
-    public void testModicationRecovery() throws Exception {
-
-        // Set up the InMemorySnapshotStore.
-        setupInMemorySnapshotStore();
-
-        // Set up the InMemoryJournal.
-
-        InMemoryJournal.addEntry(shardID.toString(), 0, DUMMY_DATA);
-
-        ShardDataTree shardDataTree = new ShardDataTree(SCHEMA_CONTEXT, TreeType.CONFIGURATION);
-
-        InMemoryJournal.addEntry(shardID.toString(), 1, new ReplicatedLogImplEntry(0, 1, newDataTreeCandidatePayload(
-                shardDataTree,
-                new WriteModification(TestModel.TEST_PATH, ImmutableNodes.containerNode(TestModel.TEST_QNAME)),
-                new WriteModification(TestModel.OUTER_LIST_PATH,
-                        ImmutableNodes.mapNodeBuilder(TestModel.OUTER_LIST_QNAME).build()))));
-
-        final int nListEntries = 16;
-        final Set<Integer> listEntryKeys = new HashSet<>();
-
-        // 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,
-                    newDataTreeCandidatePayload(shardDataTree, mod)));
-        }
-
-        InMemoryJournal.addEntry(shardID.toString(), nListEntries + 2,
-                new ApplyJournalEntries(nListEntries));
-
-        testRecovery(listEntryKeys);
-    }
-
-    private static DataTreeCandidatePayload newDataTreeCandidatePayload(final Modification... mods) throws Exception {
-        return newDataTreeCandidatePayload(new ShardDataTree(SCHEMA_CONTEXT, TreeType.CONFIGURATION), mods);
-    }
-
-    private static DataTreeCandidatePayload newDataTreeCandidatePayload(ShardDataTree shardDataTree,
-            final Modification... mods) throws Exception {
-        DataTreeModification dataTreeModification = shardDataTree.newModification();
-        for(final Modification mod: mods) {
-            mod.apply(dataTreeModification);
-        }
-
-        return DataTreeCandidatePayload.create(shardDataTree.commit(dataTreeModification));
-    }
-
     @Test
     public void testConcurrentThreePhaseCommits() throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testConcurrentThreePhaseCommits");
 
             waitUntilLeader(shard);
 
-         // Setup 3 simulated transactions with mock cohorts backed by real cohorts.
+            // Setup 3 simulated transactions with mock cohorts backed by real cohorts.
 
             final ShardDataTree dataStore = shard.underlyingActor().getDataStore();
 
@@ -782,31 +682,13 @@ public class ShardTest extends AbstractShardTest {
             verifyOuterListEntry(shard, 1);
 
             verifyLastApplied(shard, 2);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
-    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);
-    }
-
-    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;
-    }
-
     @Test
     public void testBatchedModificationsWithNoCommitOnReady() throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testBatchedModificationsWithNoCommitOnReady");
 
@@ -866,15 +748,13 @@ public class ShardTest extends AbstractShardTest {
             // Verify data in the data store.
 
             verifyOuterListEntry(shard, 1);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
     @Test
     public void testBatchedModificationsWithCommitOnReady() throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testBatchedModificationsWithCommitOnReady");
 
@@ -923,15 +803,13 @@ public class ShardTest extends AbstractShardTest {
             // Verify data in the data store.
 
             verifyOuterListEntry(shard, 1);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
     @Test(expected=IllegalStateException.class)
     public void testBatchedModificationsReadyWithIncorrectTotalMessageCount() throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testBatchedModificationsReadyWithIncorrectTotalMessageCount");
 
@@ -946,8 +824,6 @@ public class ShardTest extends AbstractShardTest {
 
             final Failure failure = expectMsgClass(duration("5 seconds"), akka.actor.Status.Failure.class);
 
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
-
             if(failure != null) {
                 throw failure.cause();
             }
@@ -957,7 +833,7 @@ public class ShardTest extends AbstractShardTest {
     @Test
     public void testBatchedModificationsWithOperationFailure() throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testBatchedModificationsWithOperationFailure");
 
@@ -987,31 +863,13 @@ public class ShardTest extends AbstractShardTest {
 
             failure = expectMsgClass(duration("5 seconds"), akka.actor.Status.Failure.class);
             assertEquals("Failure cause", cause, failure.cause());
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
-    @SuppressWarnings("unchecked")
-    private static void verifyOuterListEntry(final TestActorRef<Shard> 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<Object>)outerList.getValue()).iterator().next();
-        assertTrue(TestModel.OUTER_LIST_QNAME.getLocalName() + " entry is not MapEntryNode",
-                entry instanceof MapEntryNode);
-        final MapEntryNode mapEntry = (MapEntryNode)entry;
-        final Optional<DataContainerChild<? extends PathArgument, ?>> 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());
-    }
-
     @Test
     public void testBatchedModificationsOnTransactionChain() throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testBatchedModificationsOnTransactionChain");
 
@@ -1056,8 +914,6 @@ public class ShardTest extends AbstractShardTest {
 
             final NormalizedNode<?, ?> actualNode = readStore(shard, path);
             assertEquals("Stored node", containerNode, actualNode);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1085,7 +941,7 @@ public class ShardTest extends AbstractShardTest {
                 }
             };
 
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     Props.create(new DelegatingShardCreator(creator)), "testOnBatchedModificationsWhenNotLeader");
 
             waitUntilLeader(shard);
@@ -1097,8 +953,6 @@ public class ShardTest extends AbstractShardTest {
             shard.tell(batched, ActorRef.noSender());
 
             expectMsgEquals(batched);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1134,9 +988,9 @@ public class ShardTest extends AbstractShardTest {
         testReadyWithImmediateCommit(false);
     }
 
-    public void testReadyWithImmediateCommit(final boolean readWrite) throws Exception{
+    private void testReadyWithImmediateCommit(final boolean readWrite) throws Exception{
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testReadyWithImmediateCommit-" + readWrite);
 
@@ -1163,15 +1017,13 @@ public class ShardTest extends AbstractShardTest {
 
             final NormalizedNode<?, ?> actualNode = readStore(shard, TestModel.TEST_PATH);
             assertEquals(TestModel.TEST_QNAME.getLocalName(), containerNode, actualNode);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
     @Test
     public void testReadyLocalTransactionWithImmediateCommit() throws Exception{
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testReadyLocalTransactionWithImmediateCommit");
 
@@ -1196,15 +1048,13 @@ public class ShardTest extends AbstractShardTest {
 
             final NormalizedNode<?, ?> actualNode = readStore(shard, TestModel.OUTER_LIST_PATH);
             assertEquals(TestModel.OUTER_LIST_QNAME.getLocalName(), mergeData, actualNode);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
     @Test
     public void testReadyLocalTransactionWithThreePhaseCommit() throws Exception{
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testReadyLocalTransactionWithThreePhaseCommit");
 
@@ -1241,8 +1091,6 @@ public class ShardTest extends AbstractShardTest {
 
             final NormalizedNode<?, ?> actualNode = readStore(shard, TestModel.OUTER_LIST_PATH);
             assertEquals(TestModel.OUTER_LIST_QNAME.getLocalName(), mergeData, actualNode);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1252,10 +1100,10 @@ public class ShardTest extends AbstractShardTest {
         testCommitWithPersistenceDisabled(false);
     }
 
-    public void testCommitWithPersistenceDisabled(final boolean readWrite) throws Throwable {
+    private void testCommitWithPersistenceDisabled(final boolean readWrite) throws Throwable {
         dataStoreContextBuilder.persistent(false);
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testCommitWithPersistenceDisabled-" + readWrite);
 
@@ -1295,42 +1143,21 @@ public class ShardTest extends AbstractShardTest {
 
             final NormalizedNode<?, ?> actualNode = readStore(shard, TestModel.TEST_PATH);
             assertEquals(TestModel.TEST_QNAME.getLocalName(), containerNode, actualNode);
-
-            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;
-    }
-
     @Test
     public void testCommitWhenTransactionHasNoModifications() {
         testCommitWhenTransactionHasNoModifications(true);
         testCommitWhenTransactionHasNoModifications(false);
     }
 
-    public void testCommitWhenTransactionHasNoModifications(final boolean readWrite){
+    private void testCommitWhenTransactionHasNoModifications(final boolean readWrite){
         // 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> shard = TestActorRef.create(getSystem(),
+                final TestActorRef<Shard> shard = actorFactory.createTestActor(
                         newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                         "testCommitWhenTransactionHasNoModifications-" + readWrite);
 
@@ -1373,9 +1200,6 @@ public class ShardTest extends AbstractShardTest {
 
                 // Commit index should not advance because this does not go into the journal
                 assertEquals(-1, shardStats.getCommitIndex());
-
-                shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
-
             }
         };
     }
@@ -1386,10 +1210,10 @@ public class ShardTest extends AbstractShardTest {
         testCommitWhenTransactionHasModifications(false);
     }
 
-    public void testCommitWhenTransactionHasModifications(final boolean readWrite){
+    private void testCommitWhenTransactionHasModifications(final boolean readWrite){
         new ShardTestKit(getSystem()) {
             {
-                final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+                final TestActorRef<Shard> shard = actorFactory.createTestActor(
                         newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                         "testCommitWhenTransactionHasModifications-" + readWrite);
 
@@ -1433,9 +1257,6 @@ public class ShardTest extends AbstractShardTest {
 
                 // Commit index should advance as we do not have an empty modification
                 assertEquals(0, shardStats.getCommitIndex());
-
-                shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
-
             }
         };
     }
@@ -1446,9 +1267,9 @@ public class ShardTest extends AbstractShardTest {
         testCommitPhaseFailure(false);
     }
 
-    public void testCommitPhaseFailure(final boolean readWrite) throws Throwable {
+    private void testCommitPhaseFailure(final boolean readWrite) throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testCommitPhaseFailure-" + readWrite);
 
@@ -1515,8 +1336,6 @@ public class ShardTest extends AbstractShardTest {
             inOrder.verify(cohort1).preCommit();
             inOrder.verify(cohort1).commit();
             inOrder.verify(cohort2).canCommit();
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1526,9 +1345,9 @@ public class ShardTest extends AbstractShardTest {
         testPreCommitPhaseFailure(false);
     }
 
-    public void testPreCommitPhaseFailure(final boolean readWrite) throws Throwable {
+    private void testPreCommitPhaseFailure(final boolean readWrite) throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testPreCommitPhaseFailure-" + readWrite);
 
@@ -1589,8 +1408,6 @@ public class ShardTest extends AbstractShardTest {
             inOrder.verify(cohort1).canCommit();
             inOrder.verify(cohort1).preCommit();
             inOrder.verify(cohort2).canCommit();
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1600,9 +1417,9 @@ public class ShardTest extends AbstractShardTest {
         testCanCommitPhaseFailure(false);
     }
 
-    public void testCanCommitPhaseFailure(final boolean readWrite) throws Throwable {
+    private void testCanCommitPhaseFailure(final boolean readWrite) throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testCanCommitPhaseFailure-" + readWrite);
 
@@ -1637,8 +1454,6 @@ public class ShardTest extends AbstractShardTest {
             final CanCommitTransactionReply reply = CanCommitTransactionReply.fromSerializable(
                     expectMsgClass(CanCommitTransactionReply.SERIALIZABLE_CLASS));
             assertEquals("getCanCommit", true, reply.getCanCommit());
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1648,9 +1463,9 @@ public class ShardTest extends AbstractShardTest {
         testCanCommitPhaseFalseResponse(false);
     }
 
-    public void testCanCommitPhaseFalseResponse(final boolean readWrite) throws Throwable {
+    private void testCanCommitPhaseFalseResponse(final boolean readWrite) throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testCanCommitPhaseFalseResponse-" + readWrite);
 
@@ -1687,8 +1502,6 @@ public class ShardTest extends AbstractShardTest {
             reply = CanCommitTransactionReply.fromSerializable(
                     expectMsgClass(CanCommitTransactionReply.SERIALIZABLE_CLASS));
             assertEquals("getCanCommit", true, reply.getCanCommit());
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1698,9 +1511,9 @@ public class ShardTest extends AbstractShardTest {
         testImmediateCommitWithCanCommitPhaseFailure(false);
     }
 
-    public void testImmediateCommitWithCanCommitPhaseFailure(final boolean readWrite) throws Throwable {
+    private void testImmediateCommitWithCanCommitPhaseFailure(final boolean readWrite) throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testImmediateCommitWithCanCommitPhaseFailure-" + readWrite);
 
@@ -1734,8 +1547,6 @@ public class ShardTest extends AbstractShardTest {
             shard.tell(prepareReadyTransactionMessage(readWrite, shard.underlyingActor(), cohort, transactionID2, modification, true), getRef());
 
             expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1745,9 +1556,9 @@ public class ShardTest extends AbstractShardTest {
         testImmediateCommitWithCanCommitPhaseFalseResponse(false);
     }
 
-    public void testImmediateCommitWithCanCommitPhaseFalseResponse(final boolean readWrite) throws Throwable {
+    private void testImmediateCommitWithCanCommitPhaseFalseResponse(final boolean readWrite) throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testImmediateCommitWithCanCommitPhaseFalseResponse-" + readWrite);
 
@@ -1781,8 +1592,6 @@ public class ShardTest extends AbstractShardTest {
             shard.tell(prepareReadyTransactionMessage(readWrite, shard.underlyingActor(), cohort, transactionID2, modification, true), getRef());
 
             expectMsgClass(duration, CommitTransactionReply.SERIALIZABLE_CLASS);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1792,9 +1601,9 @@ public class ShardTest extends AbstractShardTest {
         testAbortBeforeFinishCommit(false);
     }
 
-    public void testAbortBeforeFinishCommit(final boolean readWrite) throws Throwable {
+    private void testAbortBeforeFinishCommit(final boolean readWrite) throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testAbortBeforeFinishCommit-" + readWrite);
 
@@ -1846,8 +1655,6 @@ public class ShardTest extends AbstractShardTest {
             // 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());
         }};
     }
 
@@ -1857,11 +1664,11 @@ public class ShardTest extends AbstractShardTest {
         testTransactionCommitTimeout(false);
     }
 
-    public void testTransactionCommitTimeout(final boolean readWrite) throws Throwable {
+    private void testTransactionCommitTimeout(final boolean readWrite) throws Throwable {
         dataStoreContextBuilder.shardTransactionCommitTimeoutInSeconds(1);
 
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testTransactionCommitTimeout-" + readWrite);
 
@@ -1926,8 +1733,6 @@ public class ShardTest extends AbstractShardTest {
 
             final NormalizedNode<?, ?> node = readStore(shard, listNodePath);
             assertNotNull(listNodePath + " not found", node);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1936,7 +1741,7 @@ public class ShardTest extends AbstractShardTest {
         dataStoreContextBuilder.shardTransactionCommitQueueCapacity(2);
 
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testTransactionCommitQueueCapacityExceeded");
 
@@ -1989,8 +1794,6 @@ public class ShardTest extends AbstractShardTest {
 
             shard.tell(new CanCommitTransaction(transactionID3).toSerializable(), getRef());
             expectMsgClass(duration, akka.actor.Status.Failure.class);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -1999,7 +1802,7 @@ public class ShardTest extends AbstractShardTest {
         dataStoreContextBuilder.shardCommitQueueExpiryTimeoutInMillis(1300).shardTransactionCommitTimeoutInSeconds(1);
 
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testTransactionCommitWithPriorExpiredCohortEntries");
 
@@ -2038,8 +1841,6 @@ public class ShardTest extends AbstractShardTest {
 
             shard.tell(new CanCommitTransaction(transactionID3).toSerializable(), getRef());
             expectMsgClass(duration, CanCommitTransactionReply.SERIALIZABLE_CLASS);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -2048,7 +1849,7 @@ public class ShardTest extends AbstractShardTest {
         dataStoreContextBuilder.shardCommitQueueExpiryTimeoutInMillis(1300).shardTransactionCommitTimeoutInSeconds(1);
 
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testTransactionCommitWithSubsequentExpiredCohortEntry");
 
@@ -2104,22 +1905,18 @@ public class ShardTest extends AbstractShardTest {
 
             final NormalizedNode<?, ?> node = readStore(shard, TestModel.TEST2_PATH);
             assertNotNull(TestModel.TEST2_PATH + " not found", node);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
     @Test
     public void testCanCommitBeforeReadyFailure() throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     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());
         }};
     }
 
@@ -2129,9 +1926,9 @@ public class ShardTest extends AbstractShardTest {
         testAbortCurrentTransaction(false);
     }
 
-    public void testAbortCurrentTransaction(final boolean readWrite) throws Throwable {
+    private void testAbortCurrentTransaction(final boolean readWrite) throws Throwable {
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                     "testAbortCurrentTransaction-" + readWrite);
 
@@ -2185,8 +1982,6 @@ public class ShardTest extends AbstractShardTest {
             final InOrder inOrder = inOrder(cohort1, cohort2);
             inOrder.verify(cohort1).canCommit();
             inOrder.verify(cohort2).canCommit();
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -2196,7 +1991,7 @@ public class ShardTest extends AbstractShardTest {
         testAbortQueuedTransaction(false);
     }
 
-    public void testAbortQueuedTransaction(final boolean readWrite) throws Throwable {
+    private void testAbortQueuedTransaction(final boolean readWrite) throws Throwable {
         dataStoreContextBuilder.shardTransactionCommitTimeoutInSeconds(1);
         new ShardTestKit(getSystem()) {{
             final AtomicReference<CountDownLatch> cleaupCheckLatch = new AtomicReference<>();
@@ -2218,7 +2013,7 @@ public class ShardTest extends AbstractShardTest {
                 }
             };
 
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     Props.create(new DelegatingShardCreator(creator)).withDispatcher(
                             Dispatchers.DefaultDispatcherId()), "testAbortQueuedTransaction-" + readWrite);
 
@@ -2260,8 +2055,6 @@ public class ShardTest extends AbstractShardTest {
 
             Throwable failure = expectMsgClass(duration, akka.actor.Status.Failure.class).cause();
             assertTrue("Failure type", failure instanceof IllegalStateException);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -2276,7 +2069,7 @@ public class ShardTest extends AbstractShardTest {
     }
 
     @SuppressWarnings("serial")
-    public void testCreateSnapshot(final boolean persistent, final String shardActorName) throws Exception{
+    private void testCreateSnapshot(final boolean persistent, final String shardActorName) throws Exception{
 
         final AtomicReference<CountDownLatch> latch = new AtomicReference<>(new CountDownLatch(1));
 
@@ -2325,7 +2118,7 @@ public class ShardTest extends AbstractShardTest {
                 }
             };
 
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(
                     Props.create(new DelegatingShardCreator(creator)), shardActorName);
 
             waitUntilLeader(shard);
@@ -2340,31 +2133,26 @@ public class ShardTest extends AbstractShardTest {
 
             raftActorContext.getSnapshotManager().capture(mock(ReplicatedLogEntry.class), -1);
             awaitAndValidateSnapshot(expectedRoot);
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }
 
-            private void awaitAndValidateSnapshot(NormalizedNode<?,?> expectedRoot
-                                              ) throws InterruptedException {
-                System.out.println("Inside awaitAndValidateSnapshot {}" + savedSnapshot.get());
-                assertEquals("Snapshot saved", true, latch.get().await(5, TimeUnit.SECONDS));
+        private void awaitAndValidateSnapshot(NormalizedNode<?,?> expectedRoot) throws InterruptedException {
+            assertEquals("Snapshot saved", true, latch.get().await(5, TimeUnit.SECONDS));
 
-                assertTrue("Invalid saved snapshot " + savedSnapshot.get(),
-                        savedSnapshot.get() instanceof Snapshot);
+            assertTrue("Invalid saved snapshot " + savedSnapshot.get(),
+                    savedSnapshot.get() instanceof Snapshot);
 
-                verifySnapshot((Snapshot)savedSnapshot.get(), expectedRoot);
+            verifySnapshot((Snapshot)savedSnapshot.get(), expectedRoot);
 
-                latch.set(new CountDownLatch(1));
-                savedSnapshot.set(null);
-            }
+            latch.set(new CountDownLatch(1));
+            savedSnapshot.set(null);
+        }
 
-            private void verifySnapshot(final Snapshot snapshot, final NormalizedNode<?,?> expectedRoot) {
+        private void verifySnapshot(final Snapshot snapshot, final NormalizedNode<?,?> expectedRoot) {
 
-                final NormalizedNode<?, ?> actual = SerializationUtils.deserializeNormalizedNode(snapshot.getState());
-                assertEquals("Root node", expectedRoot, actual);
+            final NormalizedNode<?, ?> actual = SerializationUtils.deserializeNormalizedNode(snapshot.getState());
+            assertEquals("Root node", expectedRoot, actual);
 
-           }
-        };
+        }};
     }
 
     /**
@@ -2413,22 +2201,14 @@ public class ShardTest extends AbstractShardTest {
                 schemaContext(SCHEMA_CONTEXT).props();
 
         new ShardTestKit(getSystem()) {{
-            final TestActorRef<Shard> shard1 = TestActorRef.create(getSystem(),
-                    persistentProps, "testPersistence1");
+            final TestActorRef<Shard> shard1 = actorFactory.createTestActor(persistentProps, "testPersistence1");
 
             assertTrue("Recovery Applicable", shard1.underlyingActor().persistence().isRecoveryApplicable());
 
-            shard1.tell(PoisonPill.getInstance(), ActorRef.noSender());
-
-            final TestActorRef<Shard> shard2 = TestActorRef.create(getSystem(),
-                    nonPersistentProps, "testPersistence2");
+            final TestActorRef<Shard> shard2 = actorFactory.createTestActor(nonPersistentProps, "testPersistence2");
 
             assertFalse("Recovery Not Applicable", shard2.underlyingActor().persistence().isRecoveryApplicable());
-
-            shard2.tell(PoisonPill.getInstance(), ActorRef.noSender());
-
         }};
-
     }
 
     @Test
@@ -2436,7 +2216,7 @@ public class ShardTest extends AbstractShardTest {
         new ShardTestKit(getSystem()) {{
             dataStoreContextBuilder.persistent(true);
 
-            final TestActorRef<Shard> shard = TestActorRef.create(getSystem(), newShardProps(), "testOnDatastoreContext");
+            final TestActorRef<Shard> shard = actorFactory.createTestActor(newShardProps(), "testOnDatastoreContext");
 
             assertEquals("isRecoveryApplicable", true,
                     shard.underlyingActor().persistence().isRecoveryApplicable());
@@ -2452,8 +2232,6 @@ public class ShardTest extends AbstractShardTest {
 
             assertEquals("isRecoveryApplicable", true,
                 shard.underlyingActor().persistence().isRecoveryApplicable());
-
-            shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
         }};
     }
 
@@ -2461,7 +2239,7 @@ public class ShardTest extends AbstractShardTest {
     public void testRegisterRoleChangeListener() throws Exception {
         new ShardTestKit(getSystem()) {
             {
-                final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+                final TestActorRef<Shard> shard = actorFactory.createTestActor(
                         newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                         "testRegisterRoleChangeListener");
 
@@ -2491,15 +2269,13 @@ public class ShardTest extends AbstractShardTest {
                         ShardLeaderStateChanged.class);
                 assertEquals("getLocalShardDataTree present", false,
                         leaderStateChanged.getLocalShardDataTree().isPresent());
-
-                shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
             }
         };
     }
 
     @Test
     public void testFollowerInitialSyncStatus() throws Exception {
-        final TestActorRef<Shard> shard = TestActorRef.create(getSystem(),
+        final TestActorRef<Shard> shard = actorFactory.createTestActor(
                 newShardProps().withDispatcher(Dispatchers.DefaultDispatcherId()),
                 "testFollowerInitialSyncStatus");
 
@@ -2510,14 +2286,6 @@ public class ShardTest extends AbstractShardTest {
         shard.underlyingActor().onReceiveCommand(new FollowerInitialSyncUpStatus(true, "member-1-shard-inventory-operational"));
 
         assertEquals(true, shard.underlyingActor().getShardMBean().getFollowerInitialSyncStatus());
-
-        shard.tell(PoisonPill.getInstance(), ActorRef.noSender());
-    }
-
-    private static void commitTransaction(final DataTree store, final DataTreeModification modification) throws DataValidationFailedException {
-        modification.ready();
-        store.validate(modification);
-        store.commit(store.prepare(modification));
     }
 
     @Test
@@ -2670,7 +2438,7 @@ public class ShardTest extends AbstractShardTest {
 
     @Test
     public void testServerRemoved() throws Exception {
-        final TestActorRef<MessageCollectorActor> parent = TestActorRef.create(getSystem(), MessageCollectorActor.props());
+        final TestActorRef<MessageCollectorActor> parent = actorFactory.createTestActor(MessageCollectorActor.props());
 
         final ActorRef shard = parent.underlyingActor().context().actorOf(
                 newShardBuilder().props().withDispatcher(Dispatchers.DefaultDispatcherId()),
@@ -2679,7 +2447,5 @@ public class ShardTest extends AbstractShardTest {
         shard.tell(new ServerRemoved("test"), ActorRef.noSender());
 
         MessageCollectorActor.expectFirstMatching(parent, ServerRemoved.class);
-
     }
-
 }