You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@slider.apache.org by st...@apache.org on 2014/11/26 19:36:44 UTC

[6/8] incubator-slider git commit: SLIDER-656 purge providers/hbase and providers/accumulo : files and modules

SLIDER-656 purge providers/hbase and providers/accumulo : files and modules


Project: http://git-wip-us.apache.org/repos/asf/incubator-slider/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-slider/commit/5d405543
Tree: http://git-wip-us.apache.org/repos/asf/incubator-slider/tree/5d405543
Diff: http://git-wip-us.apache.org/repos/asf/incubator-slider/diff/5d405543

Branch: refs/heads/develop
Commit: 5d405543b7eabd19a6692e71a9932dd370d43018
Parents: 6ef541c
Author: Steve Loughran <st...@apache.org>
Authored: Wed Nov 26 18:24:30 2014 +0000
Committer: Steve Loughran <st...@apache.org>
Committed: Wed Nov 26 18:24:30 2014 +0000

----------------------------------------------------------------------
 pom.xml                                         |   4 -
 .../accumulo/accumulo-funtests/pom.xml          | 240 ----------
 .../funtest/AccumuloBuildSetupIT.groovy         |  37 --
 .../accumulo/funtest/AccumuloCIIT.groovy        | 111 -----
 .../funtest/AccumuloCommandTestBase.groovy      | 255 -----------
 .../funtest/FunctionalAccumuloClusterIT.groovy  | 145 ------
 .../FunctionalAccumuloM1T1GC1Mon1IT.groovy      |  57 ---
 .../StubToForceGroovyTestsToCompile.java        |  22 -
 .../src/test/resources/log4j.properties         |  59 ---
 .../accumulo/slider-accumulo-provider/pom.xml   | 228 ----------
 .../accumulo/AccumuloClientProvider.java        | 351 ---------------
 .../accumulo/AccumuloConfigFileOptions.java     |  72 ---
 .../slider/providers/accumulo/AccumuloKeys.java | 120 -----
 .../accumulo/AccumuloProviderFactory.java       |  44 --
 .../accumulo/AccumuloProviderService.java       | 440 -------------------
 .../providers/accumulo/AccumuloRoles.java       |  96 ----
 .../providers/accumulo/conf/accumulo-env.sh     |  56 ---
 .../accumulo/conf/accumulo-metrics.xml          |  60 ---
 .../providers/accumulo/conf/accumulo-site.xml   | 125 ------
 .../accumulo/conf/accumulo.policy.example       | 143 ------
 .../slider/providers/accumulo/conf/auditLog.xml |  41 --
 .../apache/slider/providers/accumulo/conf/gc    |  16 -
 .../providers/accumulo/conf/generic_logger.xml  |  83 ----
 .../providers/accumulo/conf/log4j.properties    |  41 --
 .../slider/providers/accumulo/conf/masters      |  16 -
 .../slider/providers/accumulo/conf/monitor      |  16 -
 .../providers/accumulo/conf/monitor_logger.xml  |  64 ---
 .../slider/providers/accumulo/conf/slaves       |  16 -
 .../slider/providers/accumulo/conf/tracers      |  16 -
 .../providers/accumulo/instance/appconf.json    |  37 --
 .../providers/accumulo/instance/resources.json  |  30 --
 .../providers/accumulo/role-accumulo-gc.xml     |  55 ---
 .../providers/accumulo/role-accumulo-master.xml |  55 ---
 .../accumulo/role-accumulo-monitor.xml          |  52 ---
 .../providers/accumulo/role-accumulo-other.xml  |  51 ---
 .../providers/accumulo/role-accumulo-tablet.xml |  55 ---
 .../providers/accumulo/role-accumulo-tracer.xml |  51 ---
 .../providers/accumulo/AccumuloTestBase.groovy  | 247 -----------
 .../live/TestAccCorrectInstanceName.groovy      |  83 ----
 .../live/TestAccFlexTablets133Mgr113.groovy     |  59 ---
 .../accumulo/live/TestAccFlexTablets1to3.groovy |  57 ---
 .../accumulo/live/TestAccFreezeThaw.groovy      | 113 -----
 .../accumulo/live/TestAccLiveHDFSArchive.groovy |  85 ----
 .../live/TestAccLiveLocalArchive.groovy         |  87 ----
 .../accumulo/live/TestAccM1T1GC1Mon1.groovy     |  79 ----
 .../accumulo/live/TestAccM2T2GC1Mon1.groovy     |  85 ----
 .../accumulo/live/TestAccumuloAMWebApp.groovy   | 110 -----
 .../live/TestInvalidMonitorAddress.groovy       |  67 ---
 .../apache/slider/providers/accumulo/Stub.java  |  22 -
 .../src/test/resources/log4j.properties         |  59 ---
 slider-providers/hbase/hbase-funtests/pom.xml   | 253 -----------
 .../hbase/funtest/DemoHBaseCluster.groovy       |  45 --
 .../funtest/FunctionalHBaseClusterIT.groovy     | 221 ----------
 .../hbase/funtest/HBaseBuildSetupIT.groovy      |  36 --
 .../funtest/HBaseClusterBuildDestroyIT.groovy   |  89 ----
 .../funtest/HBaseClusterLifecycleIT.groovy      | 194 --------
 .../hbase/funtest/HBaseCommandTestBase.groovy   | 127 ------
 .../hbase/funtest/HBaseIntegrationIT.groovy     |  72 ---
 .../providers/hbase/funtest/HBaseLoadIT.groovy  |  71 ---
 .../hbase/funtest/HBaseNodeFailureIT.groovy     | 135 ------
 .../providers/hbase/funtest/ImagesIT.groovy     |  64 ---
 .../providers/hbase/funtest/StubCompile.java    |  22 -
 .../src/test/resources/log4j.properties         |  59 ---
 .../hbase/slider-hbase-provider/pom.xml         | 256 -----------
 .../providers/hbase/HBaseClientProvider.java    | 337 --------------
 .../providers/hbase/HBaseConfigFileOptions.java |  86 ----
 .../slider/providers/hbase/HBaseKeys.java       |  95 ----
 .../providers/hbase/HBaseProviderFactory.java   |  44 --
 .../providers/hbase/HBaseProviderService.java   | 368 ----------------
 .../slider/providers/hbase/HBaseRoles.java      |  60 ---
 .../hbase/conf/hadoop-metrics.properties        |  85 ----
 .../slider/providers/hbase/conf/hbase-env.sh    | 100 -----
 .../providers/hbase/conf/hbase-policy.xml       |  53 ---
 .../slider/providers/hbase/conf/hbase-site.xml  |  51 ---
 .../providers/hbase/conf/log4j.properties       |  91 ----
 .../slider/providers/hbase/conf/regionservers   |   0
 .../providers/hbase/instance/appconf.json       |  29 --
 .../providers/hbase/instance/resources.json     |  24 -
 .../providers/hbase/role-hbase-master.xml       |  59 ---
 .../providers/hbase/role-hbase-worker.xml       |  60 ---
 .../providers/hbase/HBaseTestUtils.groovy       | 266 -----------
 .../minicluster/HBaseMiniClusterTestBase.groovy | 415 -----------------
 .../TestFreezeThawClusterFromArchive.groovy     |  72 ---
 .../archives/TestLiveClusterFromArchive.groovy  |  76 ----
 .../TestLiveClusterFromArchiveOnHDFS.groovy     |  45 --
 .../build/TestBuildThawClusterM1W1.groovy       |  70 ---
 .../failures/TestFailedRegionService.groovy     | 113 -----
 .../failures/TestKilledHBaseAM.groovy           | 141 ------
 .../failures/TestKilledHBaseMaster.groovy       |  82 ----
 .../TestRegionServerFailureThreshold.groovy     | 185 --------
 .../flexing/TestClusterFlex0To1.groovy          |  36 --
 .../flexing/TestClusterFlex1To1.groovy          |  45 --
 .../flexing/TestClusterFlex1To2.groovy          |  45 --
 .../flexing/TestClusterFlex2DownTo1.groovy      |  45 --
 .../flexing/TestClusterFlex2To5.groovy          |  45 --
 .../flexing/TestClusterFlexDownMultiple.groovy  |  58 ---
 .../flexing/TestClusterFlexDownToZero.groovy    |  44 --
 .../TestClusterFlexHMasterFlex1To2.groovy       |  45 --
 ...reezeReconfigureThawLiveRegionService.groovy | 125 ------
 .../TestFreezeThawLiveRegionService.groovy      | 101 -----
 .../minicluster/live/Test2Master2RS.groovy      |  90 ----
 .../minicluster/live/TestHBaseMaster.groovy     | 112 -----
 .../live/TestHBaseMasterOnHDFS.groovy           |  60 ---
 .../live/TestHBaseMasterWithBadHeap.groovy      |  76 ----
 .../live/TestLiveRegionServiceOnHDFS.groovy     |  65 ---
 .../live/TestLiveTwoNodeRegionService.groovy    |  81 ----
 .../minicluster/live/TestTwoLiveClusters.groovy | 132 ------
 .../masterless/TestRoleOptPropagation.groovy    |  96 ----
 .../TestSliderConfDirToMasterlessAM.groovy      |  88 ----
 .../slider/providers/hbase/StubCompile.java     |  22 -
 .../src/test/resources/log4j.properties         |  61 ---
 111 files changed, 10636 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index f464c57..991cf1a 100644
