You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by mw...@apache.org on 2018/11/27 21:17:44 UTC

[accumulo-testing] branch master updated: Major refactor to support running in Docker (#43)

This is an automated email from the ASF dual-hosted git repository.

mwalch pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/accumulo-testing.git


The following commit(s) were added to refs/heads/master by this push:
     new 1fec443  Major refactor to support running in Docker (#43)
1fec443 is described below

commit 1fec44327ccc3fd1d32f034df9921df98bdf0973
Author: Mike Walch <mw...@apache.org>
AuthorDate: Tue Nov 27 16:17:40 2018 -0500

    Major refactor to support running in Docker (#43)
    
    * Multiple test clients are now run in Docker instead of YARN
    * Tests can still be run locally but accumulo-testing script
      has been removed and replaced by seperate scripts for
      cingest, rwalk, and agitator
    * Project no longer contains multiple Maven modules
    * Renamed package to remove 'core' from it
    * Renamed accumulo-testing.env to env.sh
    * Created Dockerfile
---
 Dockerfile                                         |  41 ++++
 README.md                                          |  98 ++++----
 bin/accumulo-testing                               | 268 ---------------------
 bin/agitator                                       | 115 +++++++++
 .../test/resources/log4j.properties => bin/build   |  14 +-
 bin/cingest                                        |  95 ++++++++
 bin/{performance-test => performance}              |   6 +-
 .../test/resources/log4j.properties => bin/rwalk   |  36 ++-
 conf/.gitignore                                    |   3 +-
 ...umulo-testing-env.sh.example => env.sh.example} |  32 ++-
 core/.gitignore                                    |   7 -
 core/pom.xml                                       | 136 -----------
 pom.xml                                            | 244 +++++++++----------
 .../main/docker/docker-entry                       |  40 ++-
 .../java/org/apache/accumulo/testing}/TestEnv.java |   2 +-
 .../org/apache/accumulo/testing}/TestProps.java    |   2 +-
 .../testing}/continuous/ContinuousBatchWalker.java |   4 +-
 .../testing}/continuous/ContinuousEnv.java         |   6 +-
 .../testing}/continuous/ContinuousIngest.java      |   4 +-
 .../testing}/continuous/ContinuousMoru.java        |   5 +-
 .../testing}/continuous/ContinuousOpts.java        |   2 +-
 .../testing}/continuous/ContinuousScanner.java     |   4 +-
 .../testing}/continuous/ContinuousUtil.java        |   2 +-
 .../testing}/continuous/ContinuousVerify.java      |   8 +-
 .../testing}/continuous/ContinuousWalk.java        |   4 +-
 .../accumulo/testing}/continuous/CreateTable.java  |   4 +-
 .../accumulo/testing}/continuous/TimeBinner.java   |   2 +-
 .../testing}/continuous/UndefinedAnalyzer.java     |   2 +-
 .../testing}/ingest/BulkImportDirectory.java       |   2 +-
 .../accumulo/testing}/ingest/TestIngest.java       |   2 +-
 .../accumulo/testing}/ingest/VerifyIngest.java     |   2 +-
 .../accumulo/testing}/mapreduce/RowHash.java       |   4 +-
 .../testing}/mapreduce/TeraSortIngest.java         |   4 +-
 .../accumulo/testing}/merkle/MerkleTree.java       |   2 +-
 .../accumulo/testing}/merkle/MerkleTreeNode.java   |   2 +-
 .../testing}/merkle/RangeSerialization.java        |   2 +-
 .../testing}/merkle/cli/CompareTables.java         |   2 +-
 .../testing}/merkle/cli/ComputeRootHash.java       |   8 +-
 .../testing}/merkle/cli/GenerateHashes.java        |   6 +-
 .../testing}/merkle/cli/ManualComparison.java      |   2 +-
 .../testing}/merkle/ingest/RandomWorkload.java     |   2 +-
 .../accumulo/testing}/merkle/package-info.java     |   2 +-
 .../testing}/merkle/skvi/DigestIterator.java       |   2 +-
 .../accumulo/testing}/performance/Environment.java |   2 +-
 .../accumulo/testing}/performance/Parameter.java   |   2 +-
 .../testing}/performance/PerformanceTest.java      |   2 +-
 .../accumulo/testing}/performance/Report.java      |   4 +-
 .../accumulo/testing}/performance/Result.java      |   2 +-
 .../accumulo/testing}/performance/Stats.java       |   2 +-
 .../testing}/performance/SystemConfiguration.java  |   2 +-
 .../testing}/performance/impl/Compare.java         |   7 +-
 .../performance/impl/ContextualReport.java         |   4 +-
 .../accumulo/testing}/performance/impl/Csv.java    |   7 +-
 .../testing}/performance/impl/ListTests.java       |   4 +-
 .../testing}/performance/impl/MergeSiteConfig.java |   4 +-
 .../testing}/performance/impl/PerfTestRunner.java  |   8 +-
 .../performance/tests/RandomCachedLookupsPT.java   |  15 +-
 .../testing}/performance/tests/ScanExecutorPT.java |  14 +-
 .../performance/tests/ScanFewFamiliesPT.java       |  12 +-
 .../testing}/performance/util/TestData.java        |   2 +-
 .../testing}/performance/util/TestExecutor.java    |   2 +-
 .../accumulo/testing}/randomwalk/Fixture.java      |   2 +-
 .../accumulo/testing}/randomwalk/Framework.java    |   2 +-
 .../accumulo/testing}/randomwalk/Module.java       |   2 +-
 .../apache/accumulo/testing}/randomwalk/Node.java  |   2 +-
 .../accumulo/testing}/randomwalk/RandWalkEnv.java  |   4 +-
 .../apache/accumulo/testing}/randomwalk/State.java |   2 +-
 .../apache/accumulo/testing}/randomwalk/Test.java  |   2 +-
 .../testing}/randomwalk/bulk/BulkImportTest.java   |   6 +-
 .../testing}/randomwalk/bulk/BulkMinusOne.java     |   6 +-
 .../testing}/randomwalk/bulk/BulkPlusOne.java      |   6 +-
 .../testing}/randomwalk/bulk/BulkTest.java         |   8 +-
 .../accumulo/testing}/randomwalk/bulk/Compact.java |   6 +-
 .../testing}/randomwalk/bulk/ConsistencyCheck.java |   6 +-
 .../accumulo/testing}/randomwalk/bulk/Merge.java   |   6 +-
 .../randomwalk/bulk/SelectiveBulkTest.java         |   6 +-
 .../randomwalk/bulk/SelectiveQueueing.java         |   6 +-
 .../accumulo/testing}/randomwalk/bulk/Setup.java   |   8 +-
 .../accumulo/testing}/randomwalk/bulk/Split.java   |   6 +-
 .../accumulo/testing}/randomwalk/bulk/Verify.java  |   8 +-
 .../testing}/randomwalk/concurrent/AddSplits.java  |   8 +-
 .../testing}/randomwalk/concurrent/BatchScan.java  |   8 +-
 .../testing}/randomwalk/concurrent/BatchWrite.java |   8 +-
 .../testing}/randomwalk/concurrent/BulkImport.java |   8 +-
 .../concurrent/ChangeAuthorizations.java           |   8 +-
 .../randomwalk/concurrent/ChangePermissions.java   |   8 +-
 .../randomwalk/concurrent/CheckPermission.java     |   8 +-
 .../testing}/randomwalk/concurrent/CloneTable.java |   8 +-
 .../testing}/randomwalk/concurrent/Compact.java    |   8 +-
 .../randomwalk/concurrent/ConcurrentFixture.java   |   8 +-
 .../testing}/randomwalk/concurrent/Config.java     |   8 +-
 .../randomwalk/concurrent/CreateNamespace.java     |   8 +-
 .../randomwalk/concurrent/CreateTable.java         |   8 +-
 .../testing}/randomwalk/concurrent/CreateUser.java |   8 +-
 .../randomwalk/concurrent/DeleteNamespace.java     |   8 +-
 .../randomwalk/concurrent/DeleteRange.java         |   8 +-
 .../randomwalk/concurrent/DeleteTable.java         |   8 +-
 .../testing}/randomwalk/concurrent/DropUser.java   |   8 +-
 .../randomwalk/concurrent/IsolatedScan.java        |   8 +-
 .../testing}/randomwalk/concurrent/ListSplits.java |   8 +-
 .../testing}/randomwalk/concurrent/Merge.java      |   8 +-
 .../randomwalk/concurrent/OfflineTable.java        |   8 +-
 .../randomwalk/concurrent/RenameNamespace.java     |   8 +-
 .../randomwalk/concurrent/RenameTable.java         |   8 +-
 .../randomwalk/concurrent/Replication.java         |  15 +-
 .../testing}/randomwalk/concurrent/ScanTable.java  |   8 +-
 .../testing}/randomwalk/concurrent/Setup.java      |   8 +-
 .../testing}/randomwalk/conditional/Compact.java   |   8 +-
 .../testing}/randomwalk/conditional/Flush.java     |   8 +-
 .../testing}/randomwalk/conditional/Init.java      |   8 +-
 .../testing}/randomwalk/conditional/Merge.java     |   8 +-
 .../testing}/randomwalk/conditional/Setup.java     |   8 +-
 .../testing}/randomwalk/conditional/Split.java     |   8 +-
 .../testing}/randomwalk/conditional/TearDown.java  |   8 +-
 .../testing}/randomwalk/conditional/Transfer.java  |   8 +-
 .../testing}/randomwalk/conditional/Utils.java     |   2 +-
 .../testing}/randomwalk/conditional/Verify.java    |   8 +-
 .../accumulo/testing}/randomwalk/image/Commit.java |   8 +-
 .../testing}/randomwalk/image/ImageFixture.java    |   8 +-
 .../testing}/randomwalk/image/ScanMeta.java        |   8 +-
 .../testing}/randomwalk/image/TableOp.java         |   8 +-
 .../accumulo/testing}/randomwalk/image/Verify.java |   8 +-
 .../accumulo/testing}/randomwalk/image/Write.java  |   8 +-
 .../testing}/randomwalk/multitable/Commit.java     |   8 +-
 .../testing}/randomwalk/multitable/CopyTable.java  |   8 +-
 .../testing}/randomwalk/multitable/CopyTool.java   |   2 +-
 .../randomwalk/multitable/CreateTable.java         |   8 +-
 .../testing}/randomwalk/multitable/DropTable.java  |   8 +-
 .../randomwalk/multitable/MultiTableFixture.java   |   8 +-
 .../randomwalk/multitable/OfflineTable.java        |   8 +-
 .../testing}/randomwalk/multitable/Write.java      |   8 +-
 .../randomwalk/security/AlterSystemPerm.java       |   8 +-
 .../testing}/randomwalk/security/AlterTable.java   |   8 +-
 .../randomwalk/security/AlterTablePerm.java        |   8 +-
 .../testing}/randomwalk/security/Authenticate.java |   8 +-
 .../testing}/randomwalk/security/ChangePass.java   |   8 +-
 .../testing}/randomwalk/security/CreateTable.java  |   8 +-
 .../testing}/randomwalk/security/CreateUser.java   |   8 +-
 .../testing}/randomwalk/security/DropTable.java    |   8 +-
 .../testing}/randomwalk/security/DropUser.java     |   8 +-
 .../randomwalk/security/SecurityFixture.java       |   8 +-
 .../randomwalk/security/SecurityHelper.java        |   4 +-
 .../testing}/randomwalk/security/SetAuths.java     |   8 +-
 .../testing}/randomwalk/security/TableOp.java      |   8 +-
 .../testing}/randomwalk/security/Validate.java     |   8 +-
 .../randomwalk/security/WalkingSecurity.java       |   6 +-
 .../randomwalk/sequential/BatchVerify.java         |   8 +-
 .../testing}/randomwalk/sequential/Commit.java     |   8 +-
 .../randomwalk/sequential/MapRedVerify.java        |   8 +-
 .../randomwalk/sequential/MapRedVerifyTool.java    |   2 +-
 .../randomwalk/sequential/SequentialFixture.java   |   8 +-
 .../testing}/randomwalk/sequential/Write.java      |   8 +-
 .../testing}/randomwalk/shard/BulkInsert.java      |   8 +-
 .../testing}/randomwalk/shard/CloneIndex.java      |   8 +-
 .../accumulo/testing}/randomwalk/shard/Commit.java |   8 +-
 .../testing}/randomwalk/shard/CompactFilter.java   |   8 +-
 .../accumulo/testing}/randomwalk/shard/Delete.java |   8 +-
 .../testing}/randomwalk/shard/DeleteSomeDocs.java  |   8 +-
 .../testing}/randomwalk/shard/DeleteWord.java      |   8 +-
 .../testing}/randomwalk/shard/ExportIndex.java     |   8 +-
 .../accumulo/testing}/randomwalk/shard/Flush.java  |   8 +-
 .../accumulo/testing}/randomwalk/shard/Grep.java   |   8 +-
 .../accumulo/testing}/randomwalk/shard/Insert.java |   8 +-
 .../accumulo/testing}/randomwalk/shard/Merge.java  |   8 +-
 .../testing}/randomwalk/shard/Reindex.java         |   8 +-
 .../accumulo/testing}/randomwalk/shard/Search.java |   8 +-
 .../testing}/randomwalk/shard/ShardFixture.java    |   8 +-
 .../testing}/randomwalk/shard/SortTool.java        |   2 +-
 .../accumulo/testing}/randomwalk/shard/Split.java  |   8 +-
 .../testing}/randomwalk/shard/VerifyIndex.java     |   8 +-
 .../testing}/randomwalk/unit/CreateTable.java      |   8 +-
 .../testing}/randomwalk/unit/DeleteTable.java      |   8 +-
 .../accumulo/testing}/randomwalk/unit/Ingest.java  |   8 +-
 .../accumulo/testing}/randomwalk/unit/Scan.java    |   8 +-
 .../accumulo/testing}/randomwalk/unit/Verify.java  |   8 +-
 .../accumulo/testing}/scalability/Ingest.java      |   4 +-
 .../apache/accumulo/testing}/scalability/Run.java  |   2 +-
 .../accumulo/testing}/scalability/ScaleTest.java   |   2 +-
 .../accumulo/testing}/stress/DataWriter.java       |   2 +-
 .../accumulo/testing}/stress/IntArgValidator.java  |   2 +-
 .../accumulo/testing}/stress/RandomByteArrays.java |   2 +-
 .../accumulo/testing}/stress/RandomMutations.java  |   2 +-
 .../testing}/stress/RandomWithinRange.java         |   2 +-
 .../org/apache/accumulo/testing}/stress/Scan.java  |   2 +-
 .../apache/accumulo/testing}/stress/ScanOpts.java  |   2 +-
 .../apache/accumulo/testing}/stress/Stream.java    |   2 +-
 .../org/apache/accumulo/testing}/stress/Write.java |   2 +-
 .../accumulo/testing}/stress/WriteOptions.java     |   2 +-
 .../accumulo/testing}/stress/package-info.java     |   8 +-
 .../main/resources/randomwalk/module.xsd           |   0
 .../main/resources/randomwalk/modules/All.xml      |   0
 .../main/resources/randomwalk/modules/Bulk.xml     |   2 +-
 .../resources/randomwalk/modules/Concurrent.xml    |   2 +-
 .../resources/randomwalk/modules/Conditional.xml   |   2 +-
 .../main/resources/randomwalk/modules/Image.xml    |   2 +-
 .../resources/randomwalk/modules/LongClean.xml     |   0
 .../resources/randomwalk/modules/LongDirty.xml     |   0
 .../main/resources/randomwalk/modules/LongEach.xml |   0
 .../resources/randomwalk/modules/MultiTable.xml    |   2 +-
 .../resources/randomwalk/modules/Replication.xml   |   0
 .../main/resources/randomwalk/modules/Security.xml |   2 +-
 .../resources/randomwalk/modules/Sequential.xml    |   2 +-
 .../main/resources/randomwalk/modules/Shard.xml    |   2 +-
 .../resources/randomwalk/modules/ShortClean.xml    |   0
 .../resources/randomwalk/modules/ShortDirty.xml    |   0
 .../resources/randomwalk/modules/ShortEach.xml     |   0
 .../resources/randomwalk/modules/unit/Basic.xml    |   2 +-
 .../resources/randomwalk/modules/unit/Simple.xml   |   2 +-
 .../testing}/randomwalk/FrameworkTest.java         |   8 +-
 .../randomwalk/ReplicationRandomWalkIT.java        |   4 +-
 {core/src => src}/test/resources/log4j.properties  |   0
 yarn/.gitignore                                    |   7 -
 yarn/pom.xml                                       | 110 ---------
 .../testing/yarn/YarnAccumuloTestRunner.java       | 153 ------------
 yarn/src/main/resources/logback.xml                |  31 ---
 215 files changed, 1073 insertions(+), 1452 deletions(-)

diff --git a/Dockerfile b/Dockerfile
new file mode 100644
index 0000000..85cce6e
--- /dev/null
+++ b/Dockerfile
@@ -0,0 +1,41 @@
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
+FROM centos:7
+
+RUN yum install -y java-1.8.0-openjdk-devel
+ENV JAVA_HOME /usr/lib/jvm/java-1.8.0-openjdk
+
+ARG TEST_JAR_VERSION
+ENV TEST_JAR_VERSION 2.0.0-SNAPSHOT
+ENV TEST_JAR_PATH /opt/accumulo-testing-${TEST_JAR_VERSION}-shaded.jar
+ENV ACCUMULO_CLIENT_PROPS /opt/conf/accumulo-client.properties
+ENV TEST_PROPS /opt/conf/accumulo-testing.properties
+ENV TEST_LOG4J /opt/conf/log4j.properties.example
+
+RUN mkdir /opt/bin
+RUN mkdir /opt/conf
+RUN touch /opt/conf/env.sh
+
+ADD ./conf/accumulo-client.properties /opt/conf/
+ADD ./conf/accumulo-testing.properties /opt/conf/
+ADD ./conf/log4j.properties.example /opt/conf/
+ADD ./bin/cingest /opt/bin
+ADD ./bin/rwalk /opt/bin
+ADD ./src/main/docker/docker-entry /opt/bin
+ADD ./target/accumulo-testing-${TEST_JAR_VERSION}-shaded.jar /opt/
+
+ENTRYPOINT ["/opt/bin/docker-entry"]
+CMD ["help"]
diff --git a/README.md b/README.md
index 30bf683..d659f8d 100644
--- a/README.md
+++ b/README.md
@@ -23,10 +23,50 @@ on your machine as well as an Accumulo instance to use for testing.
         cp accumulo-testing.properties.example accumulo-testing.properties
         vim accumulo-testing.properties
 
-3. Tests are run using the `accumulo-testing` command which is located in the `bin/`
-   directory. Run this command without any arguments to view its usage and see available tests.
 
-        ./bin/accumulo-testing
+### Run tests locally
+
+Tests are run using the following scripts in `bin/`:
+
+  * `cingest` - Runs continous ingest tests
+  * `rwalk` - Runs random walk tests
+  * `performance` - Runs performance test
+  * `agitator` - Runs agitator
+
+Run the scripts without arguments to view usage.
+
+### Run tests in Docker
+
+While test scripts can be run from a single machine, they will put more stress if they are run from
+multiple machines. The easiest way to do this is using Docker. However, only the tests below can be
+run in Docker:
+
+  * `cingest` - All applications can be run except `verify` & `moru` which launch a MapReduce job.
+  * `rwalk` - All modules can be run.
+
+1. To create the `accumulo-testing` docker image, make sure the following files exist in your clone:
+
+    * `conf/accumulo-client.properties` - Copy and configure this from your Accumulo install
+    * `conf/accumulo-testing.properties` - Copy this from the example file and configure it
+    * `target/accumulo-testing-2.0.0-SNAPSHOT-shaded.jar` - Can be created using `./bin/build`
+
+   Run the following command to create the image:
+
+   ```
+   docker build -t accumulo-testing .
+   ```
+
+2. The `accumulo-testing` image can run a single command:
+
+   ```bash
+   docker run --network="host" accumulo-testing cingest createtable
+   ```
+
+3. Multiple containers can also be run (if you have [Docker Swarm] enabled):
+
+   ```bash
+   docker service create --network="host" --replicas 2 --name ci accumulo-testing cingest ingest
+   ```
 
 ## Random walk test
 
@@ -39,16 +79,7 @@ file. A test module must also be specified. See the [modules] directory for a li
 The command below will start a single random walker in a local process using the [Image.xml][image]
 module.
 
-        ./bin/accumulo-testing rw-local Image.xml
-
-If you would like to run multiple, distributed random walkers, run the command below to start random
-walkers in 5 containers in YARN using the Image.xml module.
-
-        ./bin/accumulo-testing rw-yarn 5 Image.xml
-
-This command will create an application in YARN and exit when all containers for the test have
-started. While its running, you can view logs for each random walker using the YARN resource manager.
-The YARN application can be killed at any time using the YARN resource manager or command line tool.
+        ./bin/rwalk Image.xml
 
 ## Continuous Ingest & Query
 
@@ -69,19 +100,12 @@ First, run the command below to create an Accumulo table for the continuous inge
 table is set by the property `test.ci.common.accumulo.table` (its value defaults to `ci`) in the file
 `accumulo-testing.properties`:
 