--- a/pom.xml
+++ b/pom.xml
@@ -40,10 +40,6 @@
     <module>slider-agent</module>
     <module>slider-assembly</module>
     <module>slider-funtest</module>
-    <module>slider-providers/hbase/slider-hbase-provider</module>
-    <module>slider-providers/hbase/hbase-funtests</module>
-    <module>slider-providers/accumulo/slider-accumulo-provider</module>
-    <module>slider-providers/accumulo/accumulo-funtests</module>
   </modules>
 
   <licenses>

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/accumulo-funtests/pom.xml
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/accumulo-funtests/pom.xml b/slider-providers/accumulo/accumulo-funtests/pom.xml
deleted file mode 100644
index ae88a53..0000000
--- a/slider-providers/accumulo/accumulo-funtests/pom.xml
+++ /dev/null
@@ -1,240 +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.
--->
-
-<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>
-  <artifactId>accumulo-funtests</artifactId>
-  <name>Slider Accumulo Provider Functional Tests</name>
-  <packaging>jar</packaging>
-  <description>
-    Functional tests for the accumulo provider
-    
-  </description>
-  <parent>
-    <groupId>org.apache.slider</groupId>
-    <artifactId>slider</artifactId>
-    <version>0.61-incubating</version>
-    <relativePath>../../../</relativePath>
-  </parent>
-
-  <build>
-
-    <plugins>
-
-      <!--read in a build.properties file if defined-->
-      <plugin>
-        <groupId>org.codehaus.mojo</groupId>
-        <artifactId>properties-maven-plugin</artifactId>
-        <version>${maven.properties.version}</version>
-        <executions>
-          <execution>
-            <phase>initialize</phase>
-            <goals>
-              <goal>read-project-properties</goal>
-            </goals>
-            <configuration>
-              <quiet>true</quiet>
-              <files>
-                <file>build.properties</file>
-                <file>../../../build.properties</file>
-              </files>
-            </configuration>
-          </execution>
-        </executions>
-      </plugin>
-      
-      <plugin>
-        <artifactId>maven-compiler-plugin</artifactId>
-        <dependencies>
-          <dependency>
-            <groupId>org.codehaus.groovy</groupId>
-            <artifactId>groovy-eclipse-compiler</artifactId>
-            <version>${groovy-eclipse-compiler.version}</version>
-          </dependency>
-          <dependency>
-            <groupId>org.codehaus.groovy</groupId>
-            <artifactId>groovy-eclipse-batch</artifactId>
-            <version>${groovy-eclipse-batch.version}</version>
-          </dependency>
-        </dependencies>
-      </plugin>
-
-
-     <!-- functional test -->
-      <plugin>
-        <groupId>org.apache.maven.plugins</groupId>
-        <artifactId>maven-failsafe-plugin</artifactId>
-        <version>${maven-failsafe-plugin.version}</version>
-        <executions>
-          <execution>
-            <id>run-integration-tests</id>
-            <goals>
-              <goal>integration-test</goal>
-              <goal>verify</goal>
-            </goals>
-          </execution>
-        </executions>
-        <configuration>
-          <!--mvn process fork options-->
-          <reuseForks>${test.reuseForks}</reuseForks>
-          <forkMode>${test.forkMode}</forkMode>
-          <forkCount>1</forkCount>
-          <forkedProcessTimeoutInSeconds>${test.forkedProcessTimeoutInSeconds}
-          </forkedProcessTimeoutInSeconds>
-          <threadCount>1</threadCount>
-          <argLine>${test.argLine}</argLine>
-          <failIfNoTests>${test.funtests.failIfNoTests}</failIfNoTests>
-
-          <trimStackTrace>false</trimStackTrace>
-          <redirectTestOutputToFile>${build.redirect.test.output.to.file}</redirectTestOutputToFile>
-          <systemPropertyVariables>
-            <java.net.preferIPv4Stack>true</java.net.preferIPv4Stack>
-            <java.awt.headless>true</java.awt.headless>
-            <java.security.krb5.realm>${slider.test.java.security.krb5.realm}</java.security.krb5.realm>
-            <java.security.krb5.kdc>${slider.test.java.security.krb5.kdc}</java.security.krb5.kdc>
-            <!-- this property must be supplied-->
-            <slider.conf.dir>${slider.conf.dir}</slider.conf.dir>
-            <slider.bin.dir>../../../slider-assembly/target/slider-${project.version}-all/slider-${project.version}</slider.bin.dir>
-          </systemPropertyVariables>
-        </configuration>
-      </plugin>
- 
-    </plugins>
-  </build>
-
-  <reporting>
-    <plugins>
- 
-    </plugins>
-  </reporting>
-
-  <dependencies>
-
-    <dependency>
-      <groupId>org.apache.slider</groupId>
-      <artifactId>slider-accumulo-provider</artifactId>
-      <version>${project.version}</version>
-    </dependency>
-
-<!--
-    <dependency>
-      <groupId>org.apache.slider</groupId>
-      <artifactId>slider-accumulo-provider</artifactId>
-      <version>${project.version}</version>
-      <type>test-jar</type>
-      <scope>test</scope>
-    </dependency>
--->
-
-    <dependency>
-      <groupId>org.apache.slider</groupId>
-      <artifactId>slider-core</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>org.slf4j</groupId>
-      <artifactId>slf4j-api</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.slider</groupId>
-      <artifactId>slider-core</artifactId>
-      <version>${project.version}</version>
-      <type>test-jar</type>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.codehaus.groovy</groupId>
-      <artifactId>groovy-all</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.slider</groupId>
-      <artifactId>slider-assembly</artifactId>
-      <version>${project.version}</version>
-      <classifier>all</classifier>
-      <type>tar.gz</type>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.slider</groupId>
-      <artifactId>slider-funtest</artifactId>
-      <version>${project.version}</version>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>junit</groupId>
-      <artifactId>junit</artifactId>
-      <scope>test</scope>
-    </dependency>
-    
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-client</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-minicluster</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-core</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-minicluster</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-trace</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-fate</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-test</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.thrift</groupId>
-      <artifactId>libthrift</artifactId>
-      <version>0.9.0</version>
-      <scope>test</scope>
-    </dependency>
-    
-  </dependencies>
-
-
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloBuildSetupIT.groovy
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloBuildSetupIT.groovy b/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloBuildSetupIT.groovy
deleted file mode 100644
index 109bce9..0000000
--- a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloBuildSetupIT.groovy
+++ /dev/null
@@ -1,37 +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.slider.providers.accumulo.funtest
-
-import org.apache.hadoop.conf.Configuration
-import org.apache.slider.funtest.abstracttests.AbstractTestBuildSetup
-import org.junit.Test
-
-class AccumuloBuildSetupIT extends AbstractTestBuildSetup {
-
-  @Test
-  public void testAccumuloBuildsHavePathsDefined() throws Throwable {
-    Configuration conf = loadSliderConf();
-
-    assumeBoolOption(conf, KEY_TEST_ACCUMULO_ENABLED, true)
-
-    assertStringOptionSet(conf, KEY_TEST_ACCUMULO_APPCONF)
-    assertStringOptionSet(conf, KEY_TEST_ACCUMULO_TAR)
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloCIIT.groovy
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloCIIT.groovy b/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloCIIT.groovy
deleted file mode 100644
index bef5a03..0000000
--- a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloCIIT.groovy
+++ /dev/null
@@ -1,111 +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.slider.providers.accumulo.funtest
-
-import groovy.util.logging.Slf4j
-
-import org.apache.accumulo.core.client.Connector
-import org.apache.accumulo.core.client.ZooKeeperInstance
-import org.apache.accumulo.core.client.security.tokens.PasswordToken
-import org.apache.accumulo.test.continuous.ContinuousIngest
-import org.apache.accumulo.test.continuous.ContinuousVerify
-import org.apache.hadoop.fs.Path
-import org.apache.hadoop.io.Text
-import org.apache.hadoop.registry.client.api.RegistryConstants
-import org.apache.hadoop.util.ToolRunner
-import org.apache.hadoop.yarn.conf.YarnConfiguration
-import org.apache.slider.common.SliderXmlConfKeys
-import org.apache.slider.api.ClusterDescription
-import org.apache.slider.funtest.framework.CommandTestBase
-import org.apache.slider.funtest.framework.FuntestProperties
-import org.apache.slider.funtest.framework.PortAssignments
-
-@Slf4j
-class AccumuloCIIT extends FunctionalAccumuloClusterIT {
-  
-  @Override
-  String getClusterName() {
-    return "test_accumulo_ci"
-  }
-  
-  @Override
-  public int getNumTservers() {
-    return 2;
-  }
-
-  @Override
-  public int getMonitorPort() {
-    return PortAssignments._testAccumuloCI;
-  }
-
-  @Override
-  void clusterLoadOperations(
-      String clustername,
-      Map<String, Integer> roleMap,
-      ClusterDescription cd) {
-    assert clustername
-
-    String currentUser = System.getProperty("user.name");
-    String zookeepers = SLIDER_CONFIG.get(
-        RegistryConstants.KEY_REGISTRY_ZK_QUORUM,
-        FuntestProperties.DEFAULT_SLIDER_ZK_HOSTS)
-    ZooKeeperInstance inst = new ZooKeeperInstance(currentUser + "-" + clustername, zookeepers)
-    Connector conn = inst.getConnector("root", new PasswordToken(getPassword()))
-    
-    // Create the test table with some split points
-    String tableName = "testAccumuloCi";
-    conn.tableOperations().create(tableName)
-    TreeSet<Text> splits = new TreeSet<Text>()
-    splits.add(new Text("2"))
-    splits.add(new Text("5"))
-    splits.add(new Text("7"))
-    conn.tableOperations().addSplits(tableName, splits)
-    
-    // Write 15M records per tserver -- should take a few minutes
-    String[] ciOpts = ["-i", inst.getInstanceName(),
-      "-z", zookeepers, "-u", "root",
-      "-p", getPassword(), "--table", tableName,
-      "--num", Integer.toString(1000 * 1000 * 4 * getNumTservers()),
-      "--batchMemory", "100000000",
-      "--batchLatency", "600000",
-      "--batchThreads", "1"]
-
-    ContinuousIngest ci = new ContinuousIngest();
-    ci.main(ciOpts);
-    
-    // Create a directory for the verify to write its output to
-    Path verifyOutput = new Path("/user/" + currentUser + "/.slider/cluster/" + clustername + "/verify-output")
-    assert !clusterFS.exists(verifyOutput)
-    
-    YarnConfiguration verifyConf = new YarnConfiguration(SLIDER_CONFIG);
-
-        // Try to load the necessary classes for the Mappers to find them
-    if (loadClassesForMapReduce(verifyConf)) {
-      // If we found those classes, try to run in distributed mode.
-      tryToLoadMapredSite(verifyConf)
-    }
-    
-    // Run ContinuousVerify and ensure that no holes exist
-    ContinuousVerify verify = new ContinuousVerify();
-    String[] verifyOpts = ["-i", inst.getInstanceName(),
-      "-z", zookeepers, "-u", "root",
-      "-p", getPassword(), "--table", tableName,
-      "--output", verifyOutput.toString(), "--maxMappers", Integer.toString(2 * getNumTservers()),
-      "--reducers", Integer.toString(getNumTservers())]
-    assert 0 == ToolRunner.run(verifyConf, verify, verifyOpts)
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloCommandTestBase.groovy
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloCommandTestBase.groovy b/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloCommandTestBase.groovy
deleted file mode 100644
index f050793..0000000
--- a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/AccumuloCommandTestBase.groovy
+++ /dev/null
@@ -1,255 +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.slider.providers.accumulo.funtest
-
-import org.apache.hadoop.security.UserGroupInformation
-import org.apache.slider.common.SliderExitCodes
-import org.apache.slider.common.params.SliderActions
-import org.apache.slider.funtest.framework.FileUploader
-import org.apache.slider.providers.accumulo.AccumuloClientProvider
-import org.junit.BeforeClass
-
-import static SliderXMLConfKeysForTesting.KEY_TEST_ACCUMULO_APPCONF
-import static SliderXMLConfKeysForTesting.KEY_TEST_ACCUMULO_TAR
-import static org.apache.slider.api.ResourceKeys.YARN_MEMORY
-import static org.apache.slider.common.SliderXMLConfKeysForTesting.DEFAULT_ACCUMULO_LAUNCH_TIME_SECONDS
-import static org.apache.slider.common.SliderXMLConfKeysForTesting.KEY_ACCUMULO_LAUNCH_TIME
-import static org.apache.slider.common.SliderXMLConfKeysForTesting.KEY_TEST_ACCUMULO_ENABLED
-import static org.apache.slider.providers.accumulo.AccumuloKeys.*
-import static org.apache.slider.common.params.Arguments.ARG_PROVIDER
-import static org.apache.slider.common.params.Arguments.ARG_RES_COMP_OPT
-
-import org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
-import org.apache.accumulo.fate.ZooStore
-import org.apache.accumulo.trace.instrument.Tracer
-import org.apache.hadoop.conf.Configuration
-import org.apache.hadoop.fs.LocalFileSystem
-import org.apache.hadoop.fs.Path
-import org.apache.hadoop.mapreduce.filecache.DistributedCache
-import org.apache.hadoop.yarn.conf.YarnConfiguration
-import org.apache.slider.common.SliderXMLConfKeysForTesting
-import org.apache.slider.funtest.framework.CommandTestBase
-import org.apache.slider.funtest.framework.SliderShell
-import org.apache.slider.providers.accumulo.AccumuloKeys
-import org.apache.slider.common.params.Arguments
-import org.apache.thrift.TException
-import org.junit.Before
-
-/**
- * Anything specific to accumulo tests
- */
-abstract class AccumuloCommandTestBase extends CommandTestBase
-  implements SliderExitCodes, SliderActions {
-
-  public static final int ACCUMULO_LAUNCH_WAIT_TIME
-  public static final boolean ACCUMULO_TESTS_ENABLED
-  public static final FileUploader uploader
-  public Path ACCUMULO_TAR
-  public Path ACCUMULO_CONF
-
-  static {
-    ACCUMULO_LAUNCH_WAIT_TIME = getTimeOptionMillis(SLIDER_CONFIG,
-        KEY_ACCUMULO_LAUNCH_TIME,
-        1000 * DEFAULT_ACCUMULO_LAUNCH_TIME_SECONDS)
-    ACCUMULO_TESTS_ENABLED =
-        SLIDER_CONFIG.getBoolean(KEY_TEST_ACCUMULO_ENABLED, false)
-    uploader = new FileUploader(SLIDER_CONFIG, UserGroupInformation.currentUser)
-  }
-
-
-  public static void assumeAccumuloTestsEnabled() {
-    assume(ACCUMULO_TESTS_ENABLED, "Accumulo tests disabled")
-  }
-  
-  @BeforeClass
-  public static void verifyPreconditions() {
-    //if tests are not enabled: skip tests
-    assumeAccumuloTestsEnabled()
-    // but if they are -fail if the values are missing
-    getRequiredConfOption(SLIDER_CONFIG, OPTION_ZK_HOME)
-    getRequiredConfOption(SLIDER_CONFIG, OPTION_HADOOP_HOME)
-  }
-
-  @BeforeClass
-  public static void extendClasspath() {
-    addExtraJar(AccumuloClientProvider)
-  }
-
-  @Before
-  public void uploadFiles() {
-    File tar = new File(getRequiredConfOption(SLIDER_CONFIG,
-      KEY_TEST_ACCUMULO_TAR))
-    File conf = new File(getRequiredConfOption(SLIDER_CONFIG,
-      KEY_TEST_ACCUMULO_APPCONF))
-
-    //create the home dir or fail
-    Path home = uploader.mkHomeDir()
-
-    ACCUMULO_TAR = new Path(home, tar.getName())
-    ACCUMULO_CONF = new Path(home, "accumulo-conf")
-
-    // Upload the local accumulo tarball and conf directory to hdfs
-    uploader.copyIfOutOfDate(tar, ACCUMULO_TAR, false)
-    uploader.copyIfOutOfDate(conf, ACCUMULO_CONF, false)
-  }
-
-  /**
-   * Create an accumulo cluster
-   *
-   * @param clustername
-   * @param roles
-   * @param argsList
-   * @param blockUntilRunning
-   * @param containerMemory
-   * @return
-   */
-  public SliderShell createAccumuloCluster(String clustername,
-                                         Map<String, Integer> roles,
-                                         List<String> argsList,
-                                         boolean blockUntilRunning,
-                                         Map<String, String> clusterOps,
-                                         String containerMemory,
-                                         String password) {
-    argsList << ARG_PROVIDER << PROVIDER_ACCUMULO;
-
-
-    YarnConfiguration conf = SLIDER_CONFIG
-    clusterOps[OPTION_ZK_HOME] = getRequiredConfOption(
-        SLIDER_CONFIG, OPTION_ZK_HOME)
-    clusterOps[OPTION_HADOOP_HOME] = getRequiredConfOption(
-        SLIDER_CONFIG,
-        OPTION_HADOOP_HOME)
-    argsList << Arguments.ARG_IMAGE << ACCUMULO_TAR
-
-    argsList << Arguments.ARG_CONFDIR << ACCUMULO_CONF
-
-    argsList << Arguments.ARG_OPTION << AccumuloKeys.OPTION_ACCUMULO_PASSWORD << password
-
-    argsList << ARG_RES_COMP_OPT << ROLE_MASTER <<
-    YARN_MEMORY << containerMemory
-    argsList << ARG_RES_COMP_OPT << ROLE_TABLET <<
-    YARN_MEMORY << containerMemory
-    argsList << ARG_RES_COMP_OPT << ROLE_MONITOR <<
-    YARN_MEMORY << containerMemory
-    argsList << ARG_RES_COMP_OPT << ROLE_GARBAGE_COLLECTOR <<
-    YARN_MEMORY << containerMemory
-
-    return createSliderApplication(clustername,
-                             roles,
-                             argsList,
-                             blockUntilRunning,
-                             clusterOps)
-  }
-
-  public boolean loadClassesForMapReduce(Configuration conf) {
-    String[] neededClasses = [AccumuloInputFormat.class.getName(), TException.class.getName(), ZooStore.class.getName(), Tracer.class.getName()]
-    String[] neededJars = ["accumulo-core.jar", "libthrift.jar", "accumulo-fate.jar", "accumulo-trace.jar"]
-    
-    LocalFileSystem localfs = new LocalFileSystem();
-    localfs.initialize(new URI("file:///"), conf);
-    ArrayList<Path> jarsToLoad = new ArrayList<Path>();
-    
-    ClassLoader loader = AccumuloCommandTestBase.class.getClassLoader();
-    boolean missingJar = false
-    try {
-      for (String className : neededClasses) {
-        className = className.replace('.', '/') + ".class"
-        URL url = loader.getResource(className)
-        log.debug("For $className found $url")
-        String path = url.getPath();
-        int separator = path.indexOf('!')
-        if (-1 == separator) {
-          log.info("Could not interpret $path to find a valid path to a jar")
-          missingJar = true;
-          break;
-        }
-        path = path.substring(0, separator)
-        Path jarPath = new Path(path);
-        if (!localfs.exists(jarPath)) {
-          log.info("Could not find $jarPath")
-          missingJar = true
-          jarsToLoad.clear();
-          break
-        } else {
-          jarsToLoad.add(jarPath);
-        }
-      }
-    } catch (Exception e) {
-      log.warn("Got exception trying to parse jars from maven repository", e)
-      missingJar = true
-    }
-
-    if (missingJar) { 
-      String accumuloHome = conf.get(SliderXMLConfKeysForTesting.KEY_TEST_ACCUMULO_HOME)
-      if (null == accumuloHome) {
-        log.info(SliderXMLConfKeysForTesting.KEY_TEST_ACCUMULO_HOME + " is not defined in Slider configuration. Cannot load jars from local Accumulo installation")
-      } else {
-        Path p = new Path(accumuloHome + "/lib")
-        if (localfs.exists(p)) {
-          log.info("Found lib directory in local accumulo home: $p")
-          for (String neededJar : neededJars) {
-            Path jarPath = new Path(p, neededJar);
-            if (!localfs.exists(jarPath)) {
-              log.info("Could not find " + jarPath)
-              missingJar = true
-              jarsToLoad.clear();
-              break
-            } else {
-              jarsToLoad.add(jarPath);
-            }
-          }
-        }
-      }
-    }
-      
-    if (!missingJar) {
-      for (Path neededJar : jarsToLoad) {
-        log.info("Adding to mapreduce classpath: $neededJar")
-        DistributedCache.addArchiveToClassPath(neededJar, conf, localfs)
-      }
-      return true
-    } else {
-      log.info("Falling back to local mapreduce because the necessary Accumulo classes couldn't be loaded")
-    }
-    
-    return false
-  }
-  
-  public void tryToLoadMapredSite(Configuration conf) {
-    String hadoopHome = conf.get(AccumuloKeys.OPTION_HADOOP_HOME)
-    
-    // Add mapred-site.xml if we can find it
-    if (null == hadoopHome) {
-      log.info(AccumuloKeys.OPTION_HADOOP_HOME + " was not defined in Slider configuration. Running job in local mode");
-    } else {
-      LocalFileSystem localfs = new LocalFileSystem();
-      localfs.initialize(new URI("file:///"), conf);
-          
-      // If we found the necessary jars, make sure we throw mapred-site.xml on the classpath
-      // too so that we avoid local mode
-      Path p = new Path(hadoopHome + "/etc/hadoop/mapred-site.xml");
-      if (localfs.exists(p)) {
-        log.info("Loaded mapred-site.xml from " + p);
-        conf.addResource(p);
-      } else {
-        log.info("Failed to load mapred-site.xml as it doesn't exist at " + p);
-      }
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/FunctionalAccumuloClusterIT.groovy
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/FunctionalAccumuloClusterIT.groovy b/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/FunctionalAccumuloClusterIT.groovy
deleted file mode 100644
index ca7cc65..0000000
--- a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/FunctionalAccumuloClusterIT.groovy
+++ /dev/null
@@ -1,145 +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.slider.providers.accumulo.funtest
-
-import static org.apache.slider.providers.accumulo.AccumuloConfigFileOptions.*
-import static org.apache.slider.providers.accumulo.AccumuloKeys.*
-import groovy.util.logging.Slf4j
-
-import org.apache.slider.common.SliderExitCodes
-import org.apache.slider.api.ClusterDescription
-import org.apache.slider.funtest.framework.FuntestProperties
-import org.apache.slider.common.params.Arguments
-import org.apache.slider.client.SliderClient
-import org.junit.After
-import org.junit.Before
-import org.junit.Test
-
-/**
- * 
- */
-@Slf4j
-class FunctionalAccumuloClusterIT extends AccumuloCommandTestBase
-    implements FuntestProperties, Arguments, SliderExitCodes {
-
-      
-  public String getClusterName() {
-    return "test_functional_accumulo_cluster"
-  }
-
-  public String getPassword() {
-    return "password";
-  }
-      
-  @Before
-  public void prepareCluster() {
-    setupCluster(getClusterName())
-  }
-
-  @After
-  public void destroyCluster() {
-    teardown(getClusterName())
-  }
-
-  public int getNumMasters() {
-    return 1
-  }
-  
-  public int getNumTservers() {
-    return 1
-  }
-  
-  public int getNumMonitors() {
-    return 1
-  }
-  
-  public int getNumGarbageCollectors() {
-    return 1
-  }
-  
-  public int getNumTracers() {
-    return 0
-  }
-  
-  public int getMonitorPort() {
-    return 0
-  }
-
-  @Test
-  public void testAccumuloClusterCreate() throws Throwable {
-
-    describe "Create a working Accumulo cluster"
-
-    def path = buildClusterPath(getClusterName())
-    assert !clusterFS.exists(path)
-
-    Map<String, Integer> roleMap = [
-      (ROLE_MASTER) : getNumMasters(),
-      (ROLE_TABLET) : getNumTservers(),
-      (ROLE_MONITOR): getNumMonitors(),
-      (ROLE_GARBAGE_COLLECTOR): getNumGarbageCollectors(),
-      (ROLE_TRACER) : getNumTracers()
-    ];
-
-    Map<String, String> clusterOps = [:]
-    clusterOps["site." + MONITOR_PORT_CLIENT] = Integer.toString(getMonitorPort())
-
-    List<String> extraArgs = []
-
-    createAccumuloCluster(
-        getClusterName(),
-        roleMap,
-        extraArgs,
-        true,
-        clusterOps,
-        "128",
-        getPassword()
-        )
-    ensureApplicationIsUp(getClusterName())
-
-    //get a slider client against the cluster
-    SliderClient sliderClient = bondToCluster(SLIDER_CONFIG, getClusterName())
-    ClusterDescription cd = sliderClient.clusterDescription
-    assert getClusterName() == cd.name
-
-    log.info("Connected via Client {}", sliderClient.toString())
-
-    //wait for the role counts to be reached
-    waitForRoleCount(sliderClient, roleMap, ACCUMULO_LAUNCH_WAIT_TIME)
-    
-    clusterLoadOperations(clusterName, roleMap, cd)
-  }
-
-
-  public String getDescription() {
-    return "Create a working Accumulo cluster $clusterName"
-  }
-
-  /**
-   * Override point for any cluster load operations
-   * @param clientConf
-   * @param numWorkers
-   */
-  public void clusterLoadOperations(
-      String clustername,
-      Map<String, Integer> roleMap,
-      ClusterDescription cd) {
-
-    log.info("Client Description = " + cd.toJsonString())
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/FunctionalAccumuloM1T1GC1Mon1IT.groovy
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/FunctionalAccumuloM1T1GC1Mon1IT.groovy b/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/FunctionalAccumuloM1T1GC1Mon1IT.groovy
deleted file mode 100644
index 33910d4..0000000
--- a/slider-providers/accumulo/accumulo-funtests/src/test/groovy/org/apache/slider/providers/accumulo/funtest/FunctionalAccumuloM1T1GC1Mon1IT.groovy
+++ /dev/null
@@ -1,57 +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.slider.providers.accumulo.funtest
-
-import groovy.util.logging.Slf4j
-import org.apache.slider.api.ClusterDescription
-import org.apache.slider.common.params.Arguments
-import org.apache.slider.common.params.SliderActions
-
-@Slf4j
-public class FunctionalAccumuloM1T1GC1Mon1IT extends FunctionalAccumuloClusterIT {
-
-  @Override
-  public String getClusterName() {
-    return "test_functional_accumulo_m1t1gc1mon1";
-  }
-
-  /**
-   * Override point for any cluster load operations
-   * @param clientConf
-   * @param numWorkers
-   */
-  @Override
-  public void clusterLoadOperations(
-      String clustername,
-      Map<String, Integer> roleMap,
-      ClusterDescription cd) {
-
-    slider(0, [
-      SliderActions.ACTION_FREEZE,
-      getClusterName(),
-      Arguments.ARG_WAIT,
-      Integer.toString(FREEZE_WAIT_TIME),
-      Arguments.ARG_MESSAGE,
-      "freeze-in-test-AccumuloCluster"
-    ])
-    
-    //destroy the cluster. This only works if the permissions allow it
-    destroy(0, getClusterName())
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/accumulo-funtests/src/test/java/org/apache/slider/providers/accumulo/funtest/StubToForceGroovyTestsToCompile.java
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/accumulo-funtests/src/test/java/org/apache/slider/providers/accumulo/funtest/StubToForceGroovyTestsToCompile.java b/slider-providers/accumulo/accumulo-funtests/src/test/java/org/apache/slider/providers/accumulo/funtest/StubToForceGroovyTestsToCompile.java
deleted file mode 100644
index 1a948a2..0000000
--- a/slider-providers/accumulo/accumulo-funtests/src/test/java/org/apache/slider/providers/accumulo/funtest/StubToForceGroovyTestsToCompile.java
+++ /dev/null
@@ -1,22 +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.slider.providers.accumulo.funtest;
-
-class StubToForceGroovyTestsToCompile {
-}

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/accumulo-funtests/src/test/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/accumulo-funtests/src/test/resources/log4j.properties b/slider-providers/accumulo/accumulo-funtests/src/test/resources/log4j.properties
deleted file mode 100644
index a552a55..0000000
--- a/slider-providers/accumulo/accumulo-funtests/src/test/resources/log4j.properties
+++ /dev/null
@@ -1,59 +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.
-
-# log4j configuration used during build and unit tests
-
-log4j.rootLogger=INFO,stdout
-log4j.threshhold=ALL
-log4j.appender.stdout=org.apache.log4j.ConsoleAppender
-log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
-log4j.appender.stdout.layout.ConversionPattern=%d{ISO8601} [%t] %-5p %c{2} (%F:%M(%L)) - %m%n
-
-log4j.appender.subprocess=org.apache.log4j.ConsoleAppender
-log4j.appender.subprocess.layout=org.apache.log4j.PatternLayout
-log4j.appender.subprocess.layout.ConversionPattern=[%c{1}]: %m%n
-#log4j.logger.org.apache.slider.yarn.appmaster.SliderAppMasterer.master=INFO,subprocess
-
-log4j.logger.org.apache.slider=DEBUG
-log4j.logger.org.apache.hadoop.yarn.service.launcher=DEBUG
-
-
-
-#log4j.logger.org.apache.hadoop.yarn.service.launcher=DEBUG
-#log4j.logger.org.apache.hadoop.yarn.service=DEBUG
-#log4j.logger.org.apache.hadoop.yarn.client=DEBUG
-
-#crank back on some noise
-log4j.logger.org.apache.hadoop.util.NativeCodeLoader=ERROR
-log4j.logger.org.apache.hadoop.hdfs.server.datanode.BlockPoolSliceScanner=WARN
-log4j.logger.org.apache.hadoop.hdfs.server.blockmanagement=WARN
-log4j.logger.org.apache.hadoop.hdfs.server.namenode.FSNamesystem.audit=WARN
-log4j.logger.org.apache.hadoop.hdfs=WARN
-
-
-log4j.logger.org.apache.hadoop.yarn.server.nodemanager.containermanager.monitor=WARN
-log4j.logger.org.apache.hadoop.yarn.server.nodemanager.NodeStatusUpdaterImpl=WARN
-log4j.logger.org.apache.zookeeper=WARN
-log4j.logger.org.apache.zookeeper.ClientCnxn=FATAL
-
-log4j.logger.org.apache.hadoop.yarn.server.resourcemanager.security=WARN
-log4j.logger.org.apache.hadoop.metrics2=ERROR
-log4j.logger.org.apache.hadoop.util.HostsFileReader=WARN
-log4j.logger.org.apache.hadoop.yarn.event.AsyncDispatcher=WARN
-log4j.logger.org.apache.hadoop.security.token.delegation=WARN
-log4j.logger.org.apache.hadoop.yarn.util.AbstractLivelinessMonitor=WARN
-log4j.logger.org.apache.hadoop.yarn.server.nodemanager.security=WARN
-log4j.logger.org.apache.hadoop.yarn.server.resourcemanager.RMNMInfo=WARN

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/slider-accumulo-provider/pom.xml
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/slider-accumulo-provider/pom.xml b/slider-providers/accumulo/slider-accumulo-provider/pom.xml
deleted file mode 100644
index d128d7e..0000000
--- a/slider-providers/accumulo/slider-accumulo-provider/pom.xml
+++ /dev/null
@@ -1,228 +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.
--->
-
-<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>
-  <artifactId>slider-accumulo-provider</artifactId>
-  <name>Slider Accumulo Provider</name>
-  <packaging>jar</packaging>
-  <description>
-    Direct provider for slider. This is the original provider from Hoya, moved to one side
-    as it is no longer being actively developed
-    
-  </description>
-  <parent>
-    <groupId>org.apache.slider</groupId>
-    <artifactId>slider</artifactId>
-    <version>0.61-incubating</version>
-    <relativePath>../../../</relativePath>
-  </parent>
-
-  <build>
-
-    <!-- resources are filtered for dynamic updates. This gets build info in-->
-    <resources>
-      <resource>
-        <directory>src/main/resources</directory>
-        <filtering>true</filtering>
-      </resource>
-    </resources>
-
-    <plugins>
-
-      <!--read in a build.properties file if defined-->
-      <plugin>
-        <groupId>org.codehaus.mojo</groupId>
-        <artifactId>properties-maven-plugin</artifactId>
-        <version>${maven.properties.version}</version>
-        <executions>
-          <execution>
-            <phase>initialize</phase>
-            <goals>
-              <goal>read-project-properties</goal>
-            </goals>
-            <configuration>
-              <quiet>true</quiet>
-              <files>
-                <file>build.properties</file>
-                <file>../../build.properties</file>
-              </files>
-            </configuration>
-          </execution>
-        </executions>
-      </plugin>
-      
-      <plugin>
-        <artifactId>maven-compiler-plugin</artifactId>
-        <dependencies>
-          <dependency>
-            <groupId>org.codehaus.groovy</groupId>
-            <artifactId>groovy-eclipse-compiler</artifactId>
-            <version>${groovy-eclipse-compiler.version}</version>
-          </dependency>
-          <dependency>
-            <groupId>org.codehaus.groovy</groupId>
-            <artifactId>groovy-eclipse-batch</artifactId>
-            <version>${groovy-eclipse-batch.version}</version>
-          </dependency>
-        </dependencies>
-      </plugin>
-
-
-      <!-- test -->
-      <plugin>
-        <groupId>org.apache.maven.plugins</groupId>
-        <artifactId>maven-surefire-plugin</artifactId>
-        <version>${maven-surefire-plugin.version}</version>
-        <configuration>
-          <!--mvn process fork options-->
-          <reuseForks>${test.reuseForks}</reuseForks>
-          <forkMode>${test.forkMode}</forkMode>
-          <forkCount>1</forkCount>
-          <forkedProcessTimeoutInSeconds>${test.forkedProcessTimeoutInSeconds}
-          </forkedProcessTimeoutInSeconds>
-          <threadCount>1</threadCount>
-          <argLine>${test.argLine}</argLine>
-          <failIfNoTests>${test.failIfNoTests}</failIfNoTests>
-          
-          <trimStackTrace>false</trimStackTrace>
-          <redirectTestOutputToFile>${build.redirect.test.output.to.file}</redirectTestOutputToFile>
-          <systemPropertyVariables>
-            <java.net.preferIPv4Stack>true</java.net.preferIPv4Stack>
-            <java.awt.headless>true</java.awt.headless>
-            <java.security.krb5.realm>${slider.test.java.security.krb5.realm}</java.security.krb5.realm>
-            <java.security.krb5.kdc>${slider.test.java.security.krb5.kdc}</java.security.krb5.kdc>
-            <!-- this property must be supplied-->
-            <slider.conf.dir>${slider.conf.dir}</slider.conf.dir>
-            <slider.bin.dir>../../slider-assembly/target/slider-${project.version}-all/slider-${project.version}</slider.bin.dir>
-          </systemPropertyVariables>
-          <includes>
-            <include>**/Test*.java</include>
-          </includes>
-          <excludes>
-            <exclude>**/Test*$*.java</exclude>
-          </excludes>
-        </configuration>
-      </plugin>
-  
- 
-    </plugins>
-  </build>
-
-  <reporting>
-    <plugins>
- 
-
-
-    </plugins>
-  </reporting>
-
-  <dependencies>
-
-    <dependency>
-      <groupId>org.apache.slider</groupId>
-      <artifactId>slider-core</artifactId>
-      <version>${project.version}</version>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.slider</groupId>
-      <artifactId>slider-core</artifactId>
-      <version>${project.version}</version>
-      <type>test-jar</type>
-      <scope>test</scope>
-    </dependency>
-
-
-    <dependency>
-      <groupId>org.codehaus.groovy</groupId>
-      <artifactId>groovy-all</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-client</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-minicluster</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-core</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-minicluster</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-trace</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-fate</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.accumulo</groupId>
-      <artifactId>accumulo-test</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>junit</groupId>
-      <artifactId>junit</artifactId>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>commons-lang</groupId>
-      <artifactId>commons-lang</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>com.google.guava</groupId>
-      <artifactId>guava</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>org.slf4j</groupId>
-      <artifactId>slf4j-api</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>org.apache.zookeeper</groupId>
-      <artifactId>zookeeper</artifactId>
-    </dependency>
-
-
-  </dependencies>
-
-
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloClientProvider.java
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloClientProvider.java b/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloClientProvider.java
deleted file mode 100644
index 955e4fb..0000000
--- a/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloClientProvider.java
+++ /dev/null
@@ -1,351 +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.slider.providers.accumulo;
-
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.fs.CommonConfigurationKeys;
-import org.apache.hadoop.fs.CommonConfigurationKeysPublic;
-import org.apache.hadoop.fs.Path;
-import org.apache.hadoop.yarn.api.records.LocalResource;
-import org.apache.slider.api.InternalKeys;
-import org.apache.slider.common.SliderKeys;
-import org.apache.slider.common.SliderXmlConfKeys;
-import org.apache.slider.api.OptionKeys;
-import org.apache.slider.core.conf.AggregateConf;
-import org.apache.slider.core.conf.ConfTreeOperations;
-import org.apache.slider.core.conf.MapOperations;
-import org.apache.slider.core.launch.AbstractLauncher;
-import org.apache.slider.core.exceptions.BadCommandArgumentsException;
-import org.apache.slider.core.exceptions.BadConfigException;
-import org.apache.slider.core.exceptions.SliderException;
-import org.apache.slider.providers.AbstractClientProvider;
-import org.apache.slider.providers.ProviderRole;
-import org.apache.slider.providers.ProviderUtils;
-import org.apache.slider.common.tools.ConfigHelper;
-import org.apache.slider.common.tools.SliderFileSystem;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import java.io.FileNotFoundException;
-import java.io.IOException;
-import java.net.URI;
-import java.util.HashMap;
-import java.util.HashSet;
-import java.util.List;
-import java.util.Map;
-import java.util.Set;
-import java.util.UUID;
-
-/**
- * Client-side accumulo provider
- */
-public class AccumuloClientProvider extends AbstractClientProvider implements
-                                                       AccumuloKeys {
-
-  protected static final Logger log =
-    LoggerFactory.getLogger(AccumuloClientProvider.class);
-  private static final ProviderUtils providerUtils = new ProviderUtils(log);
-  private static final String INSTANCE_RESOURCE_BASE =
-      "/org/apache/slider/providers/accumulo/instance/";
-
-
-  protected AccumuloClientProvider(Configuration conf) {
-    super(conf);
-  }
-
-  public static List<ProviderRole> getProviderRoles() {
-    return AccumuloRoles.ROLES;
-  }
-
-  @Override
-  public String getName() {
-    return PROVIDER_ACCUMULO;
-  }
-
-  @Override
-  public List<ProviderRole> getRoles() {
-    return AccumuloRoles.ROLES;
-  }
-
-
-  @Override
-  public void prepareInstanceConfiguration(AggregateConf aggregateConf) throws
-      SliderException,
-                                                                        IOException {
-    String resourceTemplate = INSTANCE_RESOURCE_BASE + "resources.json";
-    String appConfTemplate = INSTANCE_RESOURCE_BASE + "appconf.json";
-    mergeTemplates(aggregateConf, null, resourceTemplate, appConfTemplate);
-    aggregateConf.getAppConfOperations().set(OPTION_ACCUMULO_PASSWORD,
-                                             createAccumuloPassword());
-  }
-
-
-  public String createAccumuloPassword() {
-    return UUID.randomUUID().toString();
-  }
-
-  public void setDatabasePath(Map<String, String> sitexml, String dataPath) {
-    Path path = new Path(dataPath);
-    URI parentUri = path.toUri();
-    String authority = parentUri.getAuthority();
-    String fspath =
-      parentUri.getScheme() + "://" + (authority == null ? "" : authority) + "/";
-    sitexml.put(AccumuloConfigFileOptions.INSTANCE_DFS_URI, fspath);
-    sitexml.put(AccumuloConfigFileOptions.INSTANCE_DFS_DIR,
-                parentUri.getPath());
-  }
-
-  /**
-   * Build the accumulo-site.xml file
-   * This the configuration used by Accumulo directly
-   * @param instanceDescription this is the cluster specification used to define this
-   * @return a map of the dynamic bindings for this Slider instance
-   */
-  public Map<String, String> buildSiteConfFromInstance(
-    AggregateConf instanceDescription)
-    throws BadConfigException {
-
-
-    ConfTreeOperations appconf =
-      instanceDescription.getAppConfOperations();
-
-    MapOperations globalAppOptions = appconf.getGlobalOptions();
-    MapOperations globalInstanceOptions =
-      instanceDescription.getInternalOperations().getGlobalOptions();
-
-
-    Map<String, String> sitexml = new HashMap<String, String>();
-
-    providerUtils.propagateSiteOptions(globalAppOptions, sitexml);
-
-    propagateClientFSBinding(sitexml);
-    setDatabasePath(sitexml,
-                    globalInstanceOptions.getMandatoryOption(InternalKeys.INTERNAL_DATA_DIR_PATH));
-
-
-    String quorum =
-      globalAppOptions.getMandatoryOption(OptionKeys.ZOOKEEPER_QUORUM);
-    sitexml.put(AccumuloConfigFileOptions.ZOOKEEPER_HOST, quorum);
-
-    return sitexml;
-
-  }
-
-
-  public void propagateClientFSBinding(Map<String, String> sitexml) throws
-                                                                    BadConfigException {
-    String fsDefaultName =
-      getConf().get(CommonConfigurationKeys.FS_DEFAULT_NAME_KEY);
-    if (fsDefaultName == null) {
-      throw new BadConfigException("Key not found in conf: {}",
-                                   CommonConfigurationKeysPublic.FS_DEFAULT_NAME_KEY);
-    }
-    sitexml.put(CommonConfigurationKeysPublic.FS_DEFAULT_NAME_KEY, fsDefaultName);
-    sitexml.put(SliderXmlConfKeys.FS_DEFAULT_NAME_CLASSIC, fsDefaultName);
-  }
-
-  @Override 
-  public void preflightValidateClusterConfiguration(SliderFileSystem sliderFileSystem,
-                                                    String clustername,
-                                                    Configuration configuration,
-                                                    AggregateConf instanceDefinition,
-                                                    Path clusterDirPath,
-                                                    Path generatedConfDirPath,
-                                                    boolean secure) throws
-      SliderException,
-                                                                    IOException {
-    super.preflightValidateClusterConfiguration(sliderFileSystem, clustername,
-                                                configuration,
-                                                instanceDefinition,
-                                                clusterDirPath,
-                                                generatedConfDirPath, secure);
-
-  }
-
-  /**
-   * Add Accumulo and its dependencies (only) to the job configuration.
-   * <p>
-   * This is intended as a low-level API, facilitating code reuse between this
-   * class and its mapred counterpart. It also of use to external tools that
-   * need to build a MapReduce job that interacts with Accumulo but want
-   * fine-grained control over the jars shipped to the cluster.
-   * </p>
-   *
-   * @see org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-   * @see <a href="https://issues.apache.org/;jira/browse/PIG-3285">PIG-3285</a>
-   *
-   * @param providerResources provider resources to add resource to
-   * @param sliderFileSystem filesystem
-   * @param libdir relative directory to place resources
-   * @param tempPath path in the cluster FS for temp files
-   * @throws IOException IO problems
-   * @throws SliderException Slider-specific issues
-   */
-  private void addAccumuloDependencyJars(Map<String, LocalResource> providerResources,
-                                            SliderFileSystem sliderFileSystem,
-                                            String libdir,
-                                            Path tempPath) throws
-                                                           IOException,
-      SliderException {
-    String[] jars =
-      {
-      /*  "zookeeper.jar",*/
-      };
-    Class<?>[] classes = {
-      //zk
-/*      org.apache.zookeeper.ClientCnxn.class*/
-    };
-    
-    ProviderUtils.addDependencyJars(providerResources, sliderFileSystem, tempPath,
-                                    libdir, jars,
-                                    classes);
-  }
-
-  @Override
-  public void prepareAMAndConfigForLaunch(SliderFileSystem fileSystem,
-      Configuration serviceConf,
-      AbstractLauncher launcher,
-      AggregateConf instanceDescription,
-      Path snapshotConfDirPath,
-      Path generatedConfDirPath,
-      Configuration clientConfExtras,
-      String libdir,
-      Path tempPath,
-      boolean miniClusterTestRun) throws IOException, SliderException {
-    //load in the template site config
-    log.debug("Loading template configuration from {}", snapshotConfDirPath);
-      Configuration siteConf = ConfigHelper.loadTemplateConfiguration(
-        serviceConf,
-          snapshotConfDirPath,
-        AccumuloKeys.SITE_XML,
-        AccumuloKeys.SITE_XML_RESOURCE);
-
-
-
-    Map<String, LocalResource> providerResources;
-    providerResources = fileSystem.submitDirectory(generatedConfDirPath,
-                                                   SliderKeys.PROPAGATED_CONF_DIR_NAME);
-
-
-    ProviderUtils.addProviderJar(providerResources,
-        this,
-        "slider-accumulo-provider.jar",
-        fileSystem,
-        tempPath,
-        libdir,
-        miniClusterTestRun);
-
-
-    addAccumuloDependencyJars(providerResources, fileSystem, libdir, tempPath);
-    launcher.addLocalResources(providerResources);
-    
-    //construct the cluster configuration values
-
-    ConfTreeOperations appconf =
-      instanceDescription.getAppConfOperations();
-
-
-    Map<String, String> clusterConfMap = buildSiteConfFromInstance(
-      instanceDescription);
-
-    //merge them
-    ConfigHelper.addConfigMap(siteConf,
-                              clusterConfMap.entrySet(),
-                              "Accumulo Provider");
-
-    //now, if there is an extra client conf, merge it in too
-    if (clientConfExtras != null) {
-      ConfigHelper.mergeConfigurations(siteConf, clientConfExtras,
-                                       "Slider Client", true);
-    }
-
-    if (log.isDebugEnabled()) {
-      log.debug("Merged Configuration");
-      ConfigHelper.dumpConf(siteConf);
-    }
-
-    Path sitePath = ConfigHelper.saveConfig(serviceConf,
-                                            siteConf,
-                                            generatedConfDirPath,
-                                            AccumuloKeys.SITE_XML);
-
-    log.debug("Saving the config to {}", sitePath);
-    launcher.submitDirectory(generatedConfDirPath,
-                             SliderKeys.PROPAGATED_CONF_DIR_NAME);
-
-  }
-
-  private static Set<String> knownRoleNames = new HashSet<String>();
-  static {
-    knownRoleNames.add(SliderKeys.COMPONENT_AM);
-    for (ProviderRole role : AccumuloRoles.ROLES) {
-      knownRoleNames.add(role.name);
-    }
-  }
-
-  @Override
-  public void validateInstanceDefinition(AggregateConf instanceDefinition, SliderFileSystem fs) throws
-      SliderException {
-    super.validateInstanceDefinition(instanceDefinition, fs);
-
-    ConfTreeOperations resources =
-      instanceDefinition.getResourceOperations();
-    Set<String> unknownRoles = resources.getComponentNames();
-    unknownRoles.removeAll(knownRoleNames);
-    if (!unknownRoles.isEmpty()) {
-      throw new BadCommandArgumentsException("There is unknown role: %s",
-                                             unknownRoles.iterator().next());
-    }
-    providerUtils.validateNodeCount(instanceDefinition,
-                                    AccumuloKeys.ROLE_TABLET,
-                                    1, -1);
-
-
-    providerUtils.validateNodeCount(instanceDefinition,
-                                    AccumuloKeys.ROLE_MASTER, 1, -1);
-
-    providerUtils.validateNodeCount(instanceDefinition,
-                                    AccumuloKeys.ROLE_GARBAGE_COLLECTOR,
-                                    0, -1);
-
-    providerUtils.validateNodeCount(instanceDefinition,
-                                    AccumuloKeys.ROLE_MONITOR,
-                                    0, -1);
-
-    providerUtils.validateNodeCount(instanceDefinition,
-                                    AccumuloKeys.ROLE_TRACER , 0, -1);
-
-    MapOperations globalAppConfOptions =
-      instanceDefinition.getAppConfOperations().getGlobalOptions();
-    globalAppConfOptions.verifyOptionSet(AccumuloKeys.OPTION_ZK_HOME);
-    globalAppConfOptions.verifyOptionSet(AccumuloKeys.OPTION_HADOOP_HOME);
-  }
-
-
-  /**
-   * Get the path to the script
-   * @return the script
-   */
-  public static String buildScriptBinPath(AggregateConf instanceDefinition)
-    throws FileNotFoundException {
-    return providerUtils.buildPathToScript(instanceDefinition, "bin", "accumulo");
-  }
-
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloConfigFileOptions.java
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloConfigFileOptions.java b/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloConfigFileOptions.java
deleted file mode 100644
index c6eec9a..0000000
--- a/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloConfigFileOptions.java
+++ /dev/null
@@ -1,72 +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.slider.providers.accumulo;
-
-/**
- * Mappings of config params to env variables for
- * custom -site.xml files to pick up
- */
-public interface AccumuloConfigFileOptions {
-
-
-  /**
-   * quorum style, comma separated list of hostname:port values
-   */
-  String ZOOKEEPER_HOST = "instance.zookeeper.host";
-
-  /**
-   * URI to the filesystem
-   */
-  String INSTANCE_DFS_URI = "instance.dfs.uri";
-
-  /**
-   * Dir under the DFS URI
-   */
-  String INSTANCE_DFS_DIR = "instance.dfs.dir";
-
-  // String used to restrict access to data in ZK
-  String INSTANCE_SECRET = "instance.secret";
-  
-  // IPC port for master
-  String MASTER_PORT_CLIENT = "master.port.client";
-  String MASTER_PORT_CLIENT_DEFAULT = "9999";
-  
-  // IPC port for monitor
-  String MONITOR_PORT_CLIENT = "monitor.port.client";
-  String MONITOR_PORT_CLIENT_DEFAULT = "50095";
-  int MONITOR_PORT_CLIENT_INT = Integer.parseInt(MONITOR_PORT_CLIENT_DEFAULT);
-  
-  // Log4j forwarding port
-  String MONITOR_LOG4J_PORT = "monitor.port.log4j";
-  String MONITOR_LOG4J_PORT_DEFAULT = "4560";
-  int MONITOR_LOG4J_PORT_INT = Integer.parseInt(MONITOR_LOG4J_PORT_DEFAULT);
-  
-  // IPC port for tracer
-  String TRACE_PORT_CLIENT = "trace.port.client";
-  String TRACE_PORT_CLIENT_DEFAULT = "trace.port.client";
-
-  // IPC port for tserver
-  String TSERV_PORT_CLIENT = "tserver.port.client";
-  String TSERV_PORT_CLIENT_DEFAULT = "tserver.port.client";
-  
-  // IPC port for gc
-  String GC_PORT_CLIENT = "gc.port.client";
-  String GC_PORT_CLIENT_DEFAULT = "50091";
-  int GC_PORT_CLIENT_INT = Integer.parseInt(GC_PORT_CLIENT_DEFAULT);
-}

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloKeys.java
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloKeys.java b/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloKeys.java
deleted file mode 100644
index 924ec41..0000000
--- a/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloKeys.java
+++ /dev/null
@@ -1,120 +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.slider.providers.accumulo;
-
-import org.apache.slider.api.StatusKeys;
-
-/**
- * Any keys related to acculumulo
- */
-public interface AccumuloKeys {
-  String PROVIDER_ACCUMULO = "accumulo";
-  
-  String ROLE_MASTER = "master";
-
-  String ROLE_TABLET = "tserver";
-  String ROLE_GARBAGE_COLLECTOR = "gc";
-  String ROLE_MONITOR = "monitor";
-  String ROLE_TRACER = "tracer";
-
-  String OPTION_ZK_TAR = "zk.image.path";  
-  String OPTION_ZK_HOME = "zk.home";  
-  String OPTION_HADOOP_HOME = "hadoop.home";  
-  String OPTION_ACCUMULO_PASSWORD = "accumulo.password";  
-
-  String DEFAULT_MASTER_HEAP = "256";
-  String DEFAULT_MASTER_YARN_RAM = "384";
-  String DEFAULT_MASTER_YARN_VCORES = "1";
-  String DEFAULT_ROLE_YARN_VCORES = "1";
-  String DEFAULT_ROLE_HEAP = DEFAULT_MASTER_HEAP;
-  String DEFAULT_ROLE_YARN_RAM = DEFAULT_MASTER_YARN_RAM;
-
-// org.apache.slider.providers.accumulo.conf
-
-  String VERSION = "version";
-
-  String CREATE_MASTER = ROLE_MASTER;
-  String CREATE_GC = ROLE_GARBAGE_COLLECTOR;
-  String CREATE_TABLET = ROLE_TABLET;
-  String CREATE_MONITOR = ROLE_MONITOR;
-  String CREATE_TRACER  = ROLE_TRACER;
-
-
-  String ACTION_START = "start";
-  String ACTION_STOP = "stop";
-
-  /**
-   * Config directory : {@value}
-   */
-  String ARG_CONFIG = "--config";
-  /**
-   *  name of the hbase script relative to the hbase root dir:  {@value}
-   */
-  String START_SCRIPT = "bin/accumulo";
-
-  /**
-   *  name of the site conf to generate :  {@value}
-   */
-  String SITE_XML = "accumulo-site.xml";
-
-  /**
-   * Template stored in the slider classpath -to use if there is
-   * no site-specific template
-   *  {@value}
-   */
-  String CONF_RESOURCE = "org/apache/slider/providers/accumulo/conf/";
-  String SITE_XML_RESOURCE = CONF_RESOURCE + SITE_XML;
-  String ACCUMULO_HOME = "ACCUMULO_HOME";
-
-  String ACCUMULO_CONF_DIR = "ACCUMULO_CONF_DIR";
-  String ACCUMULO_LOG_DIR = "ACCUMULO_LOG_DIR";
-  String ACCUMULO_GENERAL_OPTS = "ACCUMULO_GENERAL_OPTS";
-  String HADOOP_HOME = "HADOOP_HOME";
-  String ZOOKEEPER_HOME = "ZOOKEEPER_HOME";
-
-  /**
-   * ":"-separated list of extra jars 
-   * 
-   */
-  String ACCUMULO_XTRAJARS = "ACCUMULO_XTRAJARS";
-  String HADOOP_PREFIX = "HADOOP_PREFIX" ;
-  int INIT_TIMEOUT_DEFAULT = 60000;
-  /**
-   * timeout in millis for init to complete
-   */
-  String OPTION_ACCUMULO_INIT_TIMEOUT = "accumulo.init.timeout";
-
-  /**
-   *       @Parameter(names = "--instance-name", description = "the instance name, if not provided, will prompt")
-   */
-  String PARAM_INSTANCE_NAME = "--instance-name";
-  /**
-   *     @Parameter(names = "--password", description = "set the password on the command line")
-   */
-  String PARAM_PASSWORD = "--password";
-
-  String MONITOR_PAGE_JSON = "/json";
-  String MONITOR_PAGE_XML = "/xml";
-
-  String ACCUMULO_VERSION_COMMAND = "version";
-  
-  String MASTER_ADDRESS = StatusKeys.INFO_MASTER_ADDRESS;
-  String MONITOR_ADDRESS = "monitor.address";
-  String INSTANCE_ID = "instance_id";
-}

http://git-wip-us.apache.org/repos/asf/incubator-slider/blob/5d405543/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloProviderFactory.java
----------------------------------------------------------------------
diff --git a/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloProviderFactory.java b/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloProviderFactory.java
deleted file mode 100644
index a090cb1..0000000
--- a/slider-providers/accumulo/slider-accumulo-provider/src/main/java/org/apache/slider/providers/accumulo/AccumuloProviderFactory.java
+++ /dev/null
@@ -1,44 +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.slider.providers.accumulo;
-
-import org.apache.hadoop.conf.Configuration;
-import org.apache.slider.providers.AbstractClientProvider;
-import org.apache.slider.providers.SliderProviderFactory;
-import org.apache.slider.providers.ProviderService;
-
-public class AccumuloProviderFactory extends SliderProviderFactory {
-
-  public AccumuloProviderFactory() {
-  }
-
-  public AccumuloProviderFactory(Configuration conf) {
-    super(conf);
-  }
-
-  @Override
-  public AbstractClientProvider createClientProvider() {
-    return new AccumuloClientProvider(getConf());
-  }
-
-  @Override
-  public ProviderService createServerProvider() {
-    return new AccumuloProviderService();
-  }
-}