-          ./bin/accumulo-testing ci-createtable
+          ./bin/cingest createtable
 
-The continuous ingest tests have several applications that can either be started in a local process
-or run in multiple containers across a cluster using YARN. The `ci-local` command starts a local
-application which will run continuously until you stop using `ctrl-c`:
+The continuous ingest tests have several applications that start a local application which will run
+continuously until you stop using `ctrl-c`:
 
-          ./bin/accumulo-testing ci-local <application>
-
-The `ci-yarn` command starts an application in `<num>` containers in YARN. All containers will run
-continuously performing the same work until you kill the application in YARN. The logs for the
-application can be viewed using the YARN resource manager.
-
-          ./bin/accumulo-testing ci-yarn <num> <application>
+          ./bin/cingest <application>
 
 Below is a list of available continuous ingest applications. You should run the `ingest` application
 first to add data to your table.
@@ -91,15 +115,7 @@ first to add data to your table.
   produces detailed statistics on query/scan times.
 * `batchwalk` - Randomly walks the graph created by ingest using a batch scanner.
 * `scan` - Scans the graph
-
-The continuous ingest test has two MapReduce jobs that are used to verify and stress
-Accumulo and have the following command:
-
-          ./bin/accumulo-testing ci-mapred <application>
-
-Below is a list of available MapReduce applications:
-
-1. `verify` - Runs a MapReduce job that verifies all data created by continuous ingest. Before
+* `verify` - Runs a MapReduce job that verifies all data created by continuous ingest. Before
 running, review all `test.ci.verify.*` properties. Do not run ingest while running this command as
 it will cause erroneous reporting of UNDEFINED nodes. Each entry, except for the first batch of
 entries, inserted by continuous ingest references a previously flushed entry. Since we are
@@ -109,8 +125,7 @@ the referenced but undefined node.  The MapReduce job produces two other counts:
 UNREFERENCED. It is expected that these two counts are non zero. REFERENCED counts nodes that are
 defined and referenced. UNREFERENCED counts nodes that defined and unreferenced, these are the
 latest nodes inserted.
-
-2. `moru` - Runs a MapReduce job that stresses Accumulo by reading and writing the continuous ingest
+* `moru` - Runs a MapReduce job that stresses Accumulo by reading and writing the continuous ingest
 table. This MapReduce job will write out an entry for every entry in the table (except for ones
 created by the MapReduce job itself). Stop ingest before running this MapReduce job. Do not run more
 than one instance of this MapReduce job concurrently against a table.
@@ -121,10 +136,10 @@ The agitator will periodically kill the Accumulo master, tablet server, and Hado
 processes on random nodes. Before running the agitator you should create `accumulo-testing-env.sh`
 in `conf/` and review all of the agitator settings. The command below will start the agitator:
 
-            ./bin/accumulo-testing agitator start
+            ./bin/agitator start
 
 You can run this script as root and it will properly start processes as the user you configured in
-`accumulo-testing-env.sh` (`AGTR_HDFS_USER` for the data node and `AGTR_ACCUMULO_USER` for Accumulo
+`env.sh` (`AGTR_HDFS_USER` for the data node and `AGTR_ACCUMULO_USER` for Accumulo
 processes). If you run it as yourself and the `AGTR_HDFS_USER` and `AGTR_ACCUMULO_USER` values are
 the same as your user, the agitator will not change users. In the case where you run the agitator as
 a non-privileged user which isn't the same as `AGTR_HDFS_USER` or `AGTR_ACCUMULO_USER`, the agitator
@@ -133,7 +148,7 @@ that your `AGTR_HDFS_USER` has password-less `ssh` configured.
 
 Run the command below stop the agitator:
 
-            ./bin/accumulo-testing agitator stop
+            ./bin/agitator stop
 
 ## Performance Test
 
@@ -191,8 +206,6 @@ function stop_cluster {
 }
 ```
 
-
-
 An example script for [Uno] is provided.  To use this do the following and set
 `UNO_HOME` after copying. 
 
@@ -201,13 +214,14 @@ An example script for [Uno] is provided.  To use this do the following and set
 After the cluster control script is setup, the following will run performance
 test and produce json result files.
 
-    ./bin/performance-test run <output dir>
+    ./bin/performance run <output dir>
 
-There are some utilities for working with the json result files, run the performance-test script
+There are some utilities for working with the json result files, run the `performance` script
 with no options to see them.
 
 [Uno]: https://github.com/apache/fluo-uno
 [modules]: core/src/main/resources/randomwalk/modules
 [image]: core/src/main/resources/randomwalk/modules/Image.xml
+[Docker Swarm]: https://docs.docker.com/engine/swarm/swarm-tutorial/
 [ti]: https://travis-ci.org/apache/accumulo-testing.svg?branch=master
 [tl]: https://travis-ci.org/apache/accumulo-testing
diff --git a/bin/accumulo-testing b/bin/accumulo-testing
deleted file mode 100755
index 465e11b..0000000
--- a/bin/accumulo-testing
+++ /dev/null
@@ -1,268 +0,0 @@
-#! /usr/bin/env bash
-
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-bin_dir=$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )
-at_home=$( cd "$( dirname "$bin_dir" )" && pwd )
-at_version=2.0.0-SNAPSHOT
-
-function print_usage() {
-  cat <<EOF
-
-Usage: accumulo-testing <command> (<argument>)
-
-Possible commands:
-  agitator <command>            Runs agitator <command>. Available commands: start, stop
-  ci-createtable                Creates Accumulo table with splits for continuous ingest tests
-  ci-local <application>        Runs continuous ingest <application> in local java process
-                                Applications: ingest, walk, batchwalk, scan
-  ci-yarn <num> <application>   Runs continuous ingest <application> in <num> containers in YARN
-                                Applications: ingest, walk, batchwalk, scan
-  ci-mapred <application>       Runs continuous ingest mapreduce <application>
-                                Applications: verify, moru  
-  rw-local <module>*            Runs randomwalk <module> in local java process
-  rw-yarn <num> <module>*       Runs randomwalk <module> in <num> containers on YARN
-                                *Modules located in core/src/main/resources/randomwalk/modules
-EOF
-}
-
-if [ -f "$at_home/conf/accumulo-testing-env.sh" ]; then
-  . "$at_home"/conf/accumulo-testing-env.sh
-else
-  . "$at_home"/conf/accumulo-testing-env.sh.example
-fi
-
-if [ -z "$ACCUMULO_VERSION" ]; then
-  echo "ERROR: ACCUMULO_VERSION must be set conf/accumulo-testing-env.sh"
-  exit 1
-fi
-if [ -z "$HADOOP_VERSION" ]; then
-  echo "ERROR: HADOOP_VERSION must be set conf/accumulo-testing-env.sh"
-  exit 1
-fi
-
-at_props="$at_home/conf/accumulo-testing.properties"
-if [ ! -f "$at_props" ]; then
-  echo "Please create and edit accumulo-testing.properties in $at_home/conf"
-  exit 1
-fi
-
-log4j_config="$at_home/conf/log4j.properties"
-if [ ! -f "$log4j_config" ]; then
-  log4j_config="$at_home/conf/log4j.properties.example"
-  if [ ! -f "$log4j_config" ]; then
-    echo "Could not find logj4.properties or log4j.properties.example in $at_home/conf"
-    exit 1
-  fi
-fi
-
-function build_shade_jar() {
-  export at_shaded_jar="$at_home/core/target/accumulo-testing-core-$at_version-shaded.jar"
-  export CLASSPATH="$at_shaded_jar:$CLASSPATH"
-  if [ ! -f "$at_shaded_jar" ]; then
-    echo "Building $at_shaded_jar"
-    cd "$at_home" || exit 1
-    mvn clean package -P create-shade-jar -D skipTests -D accumulo.version="$ACCUMULO_VERSION" -D hadoop.version="$HADOOP_VERSION" -D zookeeper.version="$ZOOKEEPER_VERSION"
-  fi
-}
-
-function determine_app_main() {
-  ci_package="org.apache.accumulo.testing.core.continuous"
-  case "$1" in 
-    ingest)
-      ci_main="${ci_package}.ContinuousIngest"
-      ;;
-    walk)
-      ci_main="${ci_package}.ContinuousWalk"
-      ;;
-    batchwalk)
-      ci_main="${ci_package}.ContinuousBatchWalker"
-      ;;
-    scan)
-      ci_main="${ci_package}.ContinuousScanner"
-      ;;
-    *)
-      echo "Unknown application: $1"
-      print_usage
-      exit 1    
-  esac
-}
-
-function determine_mapred_main() {
-  ci_package="org.apache.accumulo.testing.core.continuous"
-  case "$1" in 
-    verify)
-      ci_main="${ci_package}.ContinuousVerify"
-      ;;
-    moru)
-      ci_main="${ci_package}.ContinuousMoru"
-      ;;
-    *)
-      echo "Unknown application: $1"
-      print_usage
-      exit 1    
-  esac
-}
-
-function start_agitator() {
-  hash pssh 2>/dev/null || { echo >&2 "The agitator requires pssh to be installed. Aborting."; exit 1; }
-
-  mkdir -p "${at_home}/logs"
-  log_base="${at_home}/logs/$(date +%Y%m%d%H%M%S)_$(hostname)"
-  libexec="${at_home}/libexec"
-  master_log="${log_base}_master-agitator"
-  tserver_log="${log_base}_tserver-agitator"
-  datanode_log="${log_base}_datanode-agitator"
-  master_cmd="nohup ${libexec}/master-agitator.pl $AGTR_MASTER_KILL_SLEEP_TIME $AGTR_MASTER_RESTART_SLEEP_TIME"
-  tserver_cmd="nohup ${libexec}/tserver-agitator.pl $AGTR_TSERVER_KILL_SLEEP_TIME $AGTR_TSERVER_RESTART_SLEEP_TIME $AGTR_TSERVER_MIN_KILL $AGTR_TSERVER_MAX_KILL"
-  datanode_cmd="nohup ${libexec}/datanode-agitator.pl $AGTR_DATANODE_KILL_SLEEP_TIME $AGTR_DATANODE_RESTART_SLEEP_TIME $HADOOP_HOME $AGTR_DATANODE_MIN_KILL $AGTR_DATANODE_MAX_KILL"
-  [[ -n $AGITATOR_USER ]] || AGITATOR_USER=$(whoami)
-
-  if [[ $AGITATOR_USER == root ]];  then
-    echo "Running master-agitator and tserver-agitator as $AGTR_ACCUMULO_USER using su. Running datanode-agitator as $AGTR_HDFS_USER using su."
-    su -c "$master_cmd >${master_log}.out 2>${master_log}.err" & -m - "$AGTR_ACCUMULO_USER"
-    su -c "$tserver_cmd >${tserver_log}.out 2>${tserver_log}.err" & -m - "$AGTR_ACCUMULO_USER"
-    su -c "$datanode_cmd >${datanode_log}.out 2>${datanode_log}.err" & -m - "$AGTR_HDFS_USER"
-  else
-    if [[ $AGITATOR_USER == "$AGTR_ACCUMULO_USER" ]]; then
-      echo "Running master-agitator and tserver-agitator as $AGITATOR_USER"
-      $master_cmd > "${master_log}.out" 2> "${master_log}.err" &
-      $tserver_cmd > "${tserver_log}.out" 2> "${tserver_log}.err" &
-    else 
-      echo "Running master-agitator and tserver-agitator as $AGTR_ACCUMULO_USER using sudo."
-      sudo -u "$AGTR_ACCUMULO_USER" $master_cmd > "${master_log}.out" 2> "${master_log}.err" &
-      sudo -u "$AGTR_ACCUMULO_USER" $tserver_cmd > "${tserver_log}.out" 2> "${tserver_log}.err" &
-    fi
-    if [[ $AGITATOR_USER == "$AGTR_HDFS_USER" ]]; then
-      echo "Running datanode-agitator as $AGITATOR_USER"
-      $datanode_cmd > "${datanode_log}.out" 2> "${datanode_log}.err" &
-    else
-      echo "Running datanode-agitator as $AGTR_HDFS_USER using sudo."
-      sudo -u "$AGTR_HDFS_USER" $datanode_cmd > "${datanode_log}.out" 2> "${datanode_log}.err" &
-    fi
-  fi
-
-  if ${AGTR_HDFS:-false} ; then
-    agitator_log=${log_base}_hdfs-agitator
-    sudo -u "$AGTR_HDFS_SUPERUSER" nohup "${libexec}/hdfs-agitator.pl" --sleep "${AGTR_HDFS_SLEEP_TIME}" --hdfs-cmd "${AGTR_HDFS_COMMAND}" --superuser "${AGTR_HDFS_SUPERUSER}" >"${agitator_log}.out" 2>"${agitator_log}.err" &
-  fi
-}
-
-function stop_agitator() {
-  [[ -n $AGITATOR_USER ]] || AGITATOR_USER=$(whoami)
-  if [[ $AGITATOR_USER == root ]]; then
-    echo "Stopping all processes matching 'agitator.pl' as root"
-    pkill -f agitator.pl 2>/dev/null
-  elif [[ $AGITATOR_USER == "$AGTR_ACCUMULO_USER" ]];  then
-    echo "Stopping all processes matching 'datanode-agitator.pl' as $AGTR_HDFS_USER"
-    sudo -u "$AGTR_HDFS_USER" pkill -f datanode-agitator.pl 2>/dev/null
-    echo "Stopping all processes matching 'hdfs-agitator.pl' as $AGTR_HDFS_USER"
-    sudo -u "$AGTR_HDFS_USER" pkill -f hdfs-agitator.pl 2>/dev/null
-    echo "Stopping all processes matching 'agitator.pl' as $AGITATOR_USER"
-    pkill -f agitator.pl 2>/dev/null 2>/dev/null
-  else
-    echo "Stopping all processes matching 'datanode-agitator.pl' as $AGTR_HDFS_USER"
-    sudo -u "$AGTR_HDFS_USER" pkill -f datanode-agitator.pl 2>/dev/null
-    echo "Stopping all processes matching 'hdfs-agitator.pl' as $AGTR_HDFS_USER"
-    sudo -u "$AGTR_HDFS_USER" pkill -f hdfs-agitator.pl 2>/dev/null
-    echo "Stopping all processes matching 'agitator.pl' as $AGTR_ACCUMULO_USER"
-    sudo -u "$AGTR_ACCUMULO_USER" pkill -f agitator.pl 2>/dev/null
-  fi
-}
-
-randomwalk_main="org.apache.accumulo.testing.core.randomwalk.Framework"
-case "$1" in
-ci-createtable)
-  build_shade_jar
-  java -Dlog4j.configuration="file:$log4j_config" org.apache.accumulo.testing.core.continuous.CreateTable "$at_props" "$ACCUMULO_CLIENT_PROPS"
-  ;;
-ci-local)
-  if [ -z "$2" ]; then
-    echo "ERROR: <application> needs to be set"
-    print_usage
-    exit 1
-  fi
-  determine_app_main "$2"
-  build_shade_jar
-  java -Dlog4j.configuration="file:$log4j_config" "$ci_main" "$at_props" "$ACCUMULO_CLIENT_PROPS"
-  ;;
-ci-yarn)
-  if [ -z "$2" ]; then
-    echo "ERROR: <num> needs to be set"
-    print_usage
-    exit 1
-  fi
-  if [ -z "$3" ]; then
-    echo "ERROR: <application> needs to be set"
-    print_usage
-    exit 1
-  fi
-  determine_app_main "$3"
-  build_shade_jar
-  mvn compile -P yarn-test-runner -D hadoop.version="$HADOOP_VERSION" -D exec.args="-t AccumuloCITest-$3 -j $at_shaded_jar -m $ci_main -n $2 -p $at_props -c $ACCUMULO_CLIENT_PROPS -l $log4j_config -a ./accumulo-testing.properties ./accumulo-client.properties"
-  ;;
-ci-mapred)
-  if [ -z "$2" ]; then
-    echo "ERROR: <application> needs to be set"
-    print_usage
-    exit 1
-  fi
-  determine_mapred_main "$2"
-  build_shade_jar
-  "$HADOOP_HOME"/bin/yarn jar "$at_shaded_jar" "$ci_main" "$at_props" "$ACCUMULO_CLIENT_PROPS"
-  ;;
-rw-local)
-  if [ -z "$2" ]; then
-    echo "ERROR: <module> needs to be set"
-    print_usage
-    exit 1
-  fi
-  build_shade_jar
-  java -Dlog4j.configuration="file:$log4j_config" "$randomwalk_main" "$at_props" "$ACCUMULO_CLIENT_PROPS" "$2"
-  ;;
-rw-yarn)
-  if [ -z "$2" ]; then
-    echo "ERROR: <num> needs to be set"
-    print_usage
-    exit 1
-  fi
-  if [ -z "$3" ]; then
-    echo "ERROR: <module> needs to be set"
-    print_usage
-    exit 1
-  fi
-  build_shade_jar
-  mvn compile -P yarn-test-runner -D hadoop.version="$HADOOP_VERSION" -D exec.args="-t AccumuloRWTest-$3 -j $at_shaded_jar -m $randomwalk_main -n $2 -p $at_props -c $ACCUMULO_CLIENT_PROPS -l $log4j_config -a ./accumulo-testing.properties ./accumulo-client.properties $3"
-  ;;
-agitator)
-  case "$2" in
-    start)
-      start_agitator
-      ;;
-    stop)
-      stop_agitator
-      ;;
-    *)
-      echo "ERROR: unknown command - $2"
-      print_usage
-      exit 1
-  esac
-  ;;
-*)
-  echo "Unknown command: $1"
-  print_usage
-  exit 1
-esac
diff --git a/bin/agitator b/bin/agitator
new file mode 100755
index 0000000..8933b7f
--- /dev/null
+++ b/bin/agitator
@@ -0,0 +1,115 @@
+#! /usr/bin/env bash
+
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
+bin_dir=$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )
+at_home=$( cd "$( dirname "$bin_dir" )" && pwd )
+
+function print_usage() {
+  cat <<EOF
+
+Usage: agitator <command>
+
+Possible commands:
+  start     Starts agitator
+  stop      Stop agitator
+EOF
+}
+
+if [ -f "$at_home/conf/accumulo-testing-env.sh" ]; then
+  . "$at_home"/conf/accumulo-testing-env.sh
+else
+  . "$at_home"/conf/accumulo-testing-env.sh.example
+fi
+
+function start_agitator() {
+  hash pssh 2>/dev/null || { echo >&2 "The agitator requires pssh to be installed. Aborting."; exit 1; }
+
+  mkdir -p "${at_home}/logs"
+  log_base="${at_home}/logs/$(date +%Y%m%d%H%M%S)_$(hostname)"
+  libexec="${at_home}/libexec"
+  master_log="${log_base}_master-agitator"
+  tserver_log="${log_base}_tserver-agitator"
+  datanode_log="${log_base}_datanode-agitator"
+  master_cmd="nohup ${libexec}/master-agitator.pl $AGTR_MASTER_KILL_SLEEP_TIME $AGTR_MASTER_RESTART_SLEEP_TIME"
+  tserver_cmd="nohup ${libexec}/tserver-agitator.pl $AGTR_TSERVER_KILL_SLEEP_TIME $AGTR_TSERVER_RESTART_SLEEP_TIME $AGTR_TSERVER_MIN_KILL $AGTR_TSERVER_MAX_KILL"
+  datanode_cmd="nohup ${libexec}/datanode-agitator.pl $AGTR_DATANODE_KILL_SLEEP_TIME $AGTR_DATANODE_RESTART_SLEEP_TIME $HADOOP_HOME $AGTR_DATANODE_MIN_KILL $AGTR_DATANODE_MAX_KILL"
+  [[ -n $AGITATOR_USER ]] || AGITATOR_USER=$(whoami)
+
+  if [[ $AGITATOR_USER == root ]];  then
+    echo "Running master-agitator and tserver-agitator as $AGTR_ACCUMULO_USER using su. Running datanode-agitator as $AGTR_HDFS_USER using su."
+    su -c "$master_cmd >${master_log}.out 2>${master_log}.err" & -m - "$AGTR_ACCUMULO_USER"
+    su -c "$tserver_cmd >${tserver_log}.out 2>${tserver_log}.err" & -m - "$AGTR_ACCUMULO_USER"
+    su -c "$datanode_cmd >${datanode_log}.out 2>${datanode_log}.err" & -m - "$AGTR_HDFS_USER"
+  else
+    if [[ $AGITATOR_USER == "$AGTR_ACCUMULO_USER" ]]; then
+      echo "Running master-agitator and tserver-agitator as $AGITATOR_USER"
+      $master_cmd > "${master_log}.out" 2> "${master_log}.err" &
+      $tserver_cmd > "${tserver_log}.out" 2> "${tserver_log}.err" &
+    else
+      echo "Running master-agitator and tserver-agitator as $AGTR_ACCUMULO_USER using sudo."
+      sudo -u "$AGTR_ACCUMULO_USER" $master_cmd > "${master_log}.out" 2> "${master_log}.err" &
+      sudo -u "$AGTR_ACCUMULO_USER" $tserver_cmd > "${tserver_log}.out" 2> "${tserver_log}.err" &
+    fi
+    if [[ $AGITATOR_USER == "$AGTR_HDFS_USER" ]]; then
+      echo "Running datanode-agitator as $AGITATOR_USER"
+      $datanode_cmd > "${datanode_log}.out" 2> "${datanode_log}.err" &
+    else
+      echo "Running datanode-agitator as $AGTR_HDFS_USER using sudo."
+      sudo -u "$AGTR_HDFS_USER" $datanode_cmd > "${datanode_log}.out" 2> "${datanode_log}.err" &
+    fi
+  fi
+
+  if ${AGTR_HDFS:-false} ; then
+    agitator_log=${log_base}_hdfs-agitator
+    sudo -u "$AGTR_HDFS_SUPERUSER" nohup "${libexec}/hdfs-agitator.pl" --sleep "${AGTR_HDFS_SLEEP_TIME}" --hdfs-cmd "${AGTR_HDFS_COMMAND}" --superuser "${AGTR_HDFS_SUPERUSER}" >"${agitator_log}.out" 2>"${agitator_log}.err" &
+  fi
+}
+
+function stop_agitator() {
+  [[ -n $AGITATOR_USER ]] || AGITATOR_USER=$(whoami)
+  if [[ $AGITATOR_USER == root ]]; then
+    echo "Stopping all processes matching 'agitator.pl' as root"
+    pkill -f agitator.pl 2>/dev/null
+  elif [[ $AGITATOR_USER == "$AGTR_ACCUMULO_USER" ]];  then
+    echo "Stopping all processes matching 'datanode-agitator.pl' as $AGTR_HDFS_USER"
+    sudo -u "$AGTR_HDFS_USER" pkill -f datanode-agitator.pl 2>/dev/null
+    echo "Stopping all processes matching 'hdfs-agitator.pl' as $AGTR_HDFS_USER"
+    sudo -u "$AGTR_HDFS_USER" pkill -f hdfs-agitator.pl 2>/dev/null
+    echo "Stopping all processes matching 'agitator.pl' as $AGITATOR_USER"
+    pkill -f agitator.pl 2>/dev/null 2>/dev/null
+  else
+    echo "Stopping all processes matching 'datanode-agitator.pl' as $AGTR_HDFS_USER"
+    sudo -u "$AGTR_HDFS_USER" pkill -f datanode-agitator.pl 2>/dev/null
+    echo "Stopping all processes matching 'hdfs-agitator.pl' as $AGTR_HDFS_USER"
+    sudo -u "$AGTR_HDFS_USER" pkill -f hdfs-agitator.pl 2>/dev/null
+    echo "Stopping all processes matching 'agitator.pl' as $AGTR_ACCUMULO_USER"
+    sudo -u "$AGTR_ACCUMULO_USER" pkill -f agitator.pl 2>/dev/null
+  fi
+}
+
+case "$1" in
+  start)
+    start_agitator
+    ;;
+  stop)
+    stop_agitator
+    ;;
+  *)
+    echo "ERROR: unknown command - $2"
+    print_usage
+    exit 1
+esac
diff --git a/core/src/test/resources/log4j.properties b/bin/build
old mode 100644
new mode 100755
similarity index 75%
copy from core/src/test/resources/log4j.properties
copy to bin/build
index 716f9db..97bbdd0
--- a/core/src/test/resources/log4j.properties
+++ b/bin/build
@@ -1,3 +1,5 @@
+#! /usr/bin/env bash
+
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
 # this work for additional information regarding copyright ownership.
@@ -13,9 +15,11 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-log4j.rootLogger=WARN, CA
-log4j.appender.CA=org.apache.log4j.ConsoleAppender
-log4j.appender.CA.layout=org.apache.log4j.PatternLayout
-log4j.appender.CA.layout.ConversionPattern=[%t} %-5p %c %x - %m%n
+bin_dir=$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )
+at_home=$( cd "$( dirname "$bin_dir" )" && pwd )
 
-log4j.logger.org.apache.zookeeper.ClientCnxn=FATAL
+if [ -f "$at_home/conf/env.sh" ]; then
+  . "$at_home"/conf/env.sh
+else
+  . "$at_home"/conf/env.sh.example
+fi
diff --git a/bin/cingest b/bin/cingest
new file mode 100755
index 0000000..5801a12
--- /dev/null
+++ b/bin/cingest
@@ -0,0 +1,95 @@
+#! /usr/bin/env bash
+
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
+bin_dir=$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )
+at_home=$( cd "$( dirname "$bin_dir" )" && pwd )
+
+function print_usage() {
+  cat <<EOF
+
+Usage: cingest <application>
+
+Available applications:
+
+    createtable   Creates Accumulo table for continous ingest
+    ingest        Inserts data into Accumulo that will form random graph.
+    walk          Randomly walks the graph using a scanner
+    batchwalk     Randomly walks the graph using a batch scanner
+    scan          Scans the graph
+    verify        Verifies continous ingest test. Stop ingest before running.
+    moru          Streses Accumulo by reading and writing to the ingest table.
+                  Stop ingest before running.
+EOF
+}
+
+if [ -f "$at_home/conf/env.sh" ]; then
+  . "$at_home"/conf/env.sh
+else
+  . "$at_home"/conf/env.sh.example
+fi
+
+if [ -z "$1" ]; then
+  echo "ERROR: <application> needs to be set"
+  print_usage
+  exit 1
+fi
+
+ci_package="org.apache.accumulo.testing.continuous"
+case "$1" in
+  createtable)
+    ci_main="${ci_package}.CreateTable"
+    ;;
+  ingest)
+    ci_main="${ci_package}.ContinuousIngest"
+    ;;
+  walk)
+    ci_main="${ci_package}.ContinuousWalk"
+    ;;
+  batchwalk)
+    ci_main="${ci_package}.ContinuousBatchWalker"
+    ;;
+  scan)
+    ci_main="${ci_package}.ContinuousScanner"
+    ;;
+  verify)
+    ci_main="${ci_package}.ContinuousVerify"
+    ;;
+  moru)
+    ci_main="${ci_package}.ContinuousMoru"
+    ;;
+  *)
+    echo "Unknown application: $1"
+    print_usage
+    exit 1
+esac
+
+export CLASSPATH="$TEST_JAR_PATH:$CLASSPATH"
+
+case "$1" in
+  verify|moru)
+    if [ ! -z $HADOOP_HOME ]; then
+      export CLASSPATH=$HADOOP_HOME/etc/hadoop:$CLASSPATH
+      export HADOOP_USE_CLIENT_CLASSLOADER=true
+      "$HADOOP_HOME"/bin/yarn jar "$TEST_JAR_PATH" "$ci_main" "$TEST_PROPS" "$ACCUMULO_CLIENT_PROPS"
+    else
+      echo "Hadoop must be installed and HADOOP_HOME must be set!"
+      exit 1
+    fi
+    ;;
+  *)
+    java -Dlog4j.configuration="file:$TEST_LOG4J" "$ci_main" "$TEST_PROPS" "$ACCUMULO_CLIENT_PROPS"
+esac
diff --git a/bin/performance-test b/bin/performance
similarity index 93%
rename from bin/performance-test
rename to bin/performance
index 7fa1e68..d062ecf 100755
--- a/bin/performance-test
+++ b/bin/performance
@@ -33,7 +33,7 @@ EOF
 
 
 function build_shade_jar() {
-  at_shaded_jar="$at_home/core/target/accumulo-testing-core-$at_version-shaded.jar"
+  at_shaded_jar="$at_home/core/target/accumulo-testing-$at_version-shaded.jar"
   if [ ! -f "$at_shaded_jar" ]; then
     echo "Building $at_shaded_jar"
     cd "$at_home" || exit 1
@@ -58,8 +58,8 @@ fi
 
 . $at_home/conf/cluster-control.sh
 build_shade_jar
-CP="$at_home/core/target/accumulo-testing-core-$at_version-shaded.jar"
-perf_pkg="org.apache.accumulo.testing.core.performance.impl"
+CP="$at_home/core/target/accumulo-testing-$at_version-shaded.jar"
+perf_pkg="org.apache.accumulo.testing.performance.impl"
 case "$1" in
   run)
     if [ -z "$2" ]; then
diff --git a/core/src/test/resources/log4j.properties b/bin/rwalk
old mode 100644
new mode 100755
similarity index 51%
copy from core/src/test/resources/log4j.properties
copy to bin/rwalk
index 716f9db..8a17b4e
--- a/core/src/test/resources/log4j.properties
+++ b/bin/rwalk
@@ -1,3 +1,5 @@
+#! /usr/bin/env bash
+
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
 # this work for additional information regarding copyright ownership.
@@ -13,9 +15,33 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-log4j.rootLogger=WARN, CA
-log4j.appender.CA=org.apache.log4j.ConsoleAppender
-log4j.appender.CA.layout=org.apache.log4j.PatternLayout
-log4j.appender.CA.layout.ConversionPattern=[%t} %-5p %c %x - %m%n
+bin_dir=$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )
+at_home=$( cd "$( dirname "$bin_dir" )" && pwd )
+
+function print_usage() {
+  cat <<EOF
+
+Usage: rw-test <module> (<argument>)
+
+   Runs random walk <module>
+   Modules located in core/src/main/resources/randomwalk/modules
+EOF
+}
+
+if [ -f "$at_home/conf/env.sh" ]; then
+  . "$at_home"/conf/env.sh
+else
+  . "$at_home"/conf/env.sh.example
+fi
+
+export CLASSPATH="$TEST_JAR_PATH:$CLASSPATH"
+
+randomwalk_main="org.apache.accumulo.testing.randomwalk.Framework"
+
+if [ -z "$1" ]; then
+  echo "ERROR: <module> needs to be set"
+  print_usage
+  exit 1
+fi
 
-log4j.logger.org.apache.zookeeper.ClientCnxn=FATAL
+java -Dlog4j.configuration="file:$TEST_LOG4J" "$randomwalk_main" "$TEST_PROPS" "$ACCUMULO_CLIENT_PROPS" "$1"
diff --git a/conf/.gitignore b/conf/.gitignore
index ca4a321..bd1d6b3 100644
--- a/conf/.gitignore
+++ b/conf/.gitignore
@@ -1,4 +1,5 @@
+/accumulo-client.properties
 /accumulo-testing.properties
-/accumulo-testing-env.sh
+/env.sh
 /log4j.properties
 /cluster-control.sh
diff --git a/conf/accumulo-testing-env.sh.example b/conf/env.sh.example
similarity index 68%
rename from conf/accumulo-testing-env.sh.example
rename to conf/env.sh.example
index 3876718..a3368fc 100644
--- a/conf/accumulo-testing-env.sh.example
+++ b/conf/env.sh.example
@@ -22,12 +22,40 @@ export HADOOP_HOME="${HADOOP_HOME:-/path/to/hadoop}"
 export ACCUMULO_HOME="${ACCUMULO_HOME:-/path/to/accumulo}"
 ## Path to Accumulo client properties
 export ACCUMULO_CLIENT_PROPS="$ACCUMULO_HOME/conf/accumulo-client.properties"
+
+# Configuration
+# =============
+conf_dir=$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )
+export TEST_PROPS="${conf_dir}/accumulo-testing.properties"
+if [ ! -f "$TEST_PROPS" ]; then
+  echo "Please create and edit accumulo-testing.properties in $conf_dir"
+  exit 1
+fi
+export TEST_LO4J="${conf_dir}/log4j.properties"
+if [ ! -f "$TEST_L0G4J" ]; then
+  export TEST_LOG4J="${conf_dir}/log4j.properties.example"
+  if [ ! -f "$TEST_LOG4J" ]; then
+    echo "Could not find logj4.properties or log4j.properties.example in $conf_dir"
+    exit 1
+  fi
+fi
+
+# Shaded test jar
+# ===============
+# Version of shaded test jar
+export TEST_JAR_VERSION=2.0.0-SNAPSHOT
 # Versions set below will be what is included in the shaded jar
 export ACCUMULO_VERSION="`$ACCUMULO_HOME/bin/accumulo version`"
 export HADOOP_VERSION="`hadoop version | head -n1 | awk '{print $2}'`"
 export ZOOKEEPER_VERSION=3.4.9
-# Make sure Hadoop configuration directory is on the classpath
-export CLASSPATH=$HADOOP_HOME/etc/hadoop
+# Path to shaded test jar
+at_home=$( cd "$( dirname "$conf_dir" )" && pwd )
+export TEST_JAR_PATH="${at_home}/target/accumulo-testing-${TEST_JAR_VERSION}-shaded.jar"
+if [ ! -f "$TEST_JAR_PATH" ]; then
+  echo "Building $TEST_JAR_PATH"
+  cd "${at_home}" || exit 1
+  mvn clean package -P create-shade-jar -D skipTests -D accumulo.version="$ACCUMULO_VERSION" -D hadoop.version="$HADOOP_VERSION" -D zookeeper.version="$ZOOKEEPER_VERSION"
+fi
 
 # Agitator
 # ========
diff --git a/core/.gitignore b/core/.gitignore
deleted file mode 100644
index 7e54b72..0000000
--- a/core/.gitignore
+++ /dev/null
@@ -1,7 +0,0 @@
-/.classpath
-/.project
-/.settings/
-/target/
-/*.iml
-/.idea
-/logs/
diff --git a/core/pom.xml b/core/pom.xml
deleted file mode 100644
index d982022..0000000
--- a/core/pom.xml
+++ /dev/null
@@ -1,136 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-  Licensed to the Apache Software Foundation (ASF) under one or more
-  contributor license agreements.  See the NOTICE file distributed with
-  this work for additional information regarding copyright ownership.
-  The ASF licenses this file to You under the Apache License, Version 2.0
-  (the "License"); you may not use this file except in compliance with
-  the License.  You may obtain a copy of the License at
-
-      http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  See the License for the specific language governing permissions and
-  limitations under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-  <modelVersion>4.0.0</modelVersion>
-
-  <parent>
-    <groupId>org.apache.accumulo</groupId>
-    <artifactId>accumulo-testing</artifactId>
-    <version>2.0.0-SNAPSHOT</version>
-  </parent>
-
-  <artifactId>accumulo-testing-core</artifactId>
-  <packaging>jar</packaging>
-
-  <name>Apache Accumulo Testing Core</name>
-
-  <dependencies>
-    <dependency>
-      <groupId>com.google.guava</groupId>
-      <artifactId>guava</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>commons-configuration</groupId>
-      <artifactId>commons-configuration</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.commons</groupId>
-      <artifactId>commons-math3</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-client-mapreduce</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-core</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-minicluster</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-test</artifactId>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-client</artifactId>
-    </dependency>
-    <dependency>
-        <groupId>org.apache.hadoop</groupId>
-        <artifactId>hadoop-common</artifactId>
-     </dependency>
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-mapreduce-client-jobclient</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.slf4j</groupId>
-      <artifactId>slf4j-api</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.slf4j</groupId>
-      <artifactId>slf4j-log4j12</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>junit</groupId>
-      <artifactId>junit</artifactId>
-      <scope>test</scope>
-    </dependency>
-  </dependencies>
-
-  <profiles>
-    <profile>
-      <id>create-shade-jar</id>
-      <build>
-        <plugins>
-          <plugin>
-            <groupId>org.apache.maven.plugins</groupId>
-            <artifactId>maven-shade-plugin</artifactId>
-            <executions>
-              <execution>
-                <id>testing-shade-jar</id>
-                <goals>
-                  <goal>shade</goal>
-                </goals>
-                <phase>package</phase>
-                <configuration>
-                  <shadedArtifactAttached>true</shadedArtifactAttached>
-                  <shadedClassifierName>shaded</shadedClassifierName>
-                  <artifactSet>
-                    <excludes>
-                      <exclude>org.apache.accumulo:accumulo-native</exclude>
-                    </excludes>
-                  </artifactSet>
-                  <filters>
-                    <filter>
-                      <artifact>*:*</artifact>
-                      <excludes>
-                        <exclude>META-INF/*.SF</exclude>
-                        <exclude>META-INF/*.DSA</exclude>
-                        <exclude>META-INF/*.RSA</exclude>
-                        <!-- Twill 0.13 fails if shaded jar includes this directory !-->
-                        <exclude>META-INF/license/*</exclude>
-                      </excludes>
-                    </filter>
-                  </filters>
-                  <transformers>
-                    <!-- Hadoop uses service loader to find filesystem impls, without this may not find them -->
-                    <transformer implementation="org.apache.maven.plugins.shade.resource.ServicesResourceTransformer"/>
-                  </transformers>
-                </configuration>
-              </execution>
-            </executions>
-          </plugin>
-        </plugins>
-      </build>
-    </profile>
-  </profiles>
-</project>
diff --git a/pom.xml b/pom.xml
index 7ea2a47..8d4c940 100644
--- a/pom.xml
+++ b/pom.xml
@@ -27,155 +27,28 @@
   <groupId>org.apache.accumulo</groupId>
   <artifactId>accumulo-testing</artifactId>
   <version>2.0.0-SNAPSHOT</version>
-  <packaging>pom</packaging>
+  <packaging>jar</packaging>
 
-  <name>Apache Accumulo Testing Parent</name>
-  <description>Testing suites for Apache Accumulo</description>
-
-  <modules>
-    <module>core</module>
-    <module>yarn</module>
-  </modules>
+  <name>Apache Accumulo Testing</name>
+  <description>Testing tools for Apache Accumulo</description>
 
   <properties>
     <accumulo.version>2.0.0-SNAPSHOT</accumulo.version>
     <hadoop.version>3.0.3</hadoop.version>
     <zookeeper.version>3.4.9</zookeeper.version>
     <slf4j.version>1.7.21</slf4j.version>
-    <twill.version>0.13.0</twill.version>
     <maven.compiler.source>1.8</maven.compiler.source>
     <maven.compiler.target>1.8</maven.compiler.target>
-    <formatter.config>${project.parent.basedir}/contrib/Eclipse-Accumulo-Codestyle.xml</formatter.config>
+    <formatter.config>${project.basedir}/contrib/Eclipse-Accumulo-Codestyle.xml</formatter.config>
   </properties>
 
   <dependencyManagement>
     <dependencies>
       <dependency>
-        <groupId>com.google.guava</groupId>
-        <artifactId>guava</artifactId>
-        <version>26.0-jre</version>
-      </dependency>
-      <dependency>
-        <groupId>com.beust</groupId>
-        <artifactId>jcommander</artifactId>
-        <version>1.72</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.commons</groupId>
-        <artifactId>commons-math3</artifactId>
-        <version>3.6.1</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.accumulo</groupId>
-        <artifactId>accumulo-testing-core</artifactId>
-        <version>${project.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>commons-configuration</groupId>
-        <artifactId>commons-configuration</artifactId>
-        <version>1.10</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.accumulo</groupId>
-        <artifactId>accumulo-client-mapreduce</artifactId>
-        <version>${accumulo.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.accumulo</groupId>
-        <artifactId>accumulo-core</artifactId>
-        <version>${accumulo.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.accumulo</groupId>
-        <artifactId>accumulo-fate</artifactId>
-        <version>${accumulo.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.accumulo</groupId>
-        <artifactId>accumulo-master</artifactId>
-        <version>${accumulo.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.accumulo</groupId>
-        <artifactId>accumulo-minicluster</artifactId>
-        <version>${accumulo.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.accumulo</groupId>
-        <artifactId>accumulo-test</artifactId>
-        <version>${accumulo.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.hadoop</groupId>
-        <artifactId>hadoop-client</artifactId>
-        <version>${hadoop.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.hadoop</groupId>
-        <artifactId>hadoop-mapreduce-client-jobclient</artifactId>
-        <version>${hadoop.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.hadoop</groupId>
-        <artifactId>hadoop-common</artifactId>
-        <version>${hadoop.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.hadoop</groupId>
-        <artifactId>hadoop-hdfs</artifactId>
-        <version>${hadoop.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.hadoop</groupId>
-        <artifactId>hadoop-yarn-api</artifactId>
-        <version>${hadoop.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.hadoop</groupId>
-        <artifactId>hadoop-yarn-client</artifactId>
-        <version>${hadoop.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.hadoop</groupId>
-        <artifactId>hadoop-yarn-common</artifactId>
-        <version>${hadoop.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.twill</groupId>
-        <artifactId>twill-api</artifactId>
-        <version>${twill.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.twill</groupId>
-        <artifactId>twill-ext</artifactId>
-        <version>${twill.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.apache.twill</groupId>
-        <artifactId>twill-yarn</artifactId>
-        <version>${twill.version}</version>
-      </dependency>
-      <dependency>
         <groupId>org.apache.zookeeper</groupId>
         <artifactId>zookeeper</artifactId>
         <version>${zookeeper.version}</version>
       </dependency>
-      <dependency>
-        <groupId>org.slf4j</groupId>
-        <artifactId>slf4j-api</artifactId>
-        <version>${slf4j.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>org.slf4j</groupId>
-        <artifactId>slf4j-log4j12</artifactId>
-        <version>${slf4j.version}</version>
-      </dependency>
-      <dependency>
-        <groupId>junit</groupId>
-        <artifactId>junit</artifactId>
-        <version>4.12</version>
-        <scope>test</scope>
-      </dependency>
     </dependencies>
   </dependencyManagement>
 
@@ -258,4 +131,113 @@
     </plugins>
   </build>
 
+  <dependencies>
+    <dependency>
+      <groupId>com.google.guava</groupId>
+      <artifactId>guava</artifactId>
+      <version>26.0-jre</version>
+    </dependency>
+    <dependency>
+      <groupId>commons-configuration</groupId>
+      <artifactId>commons-configuration</artifactId>
+      <version>1.10</version>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.commons</groupId>
+      <artifactId>commons-math3</artifactId>
+      <version>3.6.1</version>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.accumulo</groupId>
+      <artifactId>accumulo-core</artifactId>
+      <version>${accumulo.version}</version>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.accumulo</groupId>
+      <artifactId>accumulo-minicluster</artifactId>
+      <version>${accumulo.version}</version>
+      <scope>test</scope>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.accumulo</groupId>
+      <artifactId>accumulo-test</artifactId>
+      <version>${accumulo.version}</version>
+      <scope>test</scope>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.hadoop</groupId>
+      <artifactId>hadoop-client-api</artifactId>
+      <version>${hadoop.version}</version>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.hadoop</groupId>
+      <artifactId>hadoop-client-runtime</artifactId>
+      <version>${hadoop.version}</version>
+    </dependency>
+    <dependency>
+      <groupId>org.slf4j</groupId>
+      <artifactId>slf4j-api</artifactId>
+      <version>${slf4j.version}</version>
+    </dependency>
+    <dependency>
+      <groupId>org.slf4j</groupId>
+      <artifactId>slf4j-log4j12</artifactId>
+      <version>${slf4j.version}</version>
+    </dependency>
+    <dependency>
+      <groupId>junit</groupId>
+      <artifactId>junit</artifactId>
+      <version>4.12</version>
+      <scope>test</scope>
+    </dependency>
+  </dependencies>
+
+  <profiles>
+    <profile>
+      <id>create-shade-jar</id>
+      <build>
+        <plugins>
+          <plugin>
+            <groupId>org.apache.maven.plugins</groupId>
+            <artifactId>maven-shade-plugin</artifactId>
+            <executions>
+              <execution>
+                <id>testing-shade-jar</id>
+                <goals>
+                  <goal>shade</goal>
+                </goals>
+                <phase>package</phase>
+                <configuration>
+                  <shadedArtifactAttached>true</shadedArtifactAttached>
+                  <shadedClassifierName>shaded</shadedClassifierName>
+                  <artifactSet>
+                    <excludes>
+                      <exclude>org.apache.accumulo:accumulo-native</exclude>
+                    </excludes>
+                  </artifactSet>
+                  <filters>
+                    <filter>
+                      <artifact>*:*</artifact>
+                      <excludes>
+                        <exclude>META-INF/*.SF</exclude>
+                        <exclude>META-INF/*.DSA</exclude>
+                        <exclude>META-INF/*.RSA</exclude>
+                        <!-- Twill 0.13 fails if shaded jar includes this directory !-->
+                        <exclude>META-INF/license/*</exclude>
+                      </excludes>
+                    </filter>
+                  </filters>
+                  <transformers>
+                    <!-- Hadoop uses service loader to find filesystem impls, without this may not find them -->
+                    <transformer implementation="org.apache.maven.plugins.shade.resource.ServicesResourceTransformer"/>
+                  </transformers>
+                </configuration>
+              </execution>
+            </executions>
+          </plugin>
+        </plugins>
+      </build>
+    </profile>
+  </profiles>
+
 </project>
diff --git a/core/src/test/resources/log4j.properties b/src/main/docker/docker-entry
old mode 100644
new mode 100755
similarity index 56%
copy from core/src/test/resources/log4j.properties
copy to src/main/docker/docker-entry
index 716f9db..5a98525
--- a/core/src/test/resources/log4j.properties
+++ b/src/main/docker/docker-entry
@@ -1,3 +1,5 @@
+#! /usr/bin/env bash
+
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
 # this work for additional information regarding copyright ownership.
@@ -13,9 +15,37 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-log4j.rootLogger=WARN, CA
-log4j.appender.CA=org.apache.log4j.ConsoleAppender
-log4j.appender.CA.layout=org.apache.log4j.PatternLayout
-log4j.appender.CA.layout.ConversionPattern=[%t} %-5p %c %x - %m%n
+bin_dir=$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )
+at_home=$( cd "$( dirname "$bin_dir" )" && pwd )
+
+function print_usage() {
+  cat <<EOF
+
+Usage: accumulo-testing <script> (<argument>)
+
+  Available scripts:
+
+  cingest     Runs continuous ingest script
+  rwalk       Runs random walk script
+EOF
+}
+
+if [ -z "$1" ]; then
+  echo "ERROR: <script> needs to be set"
+  print_usage
+  exit 1
+fi
 
-log4j.logger.org.apache.zookeeper.ClientCnxn=FATAL
+case "$1" in
+  cingest|rwalk)
+    "${at_home}"/bin/"$1" "${@:2}"
+    ;;
+  -h|help)
+    print_usage
+    exit 1
+    ;;
+  *)
+    echo "ERROR - unknown <script>: $1"
+    exit 1
+    ;;
+esac
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/TestEnv.java b/src/main/java/org/apache/accumulo/testing/TestEnv.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/TestEnv.java
rename to src/main/java/org/apache/accumulo/testing/TestEnv.java
index 0890029..9b0afaa 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/TestEnv.java
+++ b/src/main/java/org/apache/accumulo/testing/TestEnv.java
@@ -1,4 +1,4 @@
-package org.apache.accumulo.testing.core;
+package org.apache.accumulo.testing;
 
 import static java.util.Objects.requireNonNull;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/TestProps.java b/src/main/java/org/apache/accumulo/testing/TestProps.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/TestProps.java
rename to src/main/java/org/apache/accumulo/testing/TestProps.java
index 3b2c98f..f8eb640 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/TestProps.java
+++ b/src/main/java/org/apache/accumulo/testing/TestProps.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core;
+package org.apache.accumulo.testing;
 
 import java.io.FileInputStream;
 import java.io.IOException;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousBatchWalker.java b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousBatchWalker.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousBatchWalker.java
rename to src/main/java/org/apache/accumulo/testing/continuous/ContinuousBatchWalker.java
index af2a8c5..c596041 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousBatchWalker.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousBatchWalker.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import java.util.ArrayList;
 import java.util.HashSet;
@@ -32,7 +32,7 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.TestProps;
+import org.apache.accumulo.testing.TestProps;
 import org.apache.hadoop.io.Text;
 
 import static com.google.common.util.concurrent.Uninterruptibles.sleepUninterruptibly;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousEnv.java b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousEnv.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousEnv.java
rename to src/main/java/org/apache/accumulo/testing/continuous/ContinuousEnv.java
index 76d6705..9642cf3 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousEnv.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousEnv.java
@@ -1,4 +1,4 @@
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -6,8 +6,8 @@ import java.util.List;
 import java.util.Random;
 
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.TestEnv;
-import org.apache.accumulo.testing.core.TestProps;
+import org.apache.accumulo.testing.TestEnv;
+import org.apache.accumulo.testing.TestProps;
 
 class ContinuousEnv extends TestEnv {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousIngest.java b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousIngest.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousIngest.java
rename to src/main/java/org/apache/accumulo/testing/continuous/ContinuousIngest.java
index 375c619..6888357 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousIngest.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousIngest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -38,7 +38,7 @@ import org.apache.accumulo.core.security.ColumnVisibility;
 import org.apache.accumulo.core.trace.Trace;
 import org.apache.accumulo.core.trace.TraceSamplers;
 import org.apache.accumulo.core.util.FastFormat;
-import org.apache.accumulo.testing.core.TestProps;
+import org.apache.accumulo.testing.TestProps;
 import org.apache.hadoop.io.Text;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousMoru.java b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousMoru.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousMoru.java
rename to src/main/java/org/apache/accumulo/testing/continuous/ContinuousMoru.java
index dad8d69..6e19ed0 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousMoru.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousMoru.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -31,7 +31,7 @@ import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.ColumnVisibility;
-import org.apache.accumulo.testing.core.TestProps;
+import org.apache.accumulo.testing.TestProps;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.conf.Configured;
 import org.apache.hadoop.io.Text;
@@ -150,6 +150,7 @@ public class ContinuousMoru extends Configured implements Tool {
     conf.setInt(MAX_CF, env.getMaxColF());
     conf.setInt(MAX_CQ, env.getMaxColQ());
     conf.set(CI_ID, UUID.randomUUID().toString());
+    conf.set("mapreduce.job.classloader", "true");
 
     job.waitForCompletion(true);
     return job.isSuccessful() ? 0 : 1;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousOpts.java b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousOpts.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousOpts.java
rename to src/main/java/org/apache/accumulo/testing/continuous/ContinuousOpts.java
index 14babaf..a2dc69f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousOpts.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousOpts.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import java.io.IOException;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousScanner.java b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousScanner.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousScanner.java
rename to src/main/java/org/apache/accumulo/testing/continuous/ContinuousScanner.java
index 3464678..e4bab76 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousScanner.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousScanner.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -29,7 +29,7 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.TestProps;
+import org.apache.accumulo.testing.TestProps;
 import org.apache.hadoop.io.Text;
 
 import static com.google.common.util.concurrent.Uninterruptibles.sleepUninterruptibly;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousUtil.java b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousUtil.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousUtil.java
rename to src/main/java/org/apache/accumulo/testing/continuous/ContinuousUtil.java
index 050bf24..b4f0148 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousUtil.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousUtil.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.Scanner;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousVerify.java b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousVerify.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousVerify.java
rename to src/main/java/org/apache/accumulo/testing/continuous/ContinuousVerify.java
index 1add7dd..59beb15 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousVerify.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousVerify.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -30,8 +30,7 @@ import org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.testing.core.TestProps;
-import org.apache.accumulo.testing.core.continuous.ContinuousWalk.BadChecksumException;
+import org.apache.accumulo.testing.TestProps;
 import org.apache.hadoop.conf.Configured;
 import org.apache.hadoop.fs.Path;
 import org.apache.hadoop.io.LongWritable;
@@ -70,7 +69,7 @@ public class ContinuousVerify extends Configured implements Tool {
 
       try {
         ContinuousWalk.validate(key, data);
-      } catch (BadChecksumException bce) {
+      } catch (ContinuousWalk.BadChecksumException bce) {
         context.getCounter(Counts.CORRUPT).increment(1L);
         if (corrupt < 1000) {
           log.error("Bad checksum : " + key);
@@ -187,6 +186,7 @@ public class ContinuousVerify extends Configured implements Tool {
     job.setOutputFormatClass(TextOutputFormat.class);
 
     job.getConfiguration().setBoolean("mapred.map.tasks.speculative.execution", scanOffline);
+    job.getConfiguration().set("mapreduce.job.classloader", "true");
 
     TextOutputFormat.setOutputPath(job, new Path(outputDir));
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousWalk.java b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousWalk.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousWalk.java
rename to src/main/java/org/apache/accumulo/testing/continuous/ContinuousWalk.java
index bb45853..7cdc55d 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/ContinuousWalk.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/ContinuousWalk.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -30,7 +30,7 @@ import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.trace.Span;
 import org.apache.accumulo.core.trace.Trace;
-import org.apache.accumulo.testing.core.TestProps;
+import org.apache.accumulo.testing.TestProps;
 import org.apache.hadoop.io.Text;
 
 public class ContinuousWalk {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/CreateTable.java b/src/main/java/org/apache/accumulo/testing/continuous/CreateTable.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/CreateTable.java
rename to src/main/java/org/apache/accumulo/testing/continuous/CreateTable.java
index 1ba6de6..0c7902a 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/CreateTable.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/CreateTable.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import java.util.SortedSet;
 import java.util.TreeSet;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.testing.core.TestProps;
+import org.apache.accumulo.testing.TestProps;
 import org.apache.hadoop.io.Text;
 
 public class CreateTable {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/TimeBinner.java b/src/main/java/org/apache/accumulo/testing/continuous/TimeBinner.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/TimeBinner.java
rename to src/main/java/org/apache/accumulo/testing/continuous/TimeBinner.java
index 843b251..b3bf00f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/TimeBinner.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/TimeBinner.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/continuous/UndefinedAnalyzer.java b/src/main/java/org/apache/accumulo/testing/continuous/UndefinedAnalyzer.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/continuous/UndefinedAnalyzer.java
rename to src/main/java/org/apache/accumulo/testing/continuous/UndefinedAnalyzer.java
index 56b7aa0..2232c52 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/continuous/UndefinedAnalyzer.java
+++ b/src/main/java/org/apache/accumulo/testing/continuous/UndefinedAnalyzer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.continuous;
+package org.apache.accumulo.testing.continuous;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/ingest/BulkImportDirectory.java b/src/main/java/org/apache/accumulo/testing/ingest/BulkImportDirectory.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/ingest/BulkImportDirectory.java
rename to src/main/java/org/apache/accumulo/testing/ingest/BulkImportDirectory.java
index bc1b305..9ac53a5 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/ingest/BulkImportDirectory.java
+++ b/src/main/java/org/apache/accumulo/testing/ingest/BulkImportDirectory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.ingest;
+package org.apache.accumulo.testing.ingest;
 
 import java.io.IOException;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/ingest/TestIngest.java b/src/main/java/org/apache/accumulo/testing/ingest/TestIngest.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/ingest/TestIngest.java
rename to src/main/java/org/apache/accumulo/testing/ingest/TestIngest.java
index 96020bb..5702b13 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/ingest/TestIngest.java
+++ b/src/main/java/org/apache/accumulo/testing/ingest/TestIngest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.ingest;
+package org.apache.accumulo.testing.ingest;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/ingest/VerifyIngest.java b/src/main/java/org/apache/accumulo/testing/ingest/VerifyIngest.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/ingest/VerifyIngest.java
rename to src/main/java/org/apache/accumulo/testing/ingest/VerifyIngest.java
index fbd0179..884befe 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/ingest/VerifyIngest.java
+++ b/src/main/java/org/apache/accumulo/testing/ingest/VerifyIngest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.ingest;
+package org.apache.accumulo.testing.ingest;
 
 import java.util.Arrays;
 import java.util.Iterator;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/mapreduce/RowHash.java b/src/main/java/org/apache/accumulo/testing/mapreduce/RowHash.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/mapreduce/RowHash.java
rename to src/main/java/org/apache/accumulo/testing/mapreduce/RowHash.java
index 1f0ab5b..3a41713 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/mapreduce/RowHash.java
+++ b/src/main/java/org/apache/accumulo/testing/mapreduce/RowHash.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.mapreduce;
+package org.apache.accumulo.testing.mapreduce;
 
 import java.io.IOException;
 import java.util.Base64;
@@ -22,7 +22,7 @@ import java.util.Collections;
 
 import org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat;
 import org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat;
-import org.apache.accumulo.core.client.mapreduce.lib.impl.MapReduceClientOnRequiredTable;
+import org.apache.accumulo.core.clientImpl.mapreduce.lib.MapReduceClientOnRequiredTable;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/mapreduce/TeraSortIngest.java b/src/main/java/org/apache/accumulo/testing/mapreduce/TeraSortIngest.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/mapreduce/TeraSortIngest.java
rename to src/main/java/org/apache/accumulo/testing/mapreduce/TeraSortIngest.java
index a4dd6c5..f505f1a 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/mapreduce/TeraSortIngest.java
+++ b/src/main/java/org/apache/accumulo/testing/mapreduce/TeraSortIngest.java
@@ -16,7 +16,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.mapreduce;
+package org.apache.accumulo.testing.mapreduce;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,7 +27,7 @@ import java.util.Random;
 
 import org.apache.accumulo.core.client.BatchWriterConfig;
 import org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat;
-import org.apache.accumulo.core.client.mapreduce.lib.impl.MapReduceClientOnRequiredTable;
+import org.apache.accumulo.core.clientImpl.mapreduce.lib.MapReduceClientOnRequiredTable;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
 import org.apache.hadoop.conf.Configuration;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/MerkleTree.java b/src/main/java/org/apache/accumulo/testing/merkle/MerkleTree.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/MerkleTree.java
rename to src/main/java/org/apache/accumulo/testing/merkle/MerkleTree.java
index 003cd5d..337d391 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/MerkleTree.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/MerkleTree.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.merkle;
+package org.apache.accumulo.testing.merkle;
 
 import java.security.NoSuchAlgorithmException;
 import java.util.ArrayList;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/MerkleTreeNode.java b/src/main/java/org/apache/accumulo/testing/merkle/MerkleTreeNode.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/MerkleTreeNode.java
rename to src/main/java/org/apache/accumulo/testing/merkle/MerkleTreeNode.java
index 168b6e1..4469c32 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/MerkleTreeNode.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/MerkleTreeNode.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.merkle;
+package org.apache.accumulo.testing.merkle;
 
 import java.security.MessageDigest;
 import java.security.NoSuchAlgorithmException;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/RangeSerialization.java b/src/main/java/org/apache/accumulo/testing/merkle/RangeSerialization.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/RangeSerialization.java
rename to src/main/java/org/apache/accumulo/testing/merkle/RangeSerialization.java
index c301d49..385cbe8 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/RangeSerialization.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/RangeSerialization.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.merkle;
+package org.apache.accumulo.testing.merkle;
 
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Mutation;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/CompareTables.java b/src/main/java/org/apache/accumulo/testing/merkle/cli/CompareTables.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/CompareTables.java
rename to src/main/java/org/apache/accumulo/testing/merkle/cli/CompareTables.java
index 030eca9..ac7eb27 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/CompareTables.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/cli/CompareTables.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.merkle.cli;
+package org.apache.accumulo.testing.merkle.cli;
 
 import java.io.FileNotFoundException;
 import java.security.NoSuchAlgorithmException;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/ComputeRootHash.java b/src/main/java/org/apache/accumulo/testing/merkle/cli/ComputeRootHash.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/ComputeRootHash.java
rename to src/main/java/org/apache/accumulo/testing/merkle/cli/ComputeRootHash.java
index dc727ce..bd1502e 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/ComputeRootHash.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/cli/ComputeRootHash.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.merkle.cli;
+package org.apache.accumulo.testing.merkle.cli;
 
 import java.security.NoSuchAlgorithmException;
 import java.util.ArrayList;
@@ -32,9 +32,9 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.merkle.MerkleTree;
-import org.apache.accumulo.testing.core.merkle.MerkleTreeNode;
-import org.apache.accumulo.testing.core.merkle.RangeSerialization;
+import org.apache.accumulo.testing.merkle.MerkleTree;
+import org.apache.accumulo.testing.merkle.MerkleTreeNode;
+import org.apache.accumulo.testing.merkle.RangeSerialization;
 import org.apache.commons.codec.binary.Hex;
 
 import com.beust.jcommander.Parameter;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/GenerateHashes.java b/src/main/java/org/apache/accumulo/testing/merkle/cli/GenerateHashes.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/GenerateHashes.java
rename to src/main/java/org/apache/accumulo/testing/merkle/cli/GenerateHashes.java
index 3162ada..21bb41f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/GenerateHashes.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/cli/GenerateHashes.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.merkle.cli;
+package org.apache.accumulo.testing.merkle.cli;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -48,8 +48,8 @@ import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.merkle.RangeSerialization;
-import org.apache.accumulo.testing.core.merkle.skvi.DigestIterator;
+import org.apache.accumulo.testing.merkle.RangeSerialization;
+import org.apache.accumulo.testing.merkle.skvi.DigestIterator;
 import org.apache.commons.codec.binary.Hex;
 import org.apache.hadoop.io.Text;
 import org.slf4j.Logger;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/ManualComparison.java b/src/main/java/org/apache/accumulo/testing/merkle/cli/ManualComparison.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/ManualComparison.java
rename to src/main/java/org/apache/accumulo/testing/merkle/cli/ManualComparison.java
index dabac7d..367d99a 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/cli/ManualComparison.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/cli/ManualComparison.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.merkle.cli;
+package org.apache.accumulo.testing.merkle.cli;
 
 import java.util.Iterator;
 import java.util.Map.Entry;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/ingest/RandomWorkload.java b/src/main/java/org/apache/accumulo/testing/merkle/ingest/RandomWorkload.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/ingest/RandomWorkload.java
rename to src/main/java/org/apache/accumulo/testing/merkle/ingest/RandomWorkload.java
index aa8e27b..57cb839 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/ingest/RandomWorkload.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/ingest/RandomWorkload.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.merkle.ingest;
+package org.apache.accumulo.testing.merkle.ingest;
 
 import java.util.Random;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/package-info.java b/src/main/java/org/apache/accumulo/testing/merkle/package-info.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/package-info.java
rename to src/main/java/org/apache/accumulo/testing/merkle/package-info.java
index 5b27e4b..2469d6f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/package-info.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/package-info.java
@@ -35,5 +35,5 @@
  *
  * @since 1.7.0
  */
-package org.apache.accumulo.testing.core.merkle;
+package org.apache.accumulo.testing.merkle;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/merkle/skvi/DigestIterator.java b/src/main/java/org/apache/accumulo/testing/merkle/skvi/DigestIterator.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/merkle/skvi/DigestIterator.java
rename to src/main/java/org/apache/accumulo/testing/merkle/skvi/DigestIterator.java
index 7e415b4..741c63d 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/merkle/skvi/DigestIterator.java
+++ b/src/main/java/org/apache/accumulo/testing/merkle/skvi/DigestIterator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.merkle.skvi;
+package org.apache.accumulo.testing.merkle.skvi;
 
 import java.io.ByteArrayOutputStream;
 import java.io.DataOutputStream;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/Environment.java b/src/main/java/org/apache/accumulo/testing/performance/Environment.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/Environment.java
rename to src/main/java/org/apache/accumulo/testing/performance/Environment.java
index b5b9806..a2e6f06 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/Environment.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/Environment.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance;
+package org.apache.accumulo.testing.performance;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/Parameter.java b/src/main/java/org/apache/accumulo/testing/performance/Parameter.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/Parameter.java
rename to src/main/java/org/apache/accumulo/testing/performance/Parameter.java
index 41eb3d4..6a27a21 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/Parameter.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/Parameter.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance;
+package org.apache.accumulo.testing.performance;
 
 public class Parameter {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/PerformanceTest.java b/src/main/java/org/apache/accumulo/testing/performance/PerformanceTest.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/PerformanceTest.java
rename to src/main/java/org/apache/accumulo/testing/performance/PerformanceTest.java
index d957286..c1200a8 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/PerformanceTest.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/PerformanceTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance;
+package org.apache.accumulo.testing.performance;
 
 public interface PerformanceTest {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/Report.java b/src/main/java/org/apache/accumulo/testing/performance/Report.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/Report.java
rename to src/main/java/org/apache/accumulo/testing/performance/Report.java
index 28924e3..45eb936 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/Report.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/Report.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance;
+package org.apache.accumulo.testing.performance;
 
 import java.util.List;
 import java.util.LongSummaryStatistics;
 
-import org.apache.accumulo.testing.core.performance.Result.Purpose;
+import org.apache.accumulo.testing.performance.Result.Purpose;
 
 import com.google.common.collect.ImmutableList;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/Result.java b/src/main/java/org/apache/accumulo/testing/performance/Result.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/Result.java
rename to src/main/java/org/apache/accumulo/testing/performance/Result.java
index 78d07fa..4e67460 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/Result.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/Result.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance;
+package org.apache.accumulo.testing.performance;
 
 public class Result {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/Stats.java b/src/main/java/org/apache/accumulo/testing/performance/Stats.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/Stats.java
rename to src/main/java/org/apache/accumulo/testing/performance/Stats.java
index cd9c859..f9c7aef 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/Stats.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/Stats.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance;
+package org.apache.accumulo.testing.performance;
 
 public class Stats {
   public final long min;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/SystemConfiguration.java b/src/main/java/org/apache/accumulo/testing/performance/SystemConfiguration.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/SystemConfiguration.java
rename to src/main/java/org/apache/accumulo/testing/performance/SystemConfiguration.java
index c626a01..a32d28f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/SystemConfiguration.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/SystemConfiguration.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance;
+package org.apache.accumulo.testing.performance;
 
 import java.util.Collections;
 import java.util.Map;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/Compare.java b/src/main/java/org/apache/accumulo/testing/performance/impl/Compare.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/impl/Compare.java
rename to src/main/java/org/apache/accumulo/testing/performance/impl/Compare.java
index e14f47d..325b4d0 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/Compare.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/impl/Compare.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.impl;
+package org.apache.accumulo.testing.performance.impl;
 
 import java.io.BufferedReader;
 import java.nio.file.Files;
@@ -27,8 +27,7 @@ import java.util.List;
 import java.util.Map;
 import java.util.Objects;
 
-import org.apache.accumulo.testing.core.performance.Result;
-import org.apache.accumulo.testing.core.performance.Result.Purpose;
+import org.apache.accumulo.testing.performance.Result;
 
 import com.google.common.collect.Sets;
 import com.google.gson.Gson;
@@ -106,7 +105,7 @@ public class Compare {
 
     for (ContextualReport cr : results) {
       for (Result r : cr.results) {
-        if (r.purpose == Purpose.COMPARISON) {
+        if (r.purpose == Result.Purpose.COMPARISON) {
           flattened.put(new TestId(cr.testClass, r.id), r.data.doubleValue());
         }
       }
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/ContextualReport.java b/src/main/java/org/apache/accumulo/testing/performance/impl/ContextualReport.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/impl/ContextualReport.java
rename to src/main/java/org/apache/accumulo/testing/performance/impl/ContextualReport.java
index 5104c31..45f40ad 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/ContextualReport.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/impl/ContextualReport.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.impl;
+package org.apache.accumulo.testing.performance.impl;
 
 import java.time.Instant;
 
-import org.apache.accumulo.testing.core.performance.Report;
+import org.apache.accumulo.testing.performance.Report;
 
 public class ContextualReport extends Report {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/Csv.java b/src/main/java/org/apache/accumulo/testing/performance/impl/Csv.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/impl/Csv.java
rename to src/main/java/org/apache/accumulo/testing/performance/impl/Csv.java
index 6433c3c..a371d11 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/Csv.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/impl/Csv.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.impl;
+package org.apache.accumulo.testing.performance.impl;
 
 import static java.util.stream.Collectors.joining;
 import static java.util.stream.Collectors.toList;
@@ -31,8 +31,7 @@ import java.util.StringJoiner;
 import java.util.TreeMap;
 import java.util.stream.Stream;
 
-import org.apache.accumulo.testing.core.performance.Result;
-import org.apache.accumulo.testing.core.performance.Result.Purpose;
+import org.apache.accumulo.testing.performance.Result;
 
 import com.google.common.collect.Iterables;
 
@@ -96,7 +95,7 @@ public class Csv {
         String id = report.id != null ? report.id :  report.testClass.substring(report.testClass.lastIndexOf('.')+1);
 
         for (Result result : report.results) {
-          if(result.purpose == Purpose.COMPARISON) {
+          if(result.purpose == Result.Purpose.COMPARISON) {
             row.put(id+"."+result.id, result.data.doubleValue());
           }
         }
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/ListTests.java b/src/main/java/org/apache/accumulo/testing/performance/impl/ListTests.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/impl/ListTests.java
rename to src/main/java/org/apache/accumulo/testing/performance/impl/ListTests.java
index f966765..4de3527 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/ListTests.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/impl/ListTests.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.impl;
+package org.apache.accumulo.testing.performance.impl;
 
-import org.apache.accumulo.testing.core.performance.PerformanceTest;
+import org.apache.accumulo.testing.performance.PerformanceTest;
 
 import com.google.common.collect.ImmutableSet;
 import com.google.common.reflect.ClassPath;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/MergeSiteConfig.java b/src/main/java/org/apache/accumulo/testing/performance/impl/MergeSiteConfig.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/impl/MergeSiteConfig.java
rename to src/main/java/org/apache/accumulo/testing/performance/impl/MergeSiteConfig.java
index aeacf20..0e98f85 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/MergeSiteConfig.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/impl/MergeSiteConfig.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.impl;
+package org.apache.accumulo.testing.performance.impl;
 
 import java.io.Reader;
 import java.io.Writer;
@@ -24,7 +24,7 @@ import java.nio.file.Path;
 import java.nio.file.Paths;
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.performance.PerformanceTest;
+import org.apache.accumulo.testing.performance.PerformanceTest;
 
 public class MergeSiteConfig {
   public static void main(String[] args) throws Exception {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/PerfTestRunner.java b/src/main/java/org/apache/accumulo/testing/performance/impl/PerfTestRunner.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/impl/PerfTestRunner.java
rename to src/main/java/org/apache/accumulo/testing/performance/impl/PerfTestRunner.java
index 7a50803..92ef0ef 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/impl/PerfTestRunner.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/impl/PerfTestRunner.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.impl;
+package org.apache.accumulo.testing.performance.impl;
 
 import java.io.Writer;
 import java.nio.file.Files;
@@ -27,9 +27,9 @@ import java.time.format.DateTimeFormatter;
 
 import org.apache.accumulo.core.client.Accumulo;
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.testing.core.performance.Environment;
-import org.apache.accumulo.testing.core.performance.PerformanceTest;
-import org.apache.accumulo.testing.core.performance.Report;
+import org.apache.accumulo.testing.performance.Environment;
+import org.apache.accumulo.testing.performance.PerformanceTest;
+import org.apache.accumulo.testing.performance.Report;
 
 import com.google.gson.Gson;
 import com.google.gson.GsonBuilder;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/tests/RandomCachedLookupsPT.java b/src/main/java/org/apache/accumulo/testing/performance/tests/RandomCachedLookupsPT.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/tests/RandomCachedLookupsPT.java
rename to src/main/java/org/apache/accumulo/testing/performance/tests/RandomCachedLookupsPT.java
index 5655c3f..bee996b 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/tests/RandomCachedLookupsPT.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/tests/RandomCachedLookupsPT.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.tests;
+package org.apache.accumulo.testing.performance.tests;
 
 import static java.util.stream.Collectors.toList;
 
@@ -43,11 +43,10 @@ import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.performance.Environment;
-import org.apache.accumulo.testing.core.performance.PerformanceTest;
-import org.apache.accumulo.testing.core.performance.Report;
-import org.apache.accumulo.testing.core.performance.Report.Builder;
-import org.apache.accumulo.testing.core.performance.SystemConfiguration;
+import org.apache.accumulo.testing.performance.Environment;
+import org.apache.accumulo.testing.performance.PerformanceTest;
+import org.apache.accumulo.testing.performance.Report;
+import org.apache.accumulo.testing.performance.SystemConfiguration;
 import org.apache.hadoop.io.Text;
 
 import com.google.common.base.Strings;
@@ -76,7 +75,7 @@ public class RandomCachedLookupsPT implements PerformanceTest {
 
   @Override
   public Report runTest(Environment env) throws Exception {
-    Builder reportBuilder = Report.builder();
+    Report.Builder reportBuilder = Report.builder();
 
     writeData(reportBuilder, env.getClient(), NUM_ROWS);
 
@@ -112,7 +111,7 @@ public class RandomCachedLookupsPT implements PerformanceTest {
     return reportBuilder.build();
   }
 
-  public static void writeData(Builder reportBuilder, AccumuloClient client, int numRows) throws Exception {
+  public static void writeData(Report.Builder reportBuilder, AccumuloClient client, int numRows) throws Exception {
 
     reportBuilder.parameter("rows", numRows, "Number of random rows written.  Each row has 4 columns.");
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/tests/ScanExecutorPT.java b/src/main/java/org/apache/accumulo/testing/performance/tests/ScanExecutorPT.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/tests/ScanExecutorPT.java
rename to src/main/java/org/apache/accumulo/testing/performance/tests/ScanExecutorPT.java
index 8f1e2d0..125859d 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/tests/ScanExecutorPT.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/tests/ScanExecutorPT.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.tests;
+package org.apache.accumulo.testing.performance.tests;
 
 import java.util.HashMap;
 import java.util.LongSummaryStatistics;
@@ -35,12 +35,12 @@ import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.spi.scan.HintScanPrioritizer;
-import org.apache.accumulo.testing.core.performance.Environment;
-import org.apache.accumulo.testing.core.performance.PerformanceTest;
-import org.apache.accumulo.testing.core.performance.Report;
-import org.apache.accumulo.testing.core.performance.SystemConfiguration;
-import org.apache.accumulo.testing.core.performance.util.TestData;
-import org.apache.accumulo.testing.core.performance.util.TestExecutor;
+import org.apache.accumulo.testing.performance.Environment;
+import org.apache.accumulo.testing.performance.PerformanceTest;
+import org.apache.accumulo.testing.performance.Report;
+import org.apache.accumulo.testing.performance.SystemConfiguration;
+import org.apache.accumulo.testing.performance.util.TestData;
+import org.apache.accumulo.testing.performance.util.TestExecutor;
 import org.apache.hadoop.io.Text;
 
 import com.google.common.collect.ImmutableMap;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/tests/ScanFewFamiliesPT.java b/src/main/java/org/apache/accumulo/testing/performance/tests/ScanFewFamiliesPT.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/tests/ScanFewFamiliesPT.java
rename to src/main/java/org/apache/accumulo/testing/performance/tests/ScanFewFamiliesPT.java
index 4f675f5..f197a97 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/tests/ScanFewFamiliesPT.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/tests/ScanFewFamiliesPT.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.tests;
+package org.apache.accumulo.testing.performance.tests;
 
 import java.util.HashSet;
 import java.util.LongSummaryStatistics;
@@ -26,11 +26,11 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.Scanner;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.performance.Environment;
-import org.apache.accumulo.testing.core.performance.PerformanceTest;
-import org.apache.accumulo.testing.core.performance.Report;
-import org.apache.accumulo.testing.core.performance.SystemConfiguration;
-import org.apache.accumulo.testing.core.performance.util.TestData;
+import org.apache.accumulo.testing.performance.Environment;
+import org.apache.accumulo.testing.performance.PerformanceTest;
+import org.apache.accumulo.testing.performance.Report;
+import org.apache.accumulo.testing.performance.SystemConfiguration;
+import org.apache.accumulo.testing.performance.util.TestData;
 import org.apache.hadoop.io.Text;
 
 import com.google.common.base.Strings;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/util/TestData.java b/src/main/java/org/apache/accumulo/testing/performance/util/TestData.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/util/TestData.java
rename to src/main/java/org/apache/accumulo/testing/performance/util/TestData.java
index ef74cc3..601aaa3 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/util/TestData.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/util/TestData.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.util;
+package org.apache.accumulo.testing.performance.util;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.BatchWriter;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/performance/util/TestExecutor.java b/src/main/java/org/apache/accumulo/testing/performance/util/TestExecutor.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/performance/util/TestExecutor.java
rename to src/main/java/org/apache/accumulo/testing/performance/util/TestExecutor.java
index c4530a4..b6c4609 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/performance/util/TestExecutor.java
+++ b/src/main/java/org/apache/accumulo/testing/performance/util/TestExecutor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.performance.util;
+package org.apache.accumulo.testing.performance.util;
 
 import java.util.ArrayList;
 import java.util.Iterator;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Fixture.java b/src/main/java/org/apache/accumulo/testing/randomwalk/Fixture.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Fixture.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/Fixture.java
index 5b48c12..3497d30 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Fixture.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/Fixture.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk;
+package org.apache.accumulo.testing.randomwalk;
 
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Framework.java b/src/main/java/org/apache/accumulo/testing/randomwalk/Framework.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Framework.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/Framework.java
index 96083fa..25732da 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Framework.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/Framework.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk;
+package org.apache.accumulo.testing.randomwalk;
 
 import java.util.HashMap;
 import java.util.Properties;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Module.java b/src/main/java/org/apache/accumulo/testing/randomwalk/Module.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Module.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/Module.java
index 7a39459..bd7c149 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Module.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/Module.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk;
+package org.apache.accumulo.testing.randomwalk;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Node.java b/src/main/java/org/apache/accumulo/testing/randomwalk/Node.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Node.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/Node.java
index 7d4e038..4e046ff 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Node.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/Node.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk;
+package org.apache.accumulo.testing.randomwalk;
 
 import java.util.Properties;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/RandWalkEnv.java b/src/main/java/org/apache/accumulo/testing/randomwalk/RandWalkEnv.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/RandWalkEnv.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/RandWalkEnv.java
index 207b364..da88d45 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/RandWalkEnv.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/RandWalkEnv.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk;
+package org.apache.accumulo.testing.randomwalk;
 
 import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.MultiTableBatchWriter;
-import org.apache.accumulo.testing.core.TestEnv;
+import org.apache.accumulo.testing.TestEnv;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/State.java b/src/main/java/org/apache/accumulo/testing/randomwalk/State.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/State.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/State.java
index b619674..37a6285 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/State.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/State.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk;
+package org.apache.accumulo.testing.randomwalk;
 
 import java.util.HashMap;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Test.java b/src/main/java/org/apache/accumulo/testing/randomwalk/Test.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Test.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/Test.java
index a8e117a..2028240 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/Test.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/Test.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk;
+package org.apache.accumulo.testing.randomwalk;
 
 /**
  * Tests are extended by users to perform actions on accumulo and are a node of the graph
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkImportTest.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkImportTest.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkImportTest.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkImportTest.java
index f850ee1..0f6ac34 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkImportTest.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkImportTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 
 /**
  * If we have a sufficient back-up of imports, let them work off before adding even more bulk-imports. Imports of PlusOne must always be balanced with imports
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkMinusOne.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkMinusOne.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkMinusOne.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkMinusOne.java
index 7b31d75..d426e53 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkMinusOne.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkMinusOne.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 
 public class BulkMinusOne extends BulkImportTest {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkPlusOne.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkPlusOne.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkPlusOne.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkPlusOne.java
index 40fbaf1..a769a13 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkPlusOne.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkPlusOne.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import java.util.ArrayList;
 import java.util.List;
@@ -28,8 +28,8 @@ import org.apache.accumulo.core.client.rfile.RFileWriter;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.client.rfile.RFile;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.apache.hadoop.fs.FileStatus;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.Path;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkTest.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkTest.java
similarity index 83%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkTest.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkTest.java
index 61fb8cf..d7acc9e 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/BulkTest.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/BulkTest.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public abstract class BulkTest extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Compact.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Compact.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Compact.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Compact.java
index 4f6e4c3..5fd4294 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Compact.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Compact.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.apache.hadoop.io.Text;
 
 public class Compact extends SelectiveBulkTest {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/ConsistencyCheck.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/ConsistencyCheck.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/ConsistencyCheck.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/ConsistencyCheck.java
index a7e16ce..eaac7e5 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/ConsistencyCheck.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/ConsistencyCheck.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import java.util.Map.Entry;
 import java.util.Random;
@@ -25,8 +25,8 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.apache.hadoop.io.Text;
 
 public class ConsistencyCheck extends SelectiveBulkTest {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Merge.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Merge.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Merge.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Merge.java
index e00bdc1..2468a8d 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Merge.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Merge.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import java.util.Arrays;
 import java.util.Random;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.apache.hadoop.io.Text;
 
 public class Merge extends SelectiveBulkTest {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/SelectiveBulkTest.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/SelectiveBulkTest.java
similarity index 89%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/SelectiveBulkTest.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/SelectiveBulkTest.java
index e4cc165..56f9c33 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/SelectiveBulkTest.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/SelectiveBulkTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 
 /**
  * Selectively runs the actual {@link BulkTest} based on the number of active TServers and the number of queued operations.
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/SelectiveQueueing.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/SelectiveQueueing.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/SelectiveQueueing.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/SelectiveQueueing.java
index 1f7c5e9..da87f7a 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/SelectiveQueueing.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/SelectiveQueueing.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import java.util.concurrent.ThreadPoolExecutor;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Setup.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Setup.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Setup.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Setup.java
index ed2f699..2f4e66f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Setup.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Setup.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import java.net.InetAddress;
 import java.util.Properties;
@@ -27,9 +27,9 @@ import org.apache.accumulo.core.client.admin.TableOperations;
 import org.apache.accumulo.core.iterators.LongCombiner;
 import org.apache.accumulo.core.iterators.user.SummingCombiner;
 import org.apache.accumulo.core.util.SimpleThreadPool;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.fs.FileSystem;
 
 public class Setup extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Split.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Split.java
similarity index 89%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Split.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Split.java
index 96d41a9..0f42b0b 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Split.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Split.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import java.util.Random;
 import java.util.SortedSet;
 import java.util.TreeSet;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.apache.hadoop.io.Text;
 
 public class Split extends SelectiveBulkTest {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Verify.java b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Verify.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Verify.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Verify.java
index 7f5937d..818e723 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/bulk/Verify.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/bulk/Verify.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.bulk;
+package org.apache.accumulo.testing.randomwalk.bulk;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -31,9 +31,9 @@ import org.apache.accumulo.core.client.Scanner;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Verify extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/AddSplits.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/AddSplits.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/AddSplits.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/AddSplits.java
index 1e4624a..ff31aaa 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/AddSplits.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/AddSplits.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.ArrayList;
 import java.util.List;
@@ -26,9 +26,9 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.TableOfflineException;
 import org.apache.accumulo.core.metadata.MetadataTable;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class AddSplits extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/BatchScan.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/BatchScan.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/BatchScan.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/BatchScan.java
index 49251fd..2f3af0a 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/BatchScan.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/BatchScan.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.ArrayList;
 import java.util.Iterator;
@@ -33,9 +33,9 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class BatchScan extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/BatchWrite.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/BatchWrite.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/BatchWrite.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/BatchWrite.java
index e6e3d0f..a533af7 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/BatchWrite.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/BatchWrite.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -31,9 +31,9 @@ import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.TableOfflineException;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class BatchWrite extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/BulkImport.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/BulkImport.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/BulkImport.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/BulkImport.java
index 916a422..7715f32 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/BulkImport.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/BulkImport.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -35,9 +35,9 @@ import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.client.rfile.RFile;
 import org.apache.accumulo.core.client.rfile.RFileWriter;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.Path;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ChangeAuthorizations.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ChangeAuthorizations.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ChangeAuthorizations.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ChangeAuthorizations.java
index 4def533..4522c2d 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ChangeAuthorizations.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ChangeAuthorizations.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -26,9 +26,9 @@ import java.util.Random;
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class ChangeAuthorizations extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ChangePermissions.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ChangePermissions.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ChangePermissions.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ChangePermissions.java
index 4ef6683..ca3c5c3 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ChangePermissions.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ChangePermissions.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.ArrayList;
 import java.util.EnumSet;
@@ -28,9 +28,9 @@ import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.security.NamespacePermission;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class ChangePermissions extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CheckPermission.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CheckPermission.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CheckPermission.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CheckPermission.java
index 85555b0..74dce76 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CheckPermission.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CheckPermission.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.security.NamespacePermission;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class CheckPermission extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CloneTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CloneTable.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CloneTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CloneTable.java
index 0fad1c5..2ed8175 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CloneTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CloneTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.HashMap;
 import java.util.HashSet;
@@ -27,9 +27,9 @@ import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.NamespaceNotFoundException;
 import org.apache.accumulo.core.client.TableExistsException;
 import org.apache.accumulo.core.client.TableNotFoundException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class CloneTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Compact.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Compact.java
similarity index 89%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Compact.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Compact.java
index e4cd953..27080a4 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Compact.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Compact.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -23,9 +23,9 @@ import java.util.Random;
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.TableOfflineException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Compact extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ConcurrentFixture.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ConcurrentFixture.java
similarity index 89%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ConcurrentFixture.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ConcurrentFixture.java
index ad2ae35..b6df085 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ConcurrentFixture.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ConcurrentFixture.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.ArrayList;
 import java.util.List;
 import java.util.Random;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.Fixture;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.Fixture;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.apache.hadoop.io.Text;
 
 /**
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Config.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Config.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Config.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Config.java
index 280ac81..c475c59 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Config.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Config.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.Properties;
 import java.util.SortedSet;
@@ -23,9 +23,9 @@ import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType;
 import org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException;
 import org.apache.accumulo.core.conf.Property;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.commons.math3.random.RandomDataGenerator;
 
 public class Config extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CreateNamespace.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CreateNamespace.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CreateNamespace.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CreateNamespace.java
index 4329c79..24b870e 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CreateNamespace.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CreateNamespace.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -22,9 +22,9 @@ import java.util.Random;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.NamespaceExistsException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class CreateNamespace extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CreateTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CreateTable.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CreateTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CreateTable.java
index 1bd5a06..378ac46 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CreateTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CreateTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.NamespaceNotFoundException;
 import org.apache.accumulo.core.client.TableExistsException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class CreateTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CreateUser.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CreateUser.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CreateUser.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CreateUser.java
index d4d120d..7e28385 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/CreateUser.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/CreateUser.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -23,9 +23,9 @@ import java.util.Random;
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.security.tokens.PasswordToken;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class CreateUser extends Test {
   @Override
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DeleteNamespace.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DeleteNamespace.java
similarity index 88%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DeleteNamespace.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DeleteNamespace.java
index c7d06b7..dbdad2c 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DeleteNamespace.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DeleteNamespace.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -23,9 +23,9 @@ import java.util.Random;
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.NamespaceNotEmptyException;
 import org.apache.accumulo.core.client.NamespaceNotFoundException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class DeleteNamespace extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DeleteRange.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DeleteRange.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DeleteRange.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DeleteRange.java
index 365face..6c5d9d0 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DeleteRange.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DeleteRange.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -25,9 +25,9 @@ import java.util.Random;
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.TableOfflineException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class DeleteRange extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DeleteTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DeleteTable.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DeleteTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DeleteTable.java
index 825b00b..67f3e14 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DeleteTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DeleteTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -22,9 +22,9 @@ import java.util.Random;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.TableNotFoundException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class DeleteTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DropUser.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DropUser.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DropUser.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DropUser.java
index 3070631..bd21b5e 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/DropUser.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/DropUser.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -22,9 +22,9 @@ import java.util.Random;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class DropUser extends Test {
   @Override
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/IsolatedScan.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/IsolatedScan.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/IsolatedScan.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/IsolatedScan.java
index 64904b5..7f91622 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/IsolatedScan.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/IsolatedScan.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Map.Entry;
@@ -31,9 +31,9 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.util.PeekingIterator;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class IsolatedScan extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ListSplits.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ListSplits.java
similarity index 88%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ListSplits.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ListSplits.java
index 7d7a4dd..1f046fe 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ListSplits.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ListSplits.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.Collection;
 import java.util.List;
@@ -24,9 +24,9 @@ import java.util.Random;
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.TableNotFoundException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class ListSplits extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Merge.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Merge.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Merge.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Merge.java
index 8511ad6..900ced6 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Merge.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Merge.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.ArrayList;
 import java.util.List;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.TableOfflineException;
 import org.apache.accumulo.core.metadata.MetadataTable;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Merge extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/OfflineTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/OfflineTable.java
similarity index 89%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/OfflineTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/OfflineTable.java
index 8561e32..2d3c12f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/OfflineTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/OfflineTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import static com.google.common.util.concurrent.Uninterruptibles.sleepUninterruptibly;
 
@@ -25,9 +25,9 @@ import java.util.concurrent.TimeUnit;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.TableNotFoundException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class OfflineTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/RenameNamespace.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/RenameNamespace.java
similarity index 88%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/RenameNamespace.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/RenameNamespace.java
index 0a4d868..5399e22 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/RenameNamespace.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/RenameNamespace.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -23,9 +23,9 @@ import java.util.Random;
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.NamespaceExistsException;
 import org.apache.accumulo.core.client.NamespaceNotFoundException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class RenameNamespace extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/RenameTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/RenameTable.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/RenameTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/RenameTable.java
index f0715ea..a8c1b73 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/RenameTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/RenameTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.List;
 import java.util.Properties;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.NamespaceNotFoundException;
 import org.apache.accumulo.core.client.TableExistsException;
 import org.apache.accumulo.core.client.TableNotFoundException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class RenameTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Replication.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Replication.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Replication.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Replication.java
index 0d08e66..8018df4 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Replication.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Replication.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import static com.google.common.util.concurrent.Uninterruptibles.sleepUninterruptibly;
 import static org.apache.accumulo.core.conf.Property.MASTER_REPLICATION_SCAN_INTERVAL;
@@ -27,7 +27,6 @@ import static org.apache.accumulo.core.conf.Property.REPLICATION_WORK_PROCESSOR_
 import static org.apache.accumulo.core.conf.Property.REPLICATION_WORK_PROCESSOR_PERIOD;
 import static org.apache.accumulo.core.conf.Property.TABLE_REPLICATION;
 import static org.apache.accumulo.core.conf.Property.TABLE_REPLICATION_TARGET;
-import static org.apache.accumulo.server.replication.ReplicaSystemFactory.getPeerConfigurationValue;
 
 import java.util.Map.Entry;
 import java.util.Properties;
@@ -48,10 +47,9 @@ import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.replication.ReplicationTable;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
-import org.apache.accumulo.tserver.replication.AccumuloReplicaSystem;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Replication extends Test {
@@ -61,14 +59,15 @@ public class Replication extends Test {
 
   @Override
   public void visit(State state, RandWalkEnv env, Properties props) throws Exception {
-    final AccumuloClient c = (AccumuloClient) env.getAccumuloClient();
+    final AccumuloClient c = env.getAccumuloClient();
     final String instName = c.info().getInstanceName();
     final InstanceOperations iOps = c.instanceOperations();
     final TableOperations tOps = c.tableOperations();
 
     // Replicate to ourselves
     iOps.setProperty(REPLICATION_NAME.getKey(), instName);
-    iOps.setProperty(REPLICATION_PEERS.getKey() + instName, getPeerConfigurationValue(AccumuloReplicaSystem.class, instName + "," + c.info().getZooKeepers()));
+    iOps.setProperty(REPLICATION_PEERS.getKey() + instName, "org.apache.accumulo.tserver.replication.AccumuloReplicaSystem," + instName + ","
+        + c.info().getZooKeepers());
     iOps.setProperty(REPLICATION_PEER_USER.getKey() + instName, env.getAccumuloUserName());
     iOps.setProperty(REPLICATION_PEER_PASSWORD.getKey() + instName, env.getAccumuloPassword());
     // Tweak some replication parameters to make the replication go faster
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ScanTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ScanTable.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ScanTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ScanTable.java
index 80311fb..3ac45cb 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/ScanTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/ScanTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.Iterator;
 import java.util.List;
@@ -31,9 +31,9 @@ import org.apache.accumulo.core.client.TableOfflineException;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class ScanTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Setup.java b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Setup.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Setup.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Setup.java
index 3902c97..833da77 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/concurrent/Setup.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/concurrent/Setup.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.concurrent;
+package org.apache.accumulo.testing.randomwalk.concurrent;
 
 import java.util.ArrayList;
 import java.util.List;
 import java.util.Properties;
 import java.util.Random;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Setup extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Compact.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Compact.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Compact.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Compact.java
index e548d11..647bb7d 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Compact.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Compact.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 import java.util.Properties;
 import java.util.Random;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 /**
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Flush.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Flush.java
similarity index 86%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Flush.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Flush.java
index e84fd27..fe48c39 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Flush.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Flush.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 import java.util.Properties;
 import java.util.Random;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 /**
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Init.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Init.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Init.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Init.java
index b300c95..0661a69 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Init.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Init.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -26,9 +26,9 @@ import org.apache.accumulo.core.client.ConditionalWriter;
 import org.apache.accumulo.core.client.ConditionalWriter.Status;
 import org.apache.accumulo.core.data.Condition;
 import org.apache.accumulo.core.data.ConditionalMutation;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 /**
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Merge.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Merge.java
similarity index 86%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Merge.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Merge.java
index f2478cf..363bd87 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Merge.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Merge.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 import java.util.Properties;
 import java.util.Random;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 /**
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Setup.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Setup.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Setup.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Setup.java
index 629b765..7651144 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Setup.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Setup.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 import java.util.Properties;
 import java.util.Random;
@@ -23,9 +23,9 @@ import org.apache.accumulo.core.client.ConditionalWriter;
 import org.apache.accumulo.core.client.ConditionalWriterConfig;
 import org.apache.accumulo.core.client.TableExistsException;
 import org.apache.accumulo.core.conf.Property;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Setup extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Split.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Split.java
similarity index 86%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Split.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Split.java
index 7dffafc..b8e306f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Split.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Split.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 import java.util.Arrays;
 import java.util.Properties;
@@ -22,9 +22,9 @@ import java.util.Random;
 import java.util.TreeSet;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 /**
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/TearDown.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/TearDown.java
similarity index 82%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/TearDown.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/TearDown.java
index 324d1a0..5bb1b14 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/TearDown.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/TearDown.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 import java.util.Properties;
 
 import org.apache.accumulo.core.client.ConditionalWriter;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 /**
  *
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Transfer.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Transfer.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Transfer.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Transfer.java
index a13750f..464d396 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Transfer.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Transfer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 import java.util.Map.Entry;
 import java.util.Properties;
@@ -31,9 +31,9 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.commons.math3.distribution.ZipfDistribution;
 import org.apache.hadoop.io.Text;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Utils.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Utils.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Utils.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Utils.java
index 5436c22..72058bd 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Utils.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Utils.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 /**
  *
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Verify.java b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Verify.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Verify.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Verify.java
index 23c866c..4366d2c 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/conditional/Verify.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/conditional/Verify.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.conditional;
+package org.apache.accumulo.testing.randomwalk.conditional;
 
 import java.util.Map.Entry;
 import java.util.Properties;
@@ -29,9 +29,9 @@ import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.iterators.user.ColumnSliceFilter;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 /**
  *
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/Commit.java b/src/main/java/org/apache/accumulo/testing/randomwalk/image/Commit.java
similarity index 83%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/Commit.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/image/Commit.java
index b7e5dae..7097b90 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/Commit.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/image/Commit.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.image;
+package org.apache.accumulo.testing.randomwalk.image;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Commit extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/ImageFixture.java b/src/main/java/org/apache/accumulo/testing/randomwalk/image/ImageFixture.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/ImageFixture.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/image/ImageFixture.java
index eedf1ee..4d9f7bd 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/ImageFixture.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/image/ImageFixture.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.image;
+package org.apache.accumulo.testing.randomwalk.image;
 
 import java.net.InetAddress;
 import java.util.HashMap;
@@ -29,9 +29,9 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.MultiTableBatchWriter;
 import org.apache.accumulo.core.client.MutationsRejectedException;
 import org.apache.accumulo.core.client.TableExistsException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.Fixture;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.Fixture;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.apache.hadoop.io.Text;
 
 public class ImageFixture extends Fixture {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/ScanMeta.java b/src/main/java/org/apache/accumulo/testing/randomwalk/image/ScanMeta.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/ScanMeta.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/image/ScanMeta.java
index 5463d36..7e56668 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/ScanMeta.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/image/ScanMeta.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.image;
+package org.apache.accumulo.testing.randomwalk.image;
 
 import java.util.ArrayList;
 import java.util.HashMap;
@@ -32,9 +32,9 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class ScanMeta extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/TableOp.java b/src/main/java/org/apache/accumulo/testing/randomwalk/image/TableOp.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/TableOp.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/image/TableOp.java
index 116a79b..e4cf731 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/TableOp.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/image/TableOp.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.image;
+package org.apache.accumulo.testing.randomwalk.image;
 
 import java.util.HashMap;
 import java.util.Map;
@@ -24,9 +24,9 @@ import java.util.Set;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.admin.TableOperations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class TableOp extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/Verify.java b/src/main/java/org/apache/accumulo/testing/randomwalk/image/Verify.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/Verify.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/image/Verify.java
index 56f1581..8039e7a 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/Verify.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/image/Verify.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.image;
+package org.apache.accumulo.testing.randomwalk.image;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -31,9 +31,9 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Verify extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/Write.java b/src/main/java/org/apache/accumulo/testing/randomwalk/image/Write.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/Write.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/image/Write.java
index 965ba60..ea24cb3 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/image/Write.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/image/Write.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.image;
+package org.apache.accumulo.testing.randomwalk.image;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -27,9 +27,9 @@ import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.MultiTableBatchWriter;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Write extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/Commit.java b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/Commit.java
similarity index 84%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/Commit.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/multitable/Commit.java
index 72c3326..b8dbe1d 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/Commit.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/Commit.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.multitable;
+package org.apache.accumulo.testing.randomwalk.multitable;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Commit extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/CopyTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/CopyTable.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/CopyTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/multitable/CopyTable.java
index d55a211..634c1fc 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/CopyTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/CopyTable.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.multitable;
+package org.apache.accumulo.testing.randomwalk.multitable;
 
 import java.util.List;
 import java.util.Properties;
 import java.util.Random;
 import java.util.TreeSet;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 import org.apache.hadoop.util.ToolRunner;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/CopyTool.java b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/CopyTool.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/CopyTool.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/multitable/CopyTool.java
index 18393d9..7831e60 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/CopyTool.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/CopyTool.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.multitable;
+package org.apache.accumulo.testing.randomwalk.multitable;
 
 import java.io.IOException;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/CreateTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/CreateTable.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/CreateTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/multitable/CreateTable.java
index 5d11530..b132662 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/CreateTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/CreateTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.multitable;
+package org.apache.accumulo.testing.randomwalk.multitable;
 
 import java.util.List;
 import java.util.Properties;
@@ -22,9 +22,9 @@ import java.util.TreeSet;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.TableExistsException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class CreateTable extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/DropTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/DropTable.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/DropTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/multitable/DropTable.java
index 1042ec1..107dabd 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/DropTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/DropTable.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.multitable;
+package org.apache.accumulo.testing.randomwalk.multitable;
 
 import java.util.List;
 import java.util.Properties;
 import java.util.Random;
 
 import org.apache.accumulo.core.client.TableNotFoundException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class DropTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/MultiTableFixture.java b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/MultiTableFixture.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/MultiTableFixture.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/multitable/MultiTableFixture.java
index 4cfb237..0a00250 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/MultiTableFixture.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/MultiTableFixture.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.multitable;
+package org.apache.accumulo.testing.randomwalk.multitable;
 
 import java.net.InetAddress;
 import java.util.List;
@@ -24,9 +24,9 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.MultiTableBatchWriter;
 import org.apache.accumulo.core.client.MutationsRejectedException;
 import org.apache.accumulo.core.client.TableNotFoundException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.Fixture;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.Fixture;
+import org.apache.accumulo.testing.randomwalk.State;
 
 public class MultiTableFixture extends Fixture {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/OfflineTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/OfflineTable.java
similarity index 86%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/OfflineTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/multitable/OfflineTable.java
index cf0d199..d226d0c 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/OfflineTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/OfflineTable.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.multitable;
+package org.apache.accumulo.testing.randomwalk.multitable;
 
 import java.util.List;
 import java.util.Properties;
 import java.util.Random;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class OfflineTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/Write.java b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/Write.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/Write.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/multitable/Write.java
index 80e9c0e..65e5d75 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/multitable/Write.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/multitable/Write.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.multitable;
+package org.apache.accumulo.testing.randomwalk.multitable;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -29,9 +29,9 @@ import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.TableOfflineException;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Write extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/AlterSystemPerm.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/AlterSystemPerm.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/AlterSystemPerm.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/AlterSystemPerm.java
index 5834ace..f37e258 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/AlterSystemPerm.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/AlterSystemPerm.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Properties;
 import java.util.Random;
@@ -23,9 +23,9 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.security.SystemPermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class AlterSystemPerm extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/AlterTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/AlterTable.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/AlterTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/AlterTable.java
index c973e11..97c2b8d 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/AlterTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/AlterTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.net.InetAddress;
 import java.util.Properties;
@@ -27,9 +27,9 @@ import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.security.SecurityErrorCode;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class AlterTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/AlterTablePerm.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/AlterTablePerm.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/AlterTablePerm.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/AlterTablePerm.java
index 55127b4..2d2509f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/AlterTablePerm.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/AlterTablePerm.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Properties;
 import java.util.Random;
@@ -28,9 +28,9 @@ import org.apache.accumulo.core.client.security.SecurityErrorCode;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class AlterTablePerm extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/Authenticate.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/Authenticate.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/Authenticate.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/Authenticate.java
index 037abbc..bcc4b05 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/Authenticate.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/Authenticate.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Arrays;
 import java.util.Properties;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
 import org.apache.accumulo.core.client.security.tokens.PasswordToken;
 import org.apache.accumulo.core.security.SystemPermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Authenticate extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/ChangePass.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/ChangePass.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/ChangePass.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/ChangePass.java
index b409892..b8d653f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/ChangePass.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/ChangePass.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Properties;
 import java.util.Random;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
 import org.apache.accumulo.core.client.security.tokens.PasswordToken;
 import org.apache.accumulo.core.security.SystemPermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class ChangePass extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/CreateTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/CreateTable.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/CreateTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/CreateTable.java
index b783ca2..f4e10fc 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/CreateTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/CreateTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Properties;
 
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.client.TableExistsException;
 import org.apache.accumulo.core.client.security.SecurityErrorCode;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class CreateTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/CreateUser.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/CreateUser.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/CreateUser.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/CreateUser.java
index 48d91de..c84e6d6 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/CreateUser.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/CreateUser.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Properties;
 
@@ -23,9 +23,9 @@ import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.security.tokens.PasswordToken;
 import org.apache.accumulo.core.security.SystemPermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class CreateUser extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/DropTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/DropTable.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/DropTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/DropTable.java
index 2b584f2..be75a3b 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/DropTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/DropTable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Properties;
 
@@ -27,9 +27,9 @@ import org.apache.accumulo.core.client.security.SecurityErrorCode;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class DropTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/DropUser.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/DropUser.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/DropUser.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/DropUser.java
index 5fd8d37..fb0190f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/DropUser.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/DropUser.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Properties;
 
@@ -22,9 +22,9 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.security.SystemPermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class DropUser extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/SecurityFixture.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/SecurityFixture.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/SecurityFixture.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/SecurityFixture.java
index af5d564..a61eed9 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/SecurityFixture.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/SecurityFixture.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.net.InetAddress;
 import java.util.Set;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.conf.ClientProperty;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.Fixture;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.Fixture;
+import org.apache.accumulo.testing.randomwalk.State;
 
 public class SecurityFixture extends Fixture {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/SecurityHelper.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/SecurityHelper.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/SecurityHelper.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/SecurityHelper.java
index 59cb434..1097c7c 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/SecurityHelper.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/SecurityHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -24,7 +24,7 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/SetAuths.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/SetAuths.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/SetAuths.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/SetAuths.java
index c309f35..6193192 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/SetAuths.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/SetAuths.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Properties;
 import java.util.Random;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.security.SystemPermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class SetAuths extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/TableOp.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/TableOp.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/TableOp.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/TableOp.java
index 3029542..b2b6504 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/TableOp.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/TableOp.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -45,9 +45,9 @@ import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.security.ColumnVisibility;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.Path;
 import org.apache.hadoop.io.Text;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/Validate.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/Validate.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/Validate.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/Validate.java
index 3d7312f..a7f788f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/Validate.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/Validate.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.util.Properties;
 
@@ -24,9 +24,9 @@ import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.security.SecurityErrorCode;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.slf4j.Logger;
 
 public class Validate extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/WalkingSecurity.java b/src/main/java/org/apache/accumulo/testing/randomwalk/security/WalkingSecurity.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/WalkingSecurity.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/security/WalkingSecurity.java
index 4a0c6f2..65c5b79 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/security/WalkingSecurity.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/security/WalkingSecurity.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.security;
+package org.apache.accumulo.testing.randomwalk.security;
 
 import java.io.IOException;
 import java.util.HashMap;
@@ -27,8 +27,8 @@ import org.apache.accumulo.core.client.security.tokens.PasswordToken;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.fs.FileSystem;
 import org.slf4j.Logger;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/BatchVerify.java b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/BatchVerify.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/BatchVerify.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/sequential/BatchVerify.java
index 5cece6e..735edc7 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/BatchVerify.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/BatchVerify.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.sequential;
+package org.apache.accumulo.testing.randomwalk.sequential;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -30,9 +30,9 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class BatchVerify extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/Commit.java b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/Commit.java
similarity index 82%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/Commit.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/sequential/Commit.java
index 7ecd063..a31ecd8 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/Commit.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/Commit.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.sequential;
+package org.apache.accumulo.testing.randomwalk.sequential;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Commit extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/MapRedVerify.java b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/MapRedVerify.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/MapRedVerify.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/sequential/MapRedVerify.java
index 1b40a7b..39a27fb 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/MapRedVerify.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/MapRedVerify.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.sequential;
+package org.apache.accumulo.testing.randomwalk.sequential;
 
 import java.util.Map.Entry;
 import java.util.Properties;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.util.ToolRunner;
 
 public class MapRedVerify extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/MapRedVerifyTool.java b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/MapRedVerifyTool.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/MapRedVerifyTool.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/sequential/MapRedVerifyTool.java
index 2751fbb..b67c11b 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/MapRedVerifyTool.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/MapRedVerifyTool.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.sequential;
+package org.apache.accumulo.testing.randomwalk.sequential;
 
 import java.io.IOException;
 import java.util.Iterator;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/SequentialFixture.java b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/SequentialFixture.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/SequentialFixture.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/sequential/SequentialFixture.java
index a7b4993..d5551a2 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/SequentialFixture.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/SequentialFixture.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.sequential;
+package org.apache.accumulo.testing.randomwalk.sequential;
 
 import java.net.InetAddress;
 
@@ -22,9 +22,9 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.MultiTableBatchWriter;
 import org.apache.accumulo.core.client.MutationsRejectedException;
 import org.apache.accumulo.core.client.TableExistsException;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.Fixture;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.Fixture;
+import org.apache.accumulo.testing.randomwalk.State;
 
 public class SequentialFixture extends Fixture {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/Write.java b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/Write.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/Write.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/sequential/Write.java
index 9394e28..b697eab 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/sequential/Write.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/sequential/Write.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.sequential;
+package org.apache.accumulo.testing.randomwalk.sequential;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -23,9 +23,9 @@ import java.util.Properties;
 import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Write extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/BulkInsert.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/BulkInsert.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/BulkInsert.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/BulkInsert.java
index a194f11..24212ff 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/BulkInsert.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/BulkInsert.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import static com.google.common.util.concurrent.Uninterruptibles.sleepUninterruptibly;
 import static java.nio.charset.StandardCharsets.UTF_8;
@@ -36,9 +36,9 @@ import org.apache.accumulo.core.data.ColumnUpdate;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.fs.FileStatus;
 import org.apache.hadoop.fs.FileSystem;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/CloneIndex.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/CloneIndex.java
similarity index 87%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/CloneIndex.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/CloneIndex.java
index 985fa23..3b33d07 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/CloneIndex.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/CloneIndex.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.HashMap;
 import java.util.HashSet;
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class CloneIndex extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Commit.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Commit.java
similarity index 81%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Commit.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/Commit.java
index 32bb6cf..9bfacc7 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Commit.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Commit.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Commit extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/CompactFilter.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/CompactFilter.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/CompactFilter.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/CompactFilter.java
index 5ab060e..ac5fe92 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/CompactFilter.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/CompactFilter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.ArrayList;
 import java.util.Iterator;
@@ -30,9 +30,9 @@ import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.iterators.user.RegExFilter;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 /**
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Delete.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Delete.java
similarity index 89%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Delete.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/Delete.java
index 6cd24ca..bf9b98f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Delete.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Delete.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Map.Entry;
 import java.util.Properties;
@@ -23,9 +23,9 @@ import java.util.Random;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Delete extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/DeleteSomeDocs.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/DeleteSomeDocs.java
similarity index 92%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/DeleteSomeDocs.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/DeleteSomeDocs.java
index e4ad81e..4611070 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/DeleteSomeDocs.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/DeleteSomeDocs.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -27,9 +27,9 @@ import org.apache.accumulo.core.client.IteratorSetting;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.iterators.user.RegExFilter;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 //a test created to test the batch deleter
 public class DeleteSomeDocs extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/DeleteWord.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/DeleteWord.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/DeleteWord.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/DeleteWord.java
index 0dc828e..8cced58 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/DeleteWord.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/DeleteWord.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.ArrayList;
 import java.util.Map.Entry;
@@ -29,9 +29,9 @@ import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 /**
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/ExportIndex.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/ExportIndex.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/ExportIndex.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/ExportIndex.java
index dc2186f..588bbe0 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/ExportIndex.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/ExportIndex.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -26,9 +26,9 @@ import java.util.Map.Entry;
 import java.util.Properties;
 
 import org.apache.accumulo.core.conf.Property;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.FileUtil;
 import org.apache.hadoop.fs.Path;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Flush.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Flush.java
similarity index 85%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Flush.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/Flush.java
index 13141a8..af050f9 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Flush.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Flush.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Properties;
 import java.util.Random;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Flush extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Grep.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Grep.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Grep.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/Grep.java
index 2dd5c9c..bb77836 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Grep.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Grep.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Arrays;
 import java.util.Collections;
@@ -31,9 +31,9 @@ import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.iterators.user.IntersectingIterator;
 import org.apache.accumulo.core.iterators.user.RegExFilter;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Grep extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Insert.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Insert.java
similarity index 94%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Insert.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/Insert.java
index 9f480eb..eb65286 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Insert.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Insert.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.HashSet;
 import java.util.Properties;
@@ -26,9 +26,9 @@ import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Insert extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Merge.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Merge.java
similarity index 89%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Merge.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/Merge.java
index 673b651..521a702 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Merge.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Merge.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Collection;
 import java.util.Properties;
@@ -22,9 +22,9 @@ import java.util.SortedSet;
 import java.util.TreeSet;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Merge extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Reindex.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Reindex.java
similarity index 90%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Reindex.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/Reindex.java
index f5b6b02..b982bfd 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Reindex.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Reindex.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Map.Entry;
 import java.util.Properties;
@@ -26,9 +26,9 @@ import org.apache.accumulo.core.client.Scanner;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Reindex extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Search.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Search.java
similarity index 93%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Search.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/Search.java
index a572c38..109f7ca 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Search.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Search.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Collections;
 import java.util.HashSet;
@@ -31,9 +31,9 @@ import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.iterators.user.IntersectingIterator;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Search extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/ShardFixture.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/ShardFixture.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/ShardFixture.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/ShardFixture.java
index 86c8571..eda75e0 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/ShardFixture.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/ShardFixture.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.net.InetAddress;
 import java.util.Random;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.MultiTableBatchWriter;
 import org.apache.accumulo.core.client.MutationsRejectedException;
 import org.apache.accumulo.core.conf.Property;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.Fixture;
-import org.apache.accumulo.testing.core.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.Fixture;
+import org.apache.accumulo.testing.randomwalk.State;
 import org.apache.hadoop.io.Text;
 import org.slf4j.Logger;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/SortTool.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/SortTool.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/SortTool.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/SortTool.java
index 04c96f4..5206417 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/SortTool.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/SortTool.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Collection;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Split.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Split.java
similarity index 86%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Split.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/Split.java
index 76a6fa5..965cd55 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/Split.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/Split.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Properties;
 import java.util.Random;
 import java.util.SortedSet;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 import org.apache.hadoop.io.Text;
 
 public class Split extends Test {
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/VerifyIndex.java b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/VerifyIndex.java
similarity index 91%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/VerifyIndex.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/shard/VerifyIndex.java
index 3db9574..96b840d 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/shard/VerifyIndex.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/shard/VerifyIndex.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.shard;
+package org.apache.accumulo.testing.randomwalk.shard;
 
 import java.util.Iterator;
 import java.util.Map.Entry;
@@ -25,9 +25,9 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.PartialKey;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.Authorizations;
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class VerifyIndex extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/CreateTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/CreateTable.java
similarity index 80%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/CreateTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/unit/CreateTable.java
index 1282993..281d89f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/CreateTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/CreateTable.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.randomwalk.unit;
+package org.apache.accumulo.testing.randomwalk.unit;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class CreateTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/DeleteTable.java b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/DeleteTable.java
similarity index 80%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/DeleteTable.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/unit/DeleteTable.java
index af90276..d78f71b 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/DeleteTable.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/DeleteTable.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.unit;
+package org.apache.accumulo.testing.randomwalk.unit;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class DeleteTable extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/Ingest.java b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/Ingest.java
similarity index 80%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/Ingest.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/unit/Ingest.java
index 1b37baf..ea4c38b 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/Ingest.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/Ingest.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.unit;
+package org.apache.accumulo.testing.randomwalk.unit;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Ingest extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/Scan.java b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/Scan.java
similarity index 80%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/Scan.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/unit/Scan.java
index 8f6bdae..c4094f7 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/Scan.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/Scan.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.unit;
+package org.apache.accumulo.testing.randomwalk.unit;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Scan extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/Verify.java b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/Verify.java
similarity index 80%
rename from core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/Verify.java
rename to src/main/java/org/apache/accumulo/testing/randomwalk/unit/Verify.java
index 4dd5f29..332e789 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/randomwalk/unit/Verify.java
+++ b/src/main/java/org/apache/accumulo/testing/randomwalk/unit/Verify.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk.unit;
+package org.apache.accumulo.testing.randomwalk.unit;
 
 import java.util.Properties;
 
-import org.apache.accumulo.testing.core.randomwalk.RandWalkEnv;
-import org.apache.accumulo.testing.core.randomwalk.State;
-import org.apache.accumulo.testing.core.randomwalk.Test;
+import org.apache.accumulo.testing.randomwalk.RandWalkEnv;
+import org.apache.accumulo.testing.randomwalk.State;
+import org.apache.accumulo.testing.randomwalk.Test;
 
 public class Verify extends Test {
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/scalability/Ingest.java b/src/main/java/org/apache/accumulo/testing/scalability/Ingest.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/scalability/Ingest.java
rename to src/main/java/org/apache/accumulo/testing/scalability/Ingest.java
index cd597ad..8191b38 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/scalability/Ingest.java
+++ b/src/main/java/org/apache/accumulo/testing/scalability/Ingest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.scalability;
+package org.apache.accumulo.testing.scalability;
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
@@ -29,7 +29,7 @@ import org.apache.accumulo.core.client.MutationsRejectedException;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.security.ColumnVisibility;
-import org.apache.accumulo.testing.core.continuous.ContinuousIngest;
+import org.apache.accumulo.testing.continuous.ContinuousIngest;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/scalability/Run.java b/src/main/java/org/apache/accumulo/testing/scalability/Run.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/scalability/Run.java
rename to src/main/java/org/apache/accumulo/testing/scalability/Run.java
index f7f7458..57c2af1 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/scalability/Run.java
+++ b/src/main/java/org/apache/accumulo/testing/scalability/Run.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.scalability;
+package org.apache.accumulo.testing.scalability;
 
 import java.io.FileInputStream;
 import java.net.InetAddress;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/scalability/ScaleTest.java b/src/main/java/org/apache/accumulo/testing/scalability/ScaleTest.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/scalability/ScaleTest.java
rename to src/main/java/org/apache/accumulo/testing/scalability/ScaleTest.java
index d511bfb..c806f7f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/scalability/ScaleTest.java
+++ b/src/main/java/org/apache/accumulo/testing/scalability/ScaleTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.scalability;
+package org.apache.accumulo.testing.scalability;
 
 import java.util.Properties;
 import java.util.TreeSet;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/DataWriter.java b/src/main/java/org/apache/accumulo/testing/stress/DataWriter.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/DataWriter.java
rename to src/main/java/org/apache/accumulo/testing/stress/DataWriter.java
index 503d41d..468e58a 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/DataWriter.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/DataWriter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.MutationsRejectedException;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/IntArgValidator.java b/src/main/java/org/apache/accumulo/testing/stress/IntArgValidator.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/IntArgValidator.java
rename to src/main/java/org/apache/accumulo/testing/stress/IntArgValidator.java
index 2265892..1ec19b4 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/IntArgValidator.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/IntArgValidator.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 import static com.google.common.base.Preconditions.checkArgument;
 import static java.util.Objects.requireNonNull;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/RandomByteArrays.java b/src/main/java/org/apache/accumulo/testing/stress/RandomByteArrays.java
similarity index 95%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/RandomByteArrays.java
rename to src/main/java/org/apache/accumulo/testing/stress/RandomByteArrays.java
index d98bc37..9514e3a 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/RandomByteArrays.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/RandomByteArrays.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 /**
  * A stream that will create random byte arrays as it is looped over.
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/RandomMutations.java b/src/main/java/org/apache/accumulo/testing/stress/RandomMutations.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/RandomMutations.java
rename to src/main/java/org/apache/accumulo/testing/stress/RandomMutations.java
index 6144dda..5effbf9 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/RandomMutations.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/RandomMutations.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 import org.apache.accumulo.core.data.Mutation;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/RandomWithinRange.java b/src/main/java/org/apache/accumulo/testing/stress/RandomWithinRange.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/RandomWithinRange.java
rename to src/main/java/org/apache/accumulo/testing/stress/RandomWithinRange.java
index 1456b3c..a9f0f26 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/RandomWithinRange.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/RandomWithinRange.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 import static com.google.common.base.Preconditions.checkArgument;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/Scan.java b/src/main/java/org/apache/accumulo/testing/stress/Scan.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/Scan.java
rename to src/main/java/org/apache/accumulo/testing/stress/Scan.java
index 04443ef..b1a5676 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/Scan.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/Scan.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 import java.util.ArrayList;
 import java.util.Iterator;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/ScanOpts.java b/src/main/java/org/apache/accumulo/testing/stress/ScanOpts.java
similarity index 97%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/ScanOpts.java
rename to src/main/java/org/apache/accumulo/testing/stress/ScanOpts.java
index 28b1118..9fe4741 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/ScanOpts.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/ScanOpts.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 import org.apache.accumulo.core.cli.ClientOnDefaultTable;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/Stream.java b/src/main/java/org/apache/accumulo/testing/stress/Stream.java
similarity index 96%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/Stream.java
rename to src/main/java/org/apache/accumulo/testing/stress/Stream.java
index a6eaa66..a78de10 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/Stream.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/Stream.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 import java.util.Iterator;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/Write.java b/src/main/java/org/apache/accumulo/testing/stress/Write.java
similarity index 98%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/Write.java
rename to src/main/java/org/apache/accumulo/testing/stress/Write.java
index 1cd4739..66fb496 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/Write.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/Write.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 import org.apache.accumulo.core.cli.BatchWriterOpts;
 import org.apache.accumulo.core.client.AccumuloClient;
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/WriteOptions.java b/src/main/java/org/apache/accumulo/testing/stress/WriteOptions.java
similarity index 99%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/WriteOptions.java
rename to src/main/java/org/apache/accumulo/testing/stress/WriteOptions.java
index 288215f..83d975f 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/WriteOptions.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/WriteOptions.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
 import org.apache.accumulo.core.cli.ClientOnDefaultTable;
 
diff --git a/core/src/main/java/org/apache/accumulo/testing/core/stress/package-info.java b/src/main/java/org/apache/accumulo/testing/stress/package-info.java
similarity index 82%
rename from core/src/main/java/org/apache/accumulo/testing/core/stress/package-info.java
rename to src/main/java/org/apache/accumulo/testing/stress/package-info.java
index 4f3d636..658938a 100644
--- a/core/src/main/java/org/apache/accumulo/testing/core/stress/package-info.java
+++ b/src/main/java/org/apache/accumulo/testing/stress/package-info.java
@@ -18,11 +18,11 @@
  * This package contains utility classes designed to test Accumulo when large cells are being written. This is an attempt to observe the behavior Accumulo
  * displays when compacting and reading these cells.
  *
- * There are two components to this package: {@link org.apache.accumulo.testing.core.stress.Write} and {@link org.apache.accumulo.testing.core.stress.Scan}.
+ * There are two components to this package: {@link org.apache.accumulo.testing.stress.Write} and {@link org.apache.accumulo.testing.stress.Scan}.
  *
- * The {@link org.apache.accumulo.testing.core.stress.Write} provides facilities for writing random sized cells. Users can configure minimum and maximum
+ * The {@link org.apache.accumulo.testing.stress.Write} provides facilities for writing random sized cells. Users can configure minimum and maximum
  * sized portions of a cell. The portions users can configure are the row, column family, column qualifier and value. Note that the sizes are uniformly
- * distributed between the minimum and maximum values. See {@link org.apache.accumulo.testing.core.stress.WriteOptions} for available options and default sizing
+ * distributed between the minimum and maximum values. See {@link org.apache.accumulo.testing.stress.WriteOptions} for available options and default sizing
  * information.
  *
  * The Scan provides users with the ability to query tables generated by the Write. It will pick a tablet at random and scan the entire range. The
@@ -32,5 +32,5 @@
  * There is no shared state intended by either of these services. This allows multiple clients to be run in parallel, either on the same host or distributed
  * across hosts.
  */
-package org.apache.accumulo.testing.core.stress;
+package org.apache.accumulo.testing.stress;
 
diff --git a/core/src/main/resources/randomwalk/module.xsd b/src/main/resources/randomwalk/module.xsd
similarity index 100%
rename from core/src/main/resources/randomwalk/module.xsd
rename to src/main/resources/randomwalk/module.xsd
diff --git a/core/src/main/resources/randomwalk/modules/All.xml b/src/main/resources/randomwalk/modules/All.xml
similarity index 100%
rename from core/src/main/resources/randomwalk/modules/All.xml
rename to src/main/resources/randomwalk/modules/All.xml
diff --git a/core/src/main/resources/randomwalk/modules/Bulk.xml b/src/main/resources/randomwalk/modules/Bulk.xml
similarity index 95%
rename from core/src/main/resources/randomwalk/modules/Bulk.xml
rename to src/main/resources/randomwalk/modules/Bulk.xml
index 9ffa76a..26004b1 100644
--- a/core/src/main/resources/randomwalk/modules/Bulk.xml
+++ b/src/main/resources/randomwalk/modules/Bulk.xml
@@ -17,7 +17,7 @@
 -->
 <module>
 
-<package prefix="bulk" value="org.apache.accumulo.testing.core.randomwalk.bulk"/>
+<package prefix="bulk" value="org.apache.accumulo.testing.randomwalk.bulk"/>
 
 <init id="bulk.Setup"/>
 
diff --git a/core/src/main/resources/randomwalk/modules/Concurrent.xml b/src/main/resources/randomwalk/modules/Concurrent.xml
similarity index 97%
rename from core/src/main/resources/randomwalk/modules/Concurrent.xml
rename to src/main/resources/randomwalk/modules/Concurrent.xml
index 256df30..4c58b42 100644
--- a/core/src/main/resources/randomwalk/modules/Concurrent.xml
+++ b/src/main/resources/randomwalk/modules/Concurrent.xml
@@ -17,7 +17,7 @@
 -->
 <module>
 
-<package prefix="ct" value="org.apache.accumulo.testing.core.randomwalk.concurrent"/>
+<package prefix="ct" value="org.apache.accumulo.testing.randomwalk.concurrent"/>
 
 <fixture id="ct.ConcurrentFixture"/>
 
diff --git a/core/src/main/resources/randomwalk/modules/Conditional.xml b/src/main/resources/randomwalk/modules/Conditional.xml
similarity index 95%
rename from core/src/main/resources/randomwalk/modules/Conditional.xml
rename to src/main/resources/randomwalk/modules/Conditional.xml
index 3c380dc..e0744bf 100644
--- a/core/src/main/resources/randomwalk/modules/Conditional.xml
+++ b/src/main/resources/randomwalk/modules/Conditional.xml
@@ -17,7 +17,7 @@
 -->
 <module>
 
-<package prefix="ct" value="org.apache.accumulo.testing.core.randomwalk.conditional"/>
+<package prefix="ct" value="org.apache.accumulo.testing.randomwalk.conditional"/>
 
 <init id="ct.Setup"/>
 
diff --git a/core/src/main/resources/randomwalk/modules/Image.xml b/src/main/resources/randomwalk/modules/Image.xml
similarity index 96%
rename from core/src/main/resources/randomwalk/modules/Image.xml
rename to src/main/resources/randomwalk/modules/Image.xml
index 0b41d14..b0e5ce0 100644
--- a/core/src/main/resources/randomwalk/modules/Image.xml
+++ b/src/main/resources/randomwalk/modules/Image.xml
@@ -17,7 +17,7 @@
 -->
 <module>
 
-<package prefix="image" value="org.apache.accumulo.testing.core.randomwalk.image"/>
+<package prefix="image" value="org.apache.accumulo.testing.randomwalk.image"/>
 
 <fixture id="image.ImageFixture"/>
 
diff --git a/core/src/main/resources/randomwalk/modules/LongClean.xml b/src/main/resources/randomwalk/modules/LongClean.xml
similarity index 100%
rename from core/src/main/resources/randomwalk/modules/LongClean.xml
rename to src/main/resources/randomwalk/modules/LongClean.xml
diff --git a/core/src/main/resources/randomwalk/modules/LongDirty.xml b/src/main/resources/randomwalk/modules/LongDirty.xml
similarity index 100%
rename from core/src/main/resources/randomwalk/modules/LongDirty.xml
rename to src/main/resources/randomwalk/modules/LongDirty.xml
diff --git a/core/src/main/resources/randomwalk/modules/LongEach.xml b/src/main/resources/randomwalk/modules/LongEach.xml
similarity index 100%
rename from core/src/main/resources/randomwalk/modules/LongEach.xml
rename to src/main/resources/randomwalk/modules/LongEach.xml
diff --git a/core/src/main/resources/randomwalk/modules/MultiTable.xml b/src/main/resources/randomwalk/modules/MultiTable.xml
similarity index 95%
rename from core/src/main/resources/randomwalk/modules/MultiTable.xml
rename to src/main/resources/randomwalk/modules/MultiTable.xml
index fa42c3f..a28d75e 100644
--- a/core/src/main/resources/randomwalk/modules/MultiTable.xml
+++ b/src/main/resources/randomwalk/modules/MultiTable.xml
@@ -17,7 +17,7 @@
 -->
 <module>
 
-<package prefix="mt" value="org.apache.accumulo.testing.core.randomwalk.multitable"/>
+<package prefix="mt" value="org.apache.accumulo.testing.randomwalk.multitable"/>
 
 <fixture id="mt.MultiTableFixture"/>
 
diff --git a/core/src/main/resources/randomwalk/modules/Replication.xml b/src/main/resources/randomwalk/modules/Replication.xml
similarity index 100%
rename from core/src/main/resources/randomwalk/modules/Replication.xml
rename to src/main/resources/randomwalk/modules/Replication.xml
diff --git a/core/src/main/resources/randomwalk/modules/Security.xml b/src/main/resources/randomwalk/modules/Security.xml
similarity index 99%
rename from core/src/main/resources/randomwalk/modules/Security.xml
rename to src/main/resources/randomwalk/modules/Security.xml
index 422b63e..19f99de 100644
--- a/core/src/main/resources/randomwalk/modules/Security.xml
+++ b/src/main/resources/randomwalk/modules/Security.xml
@@ -12,7 +12,7 @@
 <module>
 
   <package prefix="security"
-    value="org.apache.accumulo.testing.core.randomwalk.security" />
+    value="org.apache.accumulo.testing.randomwalk.security" />
 
   <fixture id="security.SecurityFixture" />
 
diff --git a/core/src/main/resources/randomwalk/modules/Sequential.xml b/src/main/resources/randomwalk/modules/Sequential.xml
similarity index 94%
rename from core/src/main/resources/randomwalk/modules/Sequential.xml
rename to src/main/resources/randomwalk/modules/Sequential.xml
index ce4abd0..fb97bc5 100644
--- a/core/src/main/resources/randomwalk/modules/Sequential.xml
+++ b/src/main/resources/randomwalk/modules/Sequential.xml
@@ -17,7 +17,7 @@
 -->
 <module>
 
-<package prefix="seq" value="org.apache.accumulo.testing.core.randomwalk.sequential"/>
+<package prefix="seq" value="org.apache.accumulo.testing.randomwalk.sequential"/>
 
 <fixture id="seq.SequentialFixture"/>
 
diff --git a/core/src/main/resources/randomwalk/modules/Shard.xml b/src/main/resources/randomwalk/modules/Shard.xml
similarity index 97%
rename from core/src/main/resources/randomwalk/modules/Shard.xml
rename to src/main/resources/randomwalk/modules/Shard.xml
index e8e8654..de7614d 100644
--- a/core/src/main/resources/randomwalk/modules/Shard.xml
+++ b/src/main/resources/randomwalk/modules/Shard.xml
@@ -17,7 +17,7 @@
 -->
 <module>
 
-<package prefix="shard" value="org.apache.accumulo.testing.core.randomwalk.shard"/>
+<package prefix="shard" value="org.apache.accumulo.testing.randomwalk.shard"/>
 
 <fixture id="shard.ShardFixture"/>
 
diff --git a/core/src/main/resources/randomwalk/modules/ShortClean.xml b/src/main/resources/randomwalk/modules/ShortClean.xml
similarity index 100%
rename from core/src/main/resources/randomwalk/modules/ShortClean.xml
rename to src/main/resources/randomwalk/modules/ShortClean.xml
diff --git a/core/src/main/resources/randomwalk/modules/ShortDirty.xml b/src/main/resources/randomwalk/modules/ShortDirty.xml
similarity index 100%
rename from core/src/main/resources/randomwalk/modules/ShortDirty.xml
rename to src/main/resources/randomwalk/modules/ShortDirty.xml
diff --git a/core/src/main/resources/randomwalk/modules/ShortEach.xml b/src/main/resources/randomwalk/modules/ShortEach.xml
similarity index 100%
rename from core/src/main/resources/randomwalk/modules/ShortEach.xml
rename to src/main/resources/randomwalk/modules/ShortEach.xml
diff --git a/core/src/main/resources/randomwalk/modules/unit/Basic.xml b/src/main/resources/randomwalk/modules/unit/Basic.xml
similarity index 93%
rename from core/src/main/resources/randomwalk/modules/unit/Basic.xml
rename to src/main/resources/randomwalk/modules/unit/Basic.xml
index f81f132..5082b2c 100644
--- a/core/src/main/resources/randomwalk/modules/unit/Basic.xml
+++ b/src/main/resources/randomwalk/modules/unit/Basic.xml
@@ -17,7 +17,7 @@
 -->
 <module>
 
-<package prefix="test" value="org.apache.accumulo.testing.core.randomwalk.unit"/>
+<package prefix="test" value="org.apache.accumulo.testing.randomwalk.unit"/>
 
 <init id="test.CreateTable"/>
 
diff --git a/core/src/main/resources/randomwalk/modules/unit/Simple.xml b/src/main/resources/randomwalk/modules/unit/Simple.xml
similarity index 93%
rename from core/src/main/resources/randomwalk/modules/unit/Simple.xml
rename to src/main/resources/randomwalk/modules/unit/Simple.xml
index 6eb685a..4132164 100644
--- a/core/src/main/resources/randomwalk/modules/unit/Simple.xml
+++ b/src/main/resources/randomwalk/modules/unit/Simple.xml
@@ -17,7 +17,7 @@
 -->
 <module>
 
-<package prefix="test" value="org.apache.accumulo.testing.core.randomwalk.unit"/>
+<package prefix="test" value="org.apache.accumulo.testing.randomwalk.unit"/>
 
 <init id="dummy.all"/>
 
diff --git a/core/src/test/java/org/apache/accumulo/testing/core/randomwalk/FrameworkTest.java b/src/test/java/org/apache/accumulo/testing/randomwalk/FrameworkTest.java
similarity index 89%
rename from core/src/test/java/org/apache/accumulo/testing/core/randomwalk/FrameworkTest.java
rename to src/test/java/org/apache/accumulo/testing/randomwalk/FrameworkTest.java
index ae2428a..a16ac4b 100644
--- a/core/src/test/java/org/apache/accumulo/testing/core/randomwalk/FrameworkTest.java
+++ b/src/test/java/org/apache/accumulo/testing/randomwalk/FrameworkTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk;
+package org.apache.accumulo.testing.randomwalk;
 
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNotEquals;
@@ -30,14 +30,14 @@ import javax.xml.parsers.ParserConfigurationException;
 import javax.xml.validation.Schema;
 import javax.xml.validation.SchemaFactory;
 
-import org.apache.accumulo.testing.core.randomwalk.unit.CreateTable;
+import org.apache.accumulo.testing.randomwalk.unit.CreateTable;
 import org.w3c.dom.Document;
 import org.xml.sax.SAXException;
 
 public class FrameworkTest {
 
   // Need to use fully qualified name here because of conflict with
-  // org.apache.accumulo.testing.core.randomwalk.Test
+  // org.apache.accumulo.testing.randomwalk.Test
   @org.junit.Test
   public void testXML() throws SAXException, URISyntaxException, ParserConfigurationException, IOException {
     SchemaFactory sf = SchemaFactory.newInstance(XMLConstants.W3C_XML_SCHEMA_NS_URI);
@@ -59,7 +59,7 @@ public class FrameworkTest {
   @org.junit.Test
   public void testRWTest() {
     Test t1 = new CreateTable();
-    assertEquals("org.apache.accumulo.testing.core.randomwalk.unit.CreateTable", t1.toString());
+    assertEquals("org.apache.accumulo.testing.randomwalk.unit.CreateTable", t1.toString());
 
     Test t2 = new CreateTable();
     assertEquals("CreateTable test nodes were not equal.", t1, t2);
diff --git a/core/src/test/java/org/apache/accumulo/testing/core/randomwalk/ReplicationRandomWalkIT.java b/src/test/java/org/apache/accumulo/testing/randomwalk/ReplicationRandomWalkIT.java
similarity index 93%
rename from core/src/test/java/org/apache/accumulo/testing/core/randomwalk/ReplicationRandomWalkIT.java
rename to src/test/java/org/apache/accumulo/testing/randomwalk/ReplicationRandomWalkIT.java
index d5659a2..2d61f6d 100644
--- a/core/src/test/java/org/apache/accumulo/testing/core/randomwalk/ReplicationRandomWalkIT.java
+++ b/src/test/java/org/apache/accumulo/testing/randomwalk/ReplicationRandomWalkIT.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.accumulo.testing.core.randomwalk;
+package org.apache.accumulo.testing.randomwalk;
 
 import static org.apache.accumulo.core.conf.Property.TSERV_NATIVEMAP_ENABLED;
 import static org.apache.accumulo.core.conf.Property.TSERV_WALOG_MAX_SIZE;
 
 import org.apache.accumulo.miniclusterImpl.MiniAccumuloConfigImpl;
 import org.apache.accumulo.test.functional.ConfigurableMacBase;
-import org.apache.accumulo.testing.core.randomwalk.concurrent.Replication;
+import org.apache.accumulo.testing.randomwalk.concurrent.Replication;
 import org.apache.hadoop.conf.Configuration;
 import org.easymock.EasyMock;
 import org.junit.Test;
diff --git a/core/src/test/resources/log4j.properties b/src/test/resources/log4j.properties
similarity index 100%
rename from core/src/test/resources/log4j.properties
rename to src/test/resources/log4j.properties
diff --git a/yarn/.gitignore b/yarn/.gitignore
deleted file mode 100644
index 7e54b72..0000000
--- a/yarn/.gitignore
+++ /dev/null
@@ -1,7 +0,0 @@
-/.classpath
-/.project
-/.settings/
-/target/
-/*.iml
-/.idea
-/logs/
diff --git a/yarn/pom.xml b/yarn/pom.xml
deleted file mode 100644
index 650c3b9..0000000
--- a/yarn/pom.xml
+++ /dev/null
@@ -1,110 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-  Licensed to the Apache Software Foundation (ASF) under one or more
-  contributor license agreements.  See the NOTICE file distributed with
-  this work for additional information regarding copyright ownership.
-  The ASF licenses this file to You under the Apache License, Version 2.0
-  (the "License"); you may not use this file except in compliance with
-  the License.  You may obtain a copy of the License at
-
-      http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  See the License for the specific language governing permissions and
-  limitations under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-  <modelVersion>4.0.0</modelVersion>
-
-  <parent>
-    <groupId>org.apache.accumulo</groupId>
-    <artifactId>accumulo-testing</artifactId>
-    <version>2.0.0-SNAPSHOT</version>
-  </parent>
-
-  <artifactId>accumulo-testing-yarn</artifactId>
-  <packaging>jar</packaging>
-
-  <name>Apache Accumulo Testing YARN</name>
-
-  <dependencies>
-    <dependency>
-      <groupId>com.beust</groupId>
-      <artifactId>jcommander</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>com.google.guava</groupId>
-      <artifactId>guava</artifactId>
-      <!-- Twill requires version 13.0.1 -->
-      <version>13.0.1</version>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-testing-core</artifactId>
-      <exclusions>
-        <exclusion>
-          <groupId>log4j</groupId>
-          <artifactId>log4j</artifactId>
-        </exclusion>
-        <exclusion>
-          <groupId>org.slf4j</groupId>
-          <artifactId>slf4j-log4j12</artifactId>
-        </exclusion>
-      </exclusions>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-yarn-api</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.twill</groupId>
-      <artifactId>twill-api</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.twill</groupId>
-      <artifactId>twill-ext</artifactId>
-      <exclusions>
-        <exclusion>
-          <groupId>log4j</groupId>
-          <artifactId>log4j</artifactId>
-        </exclusion>
-      </exclusions>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.twill</groupId>
-      <artifactId>twill-yarn</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.slf4j</groupId>
-      <artifactId>slf4j-api</artifactId>
-    </dependency>
-  </dependencies>
-
-  <profiles>
-    <profile>
-      <id>yarn-test-runner</id>
-      <build>
-        <plugins>
-          <plugin>
-            <groupId>org.codehaus.mojo</groupId>
-            <artifactId>exec-maven-plugin</artifactId>
-            <executions>
-              <execution>
-                <goals>
-                  <goal>java</goal>
-                </goals>
-                <phase>compile</phase>
-                <configuration>
-                  <mainClass>org.apache.accumulo.testing.yarn.YarnAccumuloTestRunner</mainClass>
-                </configuration>
-              </execution>
-            </executions>
-          </plugin>
-        </plugins>
-      </build>
-    </profile>
-  </profiles>
-
-</project>
diff --git a/yarn/src/main/java/org/apache/accumulo/testing/yarn/YarnAccumuloTestRunner.java b/yarn/src/main/java/org/apache/accumulo/testing/yarn/YarnAccumuloTestRunner.java
deleted file mode 100644
index 5ac22dc..0000000
--- a/yarn/src/main/java/org/apache/accumulo/testing/yarn/YarnAccumuloTestRunner.java
+++ /dev/null
@@ -1,153 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.accumulo.testing.yarn;
-
-import com.beust.jcommander.JCommander;
-import com.beust.jcommander.Parameter;
-import com.google.common.base.Preconditions;
-import org.apache.accumulo.testing.core.TestEnv;
-import org.apache.accumulo.testing.core.TestProps;
-import org.apache.hadoop.yarn.conf.YarnConfiguration;
-import org.apache.twill.api.ResourceSpecification;
-import org.apache.twill.api.TwillApplication;
-import org.apache.twill.api.TwillRunnerService;
-import org.apache.twill.api.TwillSpecification;
-import org.apache.twill.ext.BundledJarRunnable;
-import org.apache.twill.ext.BundledJarRunner;
-import org.apache.twill.yarn.YarnTwillRunnerService;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import java.io.File;
-import java.nio.file.Paths;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Objects;
-import java.util.Properties;
-
-public class YarnAccumuloTestRunner {
-
-  private static final Logger LOG = LoggerFactory.getLogger(YarnAccumuloTestRunner.class);
-
-  private static final String RUNNABLE_ID = "AccumuloTest";
-
-  private static class YarnTestApp implements TwillApplication {
-
-    private TestRunnerOpts opts;
-    private Properties props;
-
-    YarnTestApp(TestRunnerOpts opts, Properties props) {
-      this.opts = opts;
-      this.props = props;
-    }
-
-    @Override
-    public TwillSpecification configure() {
-
-      int numCores = Integer.valueOf(props.getProperty(TestProps.YARN_CONTAINER_CORES));
-      int memory = Integer.valueOf(props.getProperty(TestProps.YARN_CONTAINER_MEMORY_MB));
-
-      ResourceSpecification resourceSpec = ResourceSpecification.Builder.with().setVirtualCores(numCores)
-          .setMemory(memory, ResourceSpecification.SizeUnit.MEGA).setInstances(opts.numContainers).build();
-
-      File jarFile = new File(opts.jarPath);
-      File clientProps = new File(opts.clientProps);
-      File testProps = new File(opts.testProps);
-      File log4jProps = new File(opts.logProps);
-
-      return TwillSpecification.Builder.with().setName(opts.testName).withRunnable().add(RUNNABLE_ID, new BundledJarRunnable(), resourceSpec).withLocalFiles()
-          .add(jarFile.getName(), jarFile.toURI(), false).add(testProps.getName(), testProps.toURI()).add(clientProps.getName(), clientProps.toURI())
-          .add(log4jProps.getName(), log4jProps.toURI()).apply().anyOrder().build();
-    }
-  }
-
-  private static class TestRunnerOpts {
-
-    @Parameter(names = {"--testName", "-t"}, required = true, description = "Test name")
-    String testName;
-
-    @Parameter(names = {"--numContainers", "-n"}, required = true, description = "Test name")
-    int numContainers;
-
-    @Parameter(names = {"--jar", "-j"}, required = true, description = "Bundled jar path")
-    String jarPath;
-
-    @Parameter(names = {"--main", "-m"}, required = true, description = "Main class")
-    String mainClass;
-
-    @Parameter(names = {"--clientProps", "-c"}, required = true, description = "Accumulo client properties path")
-    String clientProps;
-
-    @Parameter(names = {"--testProps", "-p"}, required = true, description = "Test properties path")
-    String testProps;
-
-    @Parameter(names = {"--logProps", "-l"}, required = true, description = "Log properties path")
-    String logProps;
-
-    @Parameter(names = {"--args", "-a"}, variableArity = true, description = "Main class args")
-    List<String> mainArgs = new ArrayList<>();
-  }
-
-  private static void verifyPath(String path) {
-    File f = new File(path);
-    Preconditions.checkState(f.exists());
-    Preconditions.checkState(f.canRead());
-  }
-
-  public static void main(String[] args) throws Exception {
-
-    TestRunnerOpts opts = new TestRunnerOpts();
-    JCommander commander = new JCommander();
-    commander.addObject(opts);
-    commander.parse(args);
-
-    verifyPath(opts.jarPath);
-    verifyPath(opts.testProps);
-    verifyPath(opts.clientProps);
-    verifyPath(opts.logProps);
-
-    String jarFileName = Paths.get(opts.jarPath).getFileName().toString();
-    String[] mainArgs = opts.mainArgs.stream().toArray(String[]::new);
-
-    Objects.requireNonNull(jarFileName);
-    Objects.requireNonNull(opts.mainClass);
-    Objects.requireNonNull(mainArgs);
-
-    BundledJarRunner.Arguments arguments =
-        new BundledJarRunner.Arguments.Builder().setJarFileName(jarFileName)
-            .setLibFolder("lib").setMainClassName(opts.mainClass)
-            .setMainArgs(mainArgs).createArguments();
-
-    TestEnv env = new TestEnv(opts.testProps, opts.clientProps);
-
-    YarnConfiguration yarnConfig = new YarnConfiguration(env.getHadoopConfiguration());
-    TwillRunnerService twillRunner = new YarnTwillRunnerService(yarnConfig, env.getInfo().getZooKeepers());
-    twillRunner.start();
-
-    twillRunner.prepare(new YarnTestApp(opts, env.getTestProperties()))
-        .addJVMOptions("-Dlog4j.configuration=file:$PWD/" + new File(opts.logProps).getName())
-        .withArguments(RUNNABLE_ID, arguments.toArray()).start();
-
-    LOG.info("{} containers will start in YARN.", opts.numContainers);
-    LOG.info("Press Ctrl-C when these containers have started.");
-
-    while (true) {
-      Thread.sleep(1000);
-    }
-  }
-}
diff --git a/yarn/src/main/resources/logback.xml b/yarn/src/main/resources/logback.xml
deleted file mode 100644
index 7a8e3b8..0000000
--- a/yarn/src/main/resources/logback.xml
+++ /dev/null
@@ -1,31 +0,0 @@
-<!--
-  Licensed to the Apache Software Foundation (ASF) under one or more contributor license
-  agreements. See the NOTICE file distributed with this work for additional information regarding
-  copyright ownership. The ASF licenses this file to you under the Apache License, Version 2.0 (the
-  "License"); you may not use this file except in compliance with the License. You may obtain a
-  copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software distributed under the License
-  is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
-  or implied. See the License for the specific language governing permissions and limitations under
-  the License.
--->
-<configuration>
-
-  <appender name="STDOUT" class="ch.qos.logback.core.ConsoleAppender">
-    <!-- encoders are assigned the type
-         ch.qos.logback.classic.encoder.PatternLayoutEncoder by default -->
-    <encoder>
-      <pattern>%d{HH:mm:ss.SSS} [%thread] %-5level %logger{36} - %msg%n</pattern>
-    </encoder>
-  </appender>
-  
-  <logger name="org.apache.twill" level="warn"/>
-  <logger name="org.apache.twill.yarn.YarnTwillRunnerService" level="info"/>
-
-  <root level="info">
-    <appender-ref ref="STDOUT" />
-  </root>
-</configuration>