You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by ct...@apache.org on 2014/06/27 01:48:01 UTC

[04/13] ACCUMULO-2646 Generate config examples in assembly

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/check-slaves
----------------------------------------------------------------------
diff --git a/bin/check-slaves b/bin/check-slaves
deleted file mode 100755
index 2af7f42..0000000
--- a/bin/check-slaves
+++ /dev/null
@@ -1,199 +0,0 @@
-#! /usr/bin/env python
-
-# 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.
-
-# This script will check the configuration and uniformity of all the nodes in a cluster.
-# Checks
-#   each node is reachable via ssh
-#   login identity is the same
-#   the physical memory is the same
-#   the mounts are the same on each machine
-#   a set of writable locations (typically different disks) are in fact writable
-# 
-# In order to check for writable partitions, you must configure the WRITABLE variable below.
-#
-
-import subprocess
-import time
-import select
-import os
-import sys
-import fcntl
-import signal
-if not sys.platform.startswith('linux'):
-   sys.stderr.write('This script only works on linux, sorry.\n')
-   sys.exit(1)
-
-TIMEOUT = 5
-WRITABLE = []
-#WRITABLE = ['/srv/hdfs1', '/srv/hdfs2', '/srv/hdfs3']
-
-def ssh(slave, *args):
-    'execute a command on a remote slave and return the Popen handle'
-    handle = subprocess.Popen( ('ssh', '-o', 'StrictHostKeyChecking=no', '-q', '-A', '-n', slave) + args, stdout=subprocess.PIPE, stderr=subprocess.PIPE)
-    handle.slave = slave
-    handle.finished = False
-    handle.out = ''
-    return handle
-
-def wait(handles, seconds):
-    'wait for lots of handles simultaneously, and kill anything that doesn\'t return in seconds time\n'
-    'Note that stdout will be stored on the handle as the "out" field and "finished" will be set to True'
-    handles = handles[:]
-    stop = time.time() + seconds
-    for h in handles:
-       fcntl.fcntl(h.stdout, fcntl.F_SETFL, os.O_NONBLOCK)
-    while handles and time.time() < stop:
-       wait = min(0, stop - time.time())
-       handleMap = dict( [(h.stdout, h) for h in handles] )
-       rd, wr, err = select.select(handleMap.keys(), [], [], wait)
-       for r in rd:
-           handle = handleMap[r]
-           while 1:
-               more = handle.stdout.read(1024)
-               if more == '':
-                   handles.remove(handle)
-                   handle.poll()
-                   handle.wait()
-                   handle.finished = True
-               handle.out += more
-               if len(more) < 1024:
-                   break
-    for handle in handles:
-       os.kill(handle.pid, signal.SIGKILL)
-       handle.poll()
-
-def runAll(slaves, *cmd):
-    'Run the given command on all the slaves, returns Popen handles'
-    handles = []
-    for slave in slaves:
-        handles.append(ssh(slave, *cmd))
-    wait(handles, TIMEOUT)
-    return handles
-
-def checkIdentity(slaves):
-    'Ensure the login identity is consistent across the slaves'
-    handles = runAll(slaves, 'id', '-u', '-n')
-    bad = set()
-    myIdentity = os.popen('id -u -n').read().strip()
-    for h in handles:
-        if not h.finished or h.returncode != 0:
-            print '#', 'cannot look at identity on', h.slave
-            bad.add(h.slave)
-        else:
-            identity = h.out.strip()
-            if identity != myIdentity:
-                print '#', h.slave, 'inconsistent identity', identity
-                bad.add(h.slave)
-    return bad
-
-def checkMemory(slaves):
-    'Run free on all slaves and look for weird results'
-    handles = runAll(slaves, 'free')
-    bad = set()
-    mem = {}
-    swap = {}
-    for h in handles:
-        if not h.finished or h.returncode != 0:
-            print '#', 'cannot look at memory on', h.slave
-            bad.add(h.slave)
-        else:
-            if h.out.find('Swap:') < 0:
-               print '#',h.slave,'has no swap'
-               bad.add(h.slave)
-               continue
-            lines = h.out.split('\n')
-            for line in lines:
-               if line.startswith('Mem:'):
-                  mem.setdefault(line.split()[1],set()).add(h.slave)
-               if line.startswith('Swap:'):
-                  swap.setdefault(line.split()[1],set()).add(h.slave)
-    # order memory sizes by most common
-    mems = sorted([(len(v), k, v) for k, v in mem.items()], reverse=True)
-    mostCommon = float(mems[0][1])
-    for _, size, slaves in mems[1:]:
-        fract = abs(mostCommon - float(size)) / mostCommon
-        if fract > 0.05:
-            print '#',', '.join(slaves), ': unusual memory size', size
-            bad.update(slaves)
-    swaps = sorted([(len(v), k, v) for k, v in swap.items()], reverse=True)
-    mostCommon = float(mems[0][1])
-    for _, size, slaves in swaps[1:]:
-        fract = abs(mostCommon - float(size) / mostCommon)
-        if fract > 0.05:
-            print '#',', '.join(slaves), ': unusual swap size', size
-            bad.update(slaves)
-    return bad
-
-def checkWritable(slaves):
-    'Touch all the directories that should be writable by this user return any nodes that fail'
-    if not WRITABLE:
-       print '# WRITABLE value not configured, not checking partitions'
-       return []
-    handles = runAll(slaves, 'touch', *WRITABLE)
-    bad = set()
-    for h in handles:
-        if not h.finished or h.returncode != 0:
-           bad.add(h.slave)
-           print '#', h.slave, 'some drives are not writable'
-    return bad
-
-def checkMounts(slaves):
-    'Check the file systems that are mounted and report any that are unusual'
-    handles = runAll(slaves, 'mount')
-    mounts = {}
-    finished = set()
-    bad = set()
-    for handle in handles:
-        if handle.finished and handle.returncode == 0:
-            for line in handle.out.split('\n'):
-                words = line.split()
-                if len(words) < 5: continue
-                if words[4] == 'nfs': continue
-                if words[0].find(':/') >= 0: continue
-                mount = words[2]
-                mounts.setdefault(mount, set()).add(handle.slave)
-            finished.add(handle.slave)
-        else:
-            bad.add(handle.slave)
-            print '#', handle.slave, 'did not finish'
-    for m in sorted(mounts.keys()):
-        diff = finished - mounts[m]
-        if diff:
-            bad.update(diff)
-            print '#', m, 'not mounted on', ', '.join(diff)
-    return bad
-
-def main(argv):
-    if len(argv) < 1:
-        sys.stderr.write('Usage: check_slaves slaves\n')
-        sys.exit(1)
-    sys.stdin.close()
-    slaves = set()
-    for slave in open(argv[0]):
-        hashPos = slave.find('#')
-        if hashPos >= 0:
-           slave = slave[:hashPos]
-        slave = slave.strip()
-        if not slave: continue
-        slaves.add(slave)
-    bad = set()
-    for test in checkIdentity, checkMemory, checkMounts, checkWritable:
-        bad.update(test(slaves - bad))
-    for slave in sorted(slaves - bad):
-        print slave
-
-main(sys.argv[1:])

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/config.sh
----------------------------------------------------------------------
diff --git a/bin/config.sh b/bin/config.sh
deleted file mode 100755
index 7663473..0000000
--- a/bin/config.sh
+++ /dev/null
@@ -1,177 +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.
-
-# Guarantees that Accumulo and its environment variables are set.
-#
-# Parameters checked by script
-#  ACCUMULO_VERIFY_ONLY set to skip actions that would alter the local filesystem
-#
-# Values set by script that can be user provided.  If not provided script attempts to infer.
-#  ACCUMULO_CONF_DIR  Location where accumulo-env.sh, accumulo-site.xml and friends will be read from
-#  ACCUMULO_HOME      Home directory for Accumulo
-#  ACCUMULO_LOG_DIR   Directory for Accumulo daemon logs
-#  ACCUMULO_VERSION   Accumulo version name
-#  HADOOP_PREFIX      Prefix to the home dir for hadoop.
-#  MONITOR            Machine to run monitor daemon on. Used by start-here.sh script
-#
-# Iff ACCUMULO_VERIFY_ONLY is not set, this script will
-#   * Check for standalone mode (lack of masters and slaves files)
-#     - Do appropriate set up
-#   * Ensure the existence of ACCUMULO_LOG_DIR on the current host
-#   * Ensure the presense of local role files (masters, slaves, gc, tracers)
-#
-# Values always set by script.
-#  SSH                Default ssh parameters used to start daemons
-#  MALLOC_ARENA_MAX   To work around a memory management bug (see ACCUMULO-847)
-#  HADOOP_HOME        Home dir for hadoop.  TODO fix this.
-#
-# Values set by script if certain files exist
-# ACCUMULO_JAAS_CONF  Location of jaas.conf file. Needed by JAAS for things like Kerberos based logins
-# ACCUMULO_KRB5_CONF  Location of krb5.conf file. Needed by Kerberos subsystems to find login servers
-
-if [ -z "${ACCUMULO_HOME}" ] ; then
-  # Start: Resolve Script Directory
-  SOURCE="${BASH_SOURCE[0]}"
-  while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-     bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-     SOURCE="$(readlink "$SOURCE")"
-     [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-  done
-  bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-  script=$( basename "$SOURCE" )
-  # Stop: Resolve Script Directory
-
-  ACCUMULO_HOME=$( cd -P ${bin}/.. && pwd )
-  export ACCUMULO_HOME
-fi
-
-if [ ! -d "${ACCUMULO_HOME}" ]; then
-  echo "ACCUMULO_HOME=${ACCUMULO_HOME} is not a valid directory. Please make sure it exists"
-  exit 1
-fi
-
-ACCUMULO_CONF_DIR="${ACCUMULO_CONF_DIR:-$ACCUMULO_HOME/conf}"
-export ACCUMULO_CONF_DIR
-if [ -z "$ACCUMULO_CONF_DIR" -o ! -d "$ACCUMULO_CONF_DIR" ]
-then
-  echo "ACCUMULO_CONF_DIR=$ACCUMULO_CONF_DIR is not a valid directory.  Please make sure it exists"
-  exit 1
-fi
-
-if [ -f $ACCUMULO_CONF_DIR/accumulo-env.sh ] ; then
-   . $ACCUMULO_CONF_DIR/accumulo-env.sh
-elif [ -z "$ACCUMULO_TEST" ] ; then
-   #
-   # Attempt to bootstrap configuration and continue
-   #
-   echo ""
-   echo "Accumulo is not properly configured."
-   echo ""
-   echo "Try running \$ACCUMULO_HOME/bin/bootstrap_config.sh and then editing"
-   echo "\$ACCUMULO_HOME/conf/accumulo-env.sh"
-   echo ""
-   exit 1
-fi
-
-if [ -z ${ACCUMULO_LOG_DIR} ]; then
-   ACCUMULO_LOG_DIR=$ACCUMULO_HOME/logs
-fi
-
-if [ -z "${ACCUMULO_VERIFY_ONLY}" ] ; then
-  mkdir -p $ACCUMULO_LOG_DIR 2>/dev/null
-fi
-
-export ACCUMULO_LOG_DIR
-
-if [ -z "$HADOOP_PREFIX" ]
-then
-   HADOOP_PREFIX="`which hadoop`"
-   if [ -z "$HADOOP_PREFIX" ]
-   then
-      echo "You must set HADOOP_PREFIX"
-      exit 1
-   fi
-   HADOOP_PREFIX=`dirname $HADOOP_PREFIX`
-   HADOOP_PREFIX=`dirname $HADOOP_PREFIX`
-fi
-if [ ! -d "$HADOOP_PREFIX" ]
-then
-   echo "HADOOP_PREFIX, which has a value of $HADOOP_PREFIX, is not a directory."
-   exit 1
-fi
-export HADOOP_PREFIX
-
-unset MASTER1
-if [[ -f "$ACCUMULO_CONF_DIR/masters" ]]; then
-  MASTER1=$(egrep -v '(^#|^\s*$)' "$ACCUMULO_CONF_DIR/masters" | head -1)
-fi
-
-if [ -z "${MONITOR}" ] ; then
-  MONITOR=$MASTER1
-  if [ -f "$ACCUMULO_CONF_DIR/monitor" ]; then
-      MONITOR=$(egrep -v '(^#|^\s*$)' "$ACCUMULO_CONF_DIR/monitor" | head -1)
-  fi
-  if [ -z "${MONITOR}" ] ; then
-    echo "Could not infer a Monitor role. You need to either define the MONITOR env variable, define \"${ACCUMULO_CONF_DIR}/monitor\", or make sure \"${ACCUMULO_CONF_DIR}/masters\" is non-empty."
-    exit 1
-  fi
-fi
-if [ ! -f "$ACCUMULO_CONF_DIR/tracers" -a -z "${ACCUMULO_VERIFY_ONLY}" ]; then
-  if [ -z "${MASTER1}" ] ; then
-    echo "Could not find a master node to use as a default for the tracer role. Either set up \"${ACCUMULO_CONF_DIR}/tracers\" or make sure \"${ACCUMULO_CONF_DIR}/masters\" is non-empty."
-    exit 1
-  else
-    echo "$MASTER1" > "$ACCUMULO_CONF_DIR/tracers"
-  fi
-
-fi
-
-if [ ! -f "$ACCUMULO_CONF_DIR/gc" -a -z "${ACCUMULO_VERIFY_ONLY}" ]; then
-  if [ -z "${MASTER1}" ] ; then
-    echo "Could not infer a GC role. You need to either set up \"${ACCUMULO_CONF_DIR}/gc\" or make sure \"${ACCUMULO_CONF_DIR}/masters\" is non-empty."
-    exit 1
-  else
-    echo "$MASTER1" > "$ACCUMULO_CONF_DIR/gc"
-  fi
-fi
-
-SSH='ssh -qnf -o ConnectTimeout=2'
-
-export HADOOP_HOME=$HADOOP_PREFIX
-export HADOOP_HOME_WARN_SUPPRESS=true
-
-# See HADOOP-7154 and ACCUMULO-847
-export MALLOC_ARENA_MAX=${MALLOC_ARENA_MAX:-1}
-
-# ACCUMULO-1985 provide a way to use the scripts and still bind to all network interfaces
-export ACCUMULO_MONITOR_BIND_ALL=${ACCUMULO_MONITOR_BIND_ALL:-"false"}
-
-# Check for jaas.conf configuration
-if [ -z ${ACCUMULO_JAAS_CONF} ]; then
-  if [ -f ${ACCUMULO_CONF_DIR}/jaas.conf ]; then
-    export ACCUMULO_JAAS_CONF=${ACCUMULO_CONF_DIR}/jaas.conf
-  fi
-fi
-
-# Check for krb5.conf configuration
-if [ -z ${ACCUMULO_KRB5_CONF} ]; then
-  if [ -f ${ACCUMULO_CONF_DIR}/krb5.conf ]; then
-    export ACCUMULO_KRB5_CONF=${ACCUMULO_CONF_DIR}/krb5.conf
-  fi
-fi
-
-

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/generate_monitor_certificate.sh
----------------------------------------------------------------------
diff --git a/bin/generate_monitor_certificate.sh b/bin/generate_monitor_certificate.sh
deleted file mode 100755
index edd4159..0000000
--- a/bin/generate_monitor_certificate.sh
+++ /dev/null
@@ -1,84 +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.
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-
-ALIAS="default"
-KEYPASS=$(LC_CTYPE=C tr -dc '#-~' < /dev/urandom | tr -d '<>&' | head -c 20)
-STOREPASS=$(LC_CTYPE=C tr -dc '#-~' < /dev/urandom | tr -d '<>&' | head -c 20)
-KEYSTOREPATH="$ACCUMULO_HOME/conf/keystore.jks"
-TRUSTSTOREPATH="$ACCUMULO_HOME/conf/cacerts.jks"
-CERTPATH="$ACCUMULO_HOME/conf/server.cer"
-
-if [ -e "$KEYSTOREPATH" ]; then
-   rm -i $KEYSTOREPATH
-   if [ -e "$KEYSTOREPATH" ]; then
-      echo "KeyStore already exists, exiting"
-      exit 1
-   fi
-fi
-
-if [ -e "$TRUSTSTOREPATH" ]; then
-   rm -i $TRUSTSTOREPATH
-   if [ -e "$TRUSTSTOREPATH" ]; then
-      echo "TrustStore already exists, exiting"
-      exit 2
-   fi
-fi
-
-if [ -e "$CERTPATH" ]; then
-   rm -i $CERTPATH
-   if [ -e "$CERTPATH" ]; then
-      echo "Certificate already exists, exiting"
-      exit 3
-  fi
-fi
-
-${JAVA_HOME}/bin/keytool -genkey -alias $ALIAS -keyalg RSA -keypass $KEYPASS -storepass $KEYPASS -keystore $KEYSTOREPATH
-${JAVA_HOME}/bin/keytool -export -alias $ALIAS -storepass $KEYPASS -file $CERTPATH -keystore $KEYSTOREPATH
-echo "yes" | ${JAVA_HOME}/bin/keytool -import -v -trustcacerts -alias $ALIAS -file $CERTPATH -keystore $TRUSTSTOREPATH -storepass $STOREPASS
-
-echo
-echo "keystore and truststore generated.  now add the following to accumulo-site.xml:"
-echo
-echo "    <property>"
-echo "      <name>monitor.ssl.keyStore</name>"
-echo "      <value>$KEYSTOREPATH</value>"
-echo "    </property>"
-echo "    <property>"
-echo "      <name>monitor.ssl.keyStorePassword</name>"
-echo "      <value>$KEYPASS</value>"
-echo "    </property>"
-echo "    <property>"
-echo "      <name>monitor.ssl.trustStore</name>"
-echo "      <value>$TRUSTSTOREPATH</value>"
-echo "    </property>"
-echo "    <property>"
-echo "      <name>monitor.ssl.trustStorePassword</name>"
-echo "      <value>$STOREPASS</value>"
-echo "    </property>"
-echo

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/start-all.sh
----------------------------------------------------------------------
diff --git a/bin/start-all.sh b/bin/start-all.sh
deleted file mode 100755
index b71ba70..0000000
--- a/bin/start-all.sh
+++ /dev/null
@@ -1,77 +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.
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-unset DISPLAY
-
-if [ ! -f $ACCUMULO_CONF_DIR/accumulo-env.sh ] ; then
-   echo "${ACCUMULO_CONF_DIR}/accumulo-env.sh does not exist. Please make sure you configure Accumulo before you run anything"
-   echo "We provide examples you can copy in ${ACCUMULO_HOME}/conf/examples/ which are set up for your memory footprint"
-   exit 1
-fi
-
-if [ -z "$ZOOKEEPER_HOME" ] ; then
-   echo "ZOOKEEPER_HOME is not set.  Please make sure it's set globally or in conf/accumulo-env.sh"
-   exit 1
-fi
-if [ ! -d $ZOOKEEPER_HOME ]; then
-   echo "ZOOKEEPER_HOME is not a directory: $ZOOKEEPER_HOME"
-   echo "Please check the setting, either globally or in accumulo-env.sh."
-   exit 1
-fi
-
-ZOOKEEPER_VERSION=$(find -L $ZOOKEEPER_HOME -maxdepth 1 -name "zookeeper-[0-9]*.jar" | head -1)
-if [ -z "$ZOOKEEPER_VERSION" ]; then
-   echo "A Zookeeper JAR was not found in $ZOOKEEPER_HOME."
-   echo "Please check ZOOKEEPER_HOME, either globally or in accumulo-env.sh."
-   exit 1
-fi
-ZOOKEEPER_VERSION=${ZOOKEEPER_VERSION##$ZOOKEEPER_HOME/zookeeper-}
-ZOOKEEPER_VERSION=${ZOOKEEPER_VERSION%%.jar}
-
-if [ "$ZOOKEEPER_VERSION" '<' "3.3.0" ]; then
-   echo "WARN : Using Zookeeper $ZOOKEEPER_VERSION.  Use version 3.3.0 or greater to avoid zookeeper deadlock bug.";
-fi
-
-${bin}/start-server.sh $MONITOR monitor 
-
-if [ "$1" != "--notSlaves" ]; then
-   ${bin}/tup.sh
-fi
-
-${bin}/accumulo org.apache.accumulo.master.state.SetGoalState NORMAL
-for master in `egrep -v '(^#|^\s*$)' "$ACCUMULO_CONF_DIR/masters"`; do
-   ${bin}/start-server.sh $master master
-done
-
-for gc in `egrep -v '(^#|^\s*$)' "$ACCUMULO_CONF_DIR/gc"`; do
-   ${bin}/start-server.sh $gc gc "garbage collector"
-done
-
-for tracer in `egrep -v '(^#|^\s*$)' "$ACCUMULO_CONF_DIR/tracers"`; do
-   ${bin}/start-server.sh $tracer tracer
-done

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/start-here.sh
----------------------------------------------------------------------
diff --git a/bin/start-here.sh b/bin/start-here.sh
deleted file mode 100755
index 9abdb38..0000000
--- a/bin/start-here.sh
+++ /dev/null
@@ -1,78 +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.
-
-#
-# This script starts all the accumulo services on this host
-#
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-
-IFCONFIG=/sbin/ifconfig
-if [ ! -x $IFCONFIG ]; then
-   IFCONFIG='/bin/netstat -ie'
-fi
-ip=$($IFCONFIG 2>/dev/null| grep inet[^6] | awk '{print $2}' | sed 's/addr://' | grep -v 0.0.0.0 | grep -v 127.0.0.1 | head -n 1)
-if [ $? != 0 ]; then
-   ip=$(python -c 'import socket as s; print s.gethostbyname(s.getfqdn())')
-fi
-
-HOSTS="$(hostname -a 2> /dev/null) $(hostname) localhost 127.0.0.1 $ip"
-for host in $HOSTS; do
-   if grep -q "^${host}\$" $ACCUMULO_CONF_DIR/slaves; then
-      ${bin}/start-server.sh $host tserver "tablet server"
-      break
-   fi
-done
-
-for host in $HOSTS; do
-   if grep -q "^${host}\$" $ACCUMULO_CONF_DIR/masters; then
-      ${bin}/accumulo org.apache.accumulo.master.state.SetGoalState NORMAL
-      ${bin}/start-server.sh $host master
-      break
-   fi
-done
-
-for host in $HOSTS; do
-   if grep -q "^${host}\$" $ACCUMULO_CONF_DIR/gc; then
-      ${bin}/start-server.sh $host gc "garbage collector"
-      break
-   fi
-done
-
-for host in $HOSTS; do
-   if [ ${host} = "${MONITOR}" ]; then
-      ${bin}/start-server.sh $MONITOR monitor 
-      break
-   fi
-done
-
-for host in $HOSTS; do
-   if grep -q "^${host}\$" $ACCUMULO_CONF_DIR/tracers; then
-      ${bin}/start-server.sh $host tracer 
-      break
-   fi
-done

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/start-server.sh
----------------------------------------------------------------------
diff --git a/bin/start-server.sh b/bin/start-server.sh
deleted file mode 100755
index 62ad91d..0000000
--- a/bin/start-server.sh
+++ /dev/null
@@ -1,87 +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.
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-script=$( basename "$SOURCE" )
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-
-HOST="$1"
-host "$1" >/dev/null 2>/dev/null
-if [ $? -ne 0 ]; then
-   LOGHOST="$1"
-else
-   LOGHOST=$(host "$1" | head -1 | cut -d' ' -f1)
-fi
-ADDRESS="$1"
-SERVICE="$2"
-LONGNAME="$3"
-if [ -z "$LONGNAME" ]; then
-   LONGNAME="$2"
-fi
-SLAVES=$( wc -l < ${ACCUMULO_CONF_DIR}/slaves )
-
-IFCONFIG=/sbin/ifconfig
-if [ ! -x $IFCONFIG ]; then
-   IFCONFIG='/bin/netstat -ie'
-fi
-
-# ACCUMULO-1985 Allow monitor to bind on all interfaces
-if [ ${SERVICE} == "monitor" -a ${ACCUMULO_MONITOR_BIND_ALL} == "true" ]; then
-    ADDRESS="0.0.0.0"
-fi
-
-ip=$($IFCONFIG 2>/dev/null| grep inet[^6] | awk '{print $2}' | sed 's/addr://' | grep -v 0.0.0.0 | grep -v 127.0.0.1 | head -n 1)
-if [ $? != 0 ]
-then
-   ip=$(python -c 'import socket as s; print s.gethostbyname(s.getfqdn())')
-fi
-
-if [ "$HOST" = "localhost" -o "$HOST" = "`hostname`" -o "$HOST" = "$ip" ]; then
-   PID=$(ps -ef | egrep ${ACCUMULO_HOME}/.*/accumulo.*.jar | grep "Main $SERVICE" | grep -v grep | awk {'print $2'} | head -1)
-else
-   PID=$($SSH $HOST ps -ef | egrep ${ACCUMULO_HOME}/.*/accumulo.*.jar | grep "Main $SERVICE" | grep -v grep | awk {'print $2'} | head -1)
-fi
-
-if [ -z "$PID" ]; then
-   echo "Starting $LONGNAME on $HOST"
-   if [ "$HOST" = "localhost" -o "$HOST" = "`hostname`" -o "$HOST" = "$ip" ]; then
-      ${bin}/accumulo ${SERVICE} --address ${ADDRESS} >${ACCUMULO_LOG_DIR}/${SERVICE}_${LOGHOST}.out 2>${ACCUMULO_LOG_DIR}/${SERVICE}_${LOGHOST}.err & 
-      MAX_FILES_OPEN=$(ulimit -n)
-   else
-      $SSH $HOST "bash -c 'exec nohup ${bin}/accumulo ${SERVICE} --address ${ADDRESS} >${ACCUMULO_LOG_DIR}/${SERVICE}_${LOGHOST}.out 2>${ACCUMULO_LOG_DIR}/${SERVICE}_${LOGHOST}.err' &"
-      MAX_FILES_OPEN=$($SSH $HOST "/usr/bin/env bash -c 'ulimit -n'") 
-   fi
-
-   if [ -n "$MAX_FILES_OPEN" ] && [ -n "$SLAVES" ] ; then
-      MAX_FILES_RECOMMENDED=${MAX_FILES_RECOMMENDED:-32768}
-      if (( SLAVES > 10 )) && (( MAX_FILES_OPEN < MAX_FILES_RECOMMENDED ))
-      then
-         echo "WARN : Max open files on $HOST is $MAX_FILES_OPEN, recommend $MAX_FILES_RECOMMENDED" >&2
-      fi
-   fi
-else
-   echo "$HOST : $LONGNAME already running (${PID})"
-fi

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/stop-all.sh
----------------------------------------------------------------------
diff --git a/bin/stop-all.sh b/bin/stop-all.sh
deleted file mode 100755
index 3bd30bd..0000000
--- a/bin/stop-all.sh
+++ /dev/null
@@ -1,68 +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.
-
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-
-echo "Stopping accumulo services..."
-${bin}/accumulo admin "$@" stopAll
-
-if [ $? -ne 0 ]; then
-   echo "Invalid password or unable to connect to the master"
-   echo "Initiating forced shutdown in 15 seconds (Ctrl-C to abort)"
-   sleep 10
-   echo "Initiating forced shutdown in  5 seconds (Ctrl-C to abort)"
-else
-   echo "Accumulo shut down cleanly"
-   echo "Utilities and unresponsive servers will shut down in 5 seconds (Ctrl-C to abort)"
-fi
-
-sleep 5
-
-#look for master and gc processes not killed by 'admin stopAll'
-for signal in TERM KILL ; do
-   for master in `grep -v '^#' "$ACCUMULO_CONF_DIR/masters"`; do
-      ${bin}/stop-server.sh $master "$ACCUMULO_HOME/lib/accumulo-start.*.jar" master $signal
-   done
-
-   for gc in `grep -v '^#' "$ACCUMULO_CONF_DIR/gc"`; do
-      ${bin}/stop-server.sh "$gc" "$ACCUMULO_HOME/lib/accumulo-start.*.jar" gc $signal
-   done
-
-   ${bin}/stop-server.sh "$MONITOR" "$ACCUMULO_HOME/.*/accumulo-start.*.jar" monitor $signal
-
-   for tracer in `egrep -v '(^#|^\s*$)' "$ACCUMULO_CONF_DIR/tracers"`; do
-      ${bin}/stop-server.sh $tracer "$ACCUMULO_HOME/.*/accumulo-start.*.jar" tracer $signal
-   done
-done
-
-# stop tserver still running
-${bin}/tdown.sh
-
-echo "Cleaning all server entries in ZooKeeper"
-$ACCUMULO_HOME/bin/accumulo org.apache.accumulo.server.util.ZooZap -master -tservers -tracers
-

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/stop-here.sh
----------------------------------------------------------------------
diff --git a/bin/stop-here.sh b/bin/stop-here.sh
deleted file mode 100755
index 4d5533a..0000000
--- a/bin/stop-here.sh
+++ /dev/null
@@ -1,60 +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.
-
-#
-# This script safely stops all the accumulo services on this host
-#
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-
-ACCUMULO="$ACCUMULO_HOME/lib/accumulo-start.jar"
-
-# Determine hostname without errors to user
-HOSTNAME=$(hostname -a 2> /dev/null | head -1)
-if [ -z ${HOSTNAME} ]; then
-   HOSTNAME=$(hostname)
-fi
-
-if egrep -q localhost\|127.0.0.1 $ACCUMULO_CONF_DIR/slaves; then
-   $bin/accumulo admin stop localhost
-else
-   for host in "$(hostname -a 2> /dev/null) $(hostname)"; do
-      if grep -q ${host} $ACCUMULO_CONF_DIR/slaves; then
-         ${bin}/accumulo admin stop $host
-      fi
-   done
-fi
-
-for signal in TERM KILL; do
-   for svc in tserver gc master monitor logger tracer; do
-      PID=$(ps -ef | egrep ${ACCUMULO} | grep "Main $svc" | grep -v grep | grep -v stop-here.sh | awk '{print $2}' | head -1)
-      if [ ! -z $PID ]; then
-         echo "Stopping ${svc} on ${HOSTNAME} with signal ${signal}"
-         kill -s ${signal} ${PID}
-      fi
-   done
-done

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/stop-server.sh
----------------------------------------------------------------------
diff --git a/bin/stop-server.sh b/bin/stop-server.sh
deleted file mode 100755
index 6fbe0af..0000000
--- a/bin/stop-server.sh
+++ /dev/null
@@ -1,56 +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.
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-
-HOST=$1
-
-IFCONFIG=/sbin/ifconfig
-if [ ! -x $IFCONFIG ]
-then
-   IFCONFIG='/bin/netstat -ie'
-fi
-ip=$($IFCONFIG 2>/dev/null| grep inet[^6] | awk '{print $2}' | sed 's/addr://' | grep -v 0.0.0.0 | grep -v 127.0.0.1 | head -n 1)
-if [ $? != 0 ]
-then
-   ip=$(python -c 'import socket as s; print s.gethostbyname(s.getfqdn())')
-fi
-
-# only stop if there's not one already running
-if [ "$HOST" = "localhost" -o "$HOST" = "`hostname`" -o "$HOST" = "$ip" ]; then
-   PID=$(ps -ef | grep "$ACCUMULO_HOME" | egrep ${2} | grep "Main ${3}" | grep -v grep | grep -v ssh | grep -v stop-server.sh | awk {'print $2'} | head -1)
-   if [ ! -z $PID ]; then
-      echo "Stopping ${3} on $1";
-      kill -s ${4} ${PID} 2>/dev/null
-   fi;
-else
-   PID=$(ssh -q -o 'ConnectTimeout 8' $1 "ps -ef | grep \"$ACCUMULO_HOME\" |  egrep '${2}' | grep 'Main ${3}' | grep -v grep | grep -v ssh | grep -v stop-server.sh" | awk {'print $2'} | head -1)
-   if [ ! -z $PID ]; then
-      echo "Stopping ${3} on $1";
-      ssh -q -o 'ConnectTimeout 8' $1 "kill -s ${4} ${PID} 2>/dev/null"
-   fi;
-fi

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/tdown.sh
----------------------------------------------------------------------
diff --git a/bin/tdown.sh b/bin/tdown.sh
deleted file mode 100755
index 141ad24..0000000
--- a/bin/tdown.sh
+++ /dev/null
@@ -1,49 +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.
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-
-HADOOP_CMD=$HADOOP_PREFIX/bin/hadoop
-SLAVES=$ACCUMULO_CONF_DIR/slaves
-SLAVE_HOSTS=$(egrep -v '(^#|^\s*$)' "${SLAVES}")
-
-echo "Stopping unresponsive tablet servers (if any)..."
-for server in ${SLAVE_HOSTS}; do
-   # only start if there's not one already running
-   $ACCUMULO_HOME/bin/stop-server.sh $server "$ACCUMULO_HOME/lib/accumulo-start.jar" tserver TERM & 
-done
-
-sleep 10
-
-echo "Stopping unresponsive tablet servers hard (if any)..."
-for server in ${SLAVE_HOSTS}; do
-   # only start if there's not one already running
-   $ACCUMULO_HOME/bin/stop-server.sh $server "$ACCUMULO_HOME/lib/accumulo-start.jar" tserver KILL & 
-done
-
-echo "Cleaning tablet server entries from zookeeper"
-$ACCUMULO_HOME/bin/accumulo org.apache.accumulo.server.util.ZooZap -tservers

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/tool.sh
----------------------------------------------------------------------
diff --git a/bin/tool.sh b/bin/tool.sh
deleted file mode 100755
index 376983f..0000000
--- a/bin/tool.sh
+++ /dev/null
@@ -1,92 +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.
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-
-if [ -z "$HADOOP_PREFIX" ] ; then
-   echo "HADOOP_PREFIX is not set.  Please make sure it's set globally or in conf/accumulo-env.sh"
-   exit 1
-fi
-if [ -z "$ZOOKEEPER_HOME" ] ; then
-   echo "ZOOKEEPER_HOME is not set.  Please make sure it's set globally or in conf/accumulo-env.sh"
-   exit 1
-fi
-
-ZOOKEEPER_CMD='ls -1 $ZOOKEEPER_HOME/zookeeper-[0-9]*[^csn].jar '
-if [ `eval $ZOOKEEPER_CMD | wc -l` != "1" ] ; then
-   echo "Not exactly one zookeeper jar in $ZOOKEEPER_HOME"
-   exit 1
-fi
-ZOOKEEPER_LIB=$(eval $ZOOKEEPER_CMD)
-
-LIB="$ACCUMULO_HOME/lib"
-CORE_LIB="$LIB/accumulo-core.jar"
-FATE_LIB="$LIB/accumulo-fate.jar"
-THRIFT_LIB="$LIB/libthrift.jar"
-TRACE_LIB="$LIB/accumulo-trace.jar"
-JCOMMANDER_LIB="$LIB/jcommander.jar"
-COMMONS_VFS_LIB="$LIB/commons-vfs2.jar"
-GUAVA_LIB="$LIB/guava.jar"
-
-USERJARS=" "
-for arg in "$@"; do
-    if [ "$arg" != "-libjars" -a -z "$TOOLJAR" ]; then
-      TOOLJAR="$arg"
-      shift
-   elif [ "$arg" != "-libjars" -a -z "$CLASSNAME" ]; then
-      CLASSNAME="$arg"
-      shift
-   elif [ -z "$USERJARS" ]; then
-      USERJARS=$(echo "$arg" | tr "," " ")
-      shift
-   elif [ "$arg" = "-libjars" ]; then
-      USERJARS=""
-      shift
-   else
-      break
-   fi
-done
-
-LIB_JARS="$THRIFT_LIB,$CORE_LIB,$FATE_LIB,$ZOOKEEPER_LIB,$TRACE_LIB,$JCOMMANDER_LIB,$COMMONS_VFS_LIB,$GUAVA_LIB"
-H_JARS="$THRIFT_LIB:$CORE_LIB:$FATE_LIB:$ZOOKEEPER_LIB:$TRACE_LIB:$JCOMMANDER_LIB:$COMMONS_VFS_LIB:$GUAVA_LIB"
-
-for jar in $USERJARS; do
-   LIB_JARS="$LIB_JARS,$jar"
-   H_JARS="$H_JARS:$jar"
-done
-export HADOOP_CLASSPATH="$H_JARS:$HADOOP_CLASSPATH"
-
-if [ -z "$CLASSNAME" -o -z "$TOOLJAR" ]; then
-   echo "Usage: tool.sh path/to/myTool.jar my.tool.class.Name [-libjars my1.jar,my2.jar]" 1>&2
-   exit 1
-fi
-
-#echo USERJARS=$USERJARS
-#echo CLASSNAME=$CLASSNAME
-#echo HADOOP_CLASSPATH=$HADOOP_CLASSPATH
-#echo exec "$HADOOP_PREFIX/bin/hadoop" jar "$TOOLJAR" $CLASSNAME -libjars \"$LIB_JARS\" $ARGS
-exec "$HADOOP_PREFIX/bin/hadoop" jar "$TOOLJAR" $CLASSNAME -libjars \"$LIB_JARS\" "$@"

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/bin/tup.sh
----------------------------------------------------------------------
diff --git a/bin/tup.sh b/bin/tup.sh
deleted file mode 100755
index b26def5..0000000
--- a/bin/tup.sh
+++ /dev/null
@@ -1,46 +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.
-
-# Start: Resolve Script Directory
-SOURCE="${BASH_SOURCE[0]}"
-while [ -h "$SOURCE" ]; do # resolve $SOURCE until the file is no longer a symlink
-   bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-   SOURCE="$(readlink "$SOURCE")"
-   [[ $SOURCE != /* ]] && SOURCE="$bin/$SOURCE" # if $SOURCE was a relative symlink, we need to resolve it relative to the path where the symlink file was located
-done
-bin="$( cd -P "$( dirname "$SOURCE" )" && pwd )"
-# Stop: Resolve Script Directory
-
-. "$bin"/config.sh
-
-SLAVES=$ACCUMULO_CONF_DIR/slaves
-
-echo -n "Starting tablet servers ..."
-
-count=1
-for server in `egrep -v '(^#|^\s*$)' "${SLAVES}"`; do
-   echo -n "."
-   ${bin}/start-server.sh $server tserver "tablet server" &
-   let count++
-   if [ $(( ${count} % 72 )) -eq 0 ] ;
-   then
-      echo
-      wait
-   fi
-done
-
-echo " done"

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/accumulo.policy.example
----------------------------------------------------------------------
diff --git a/conf/accumulo.policy.example b/conf/accumulo.policy.example
deleted file mode 100644
index 2964f06..0000000
--- a/conf/accumulo.policy.example
+++ /dev/null
@@ -1,143 +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.
- */
-
-grant codeBase "file:${java.home}/lib/ext/*" {
-  permission java.security.AllPermission;
-};
-
-// These should all be empty in a fielded system
-grant codeBase "file:${org.apache.accumulo.core.home.dir}/src/server/target/classes/" {
-  permission java.security.AllPermission;
-};
-grant codeBase "file:${org.apache.accumulo.core.home.dir}/src/core/target/classes/" {
-  permission java.security.AllPermission;
-};
-grant codeBase "file:${org.apache.accumulo.core.home.dir}/src/start/target/classes/" {
-  permission java.security.AllPermission;
-};
-grant codeBase "file:${org.apache.accumulo.core.home.dir}/src/examples/target/classes/" {
-  permission java.security.AllPermission;
-};
-
-grant codebase "file:${hadoop.home.dir}/*" {
-  permission java.lang.reflect.ReflectPermission "suppressAccessChecks";
-  permission java.lang.RuntimePermission "shutdownHooks"; // hadoop libs use executables to discover usernames, groups, etc.
-  permission java.lang.RuntimePermission "loadLibrary.*";
-  permission java.io.FilePermission "<<ALL FILES>>", "read, execute";
-  permission java.io.FilePermission "/tmp", "write, delete";
-  permission java.io.FilePermission "/tmp/-", "write, delete";
-  permission java.io.FilePermission "/", "write";
-  permission java.net.SocketPermission "*", "connect, resolve";
-  permission java.util.PropertyPermission "java.library.path", "read";
-  permission java.util.PropertyPermission "user.dir", "read";
-  permission java.util.PropertyPermission "org.apache.commons.logging.*", "read";
-  permission java.util.PropertyPermission "entityExpansionLimit", "read";
-  permission java.util.PropertyPermission "maxOccurLimit", "read";
-  permission java.util.PropertyPermission "os.name", "read";
-};
-
-grant codebase "file:${hadoop.home.dir}/lib/*" {
-  // monitor's jetty web service
-  permission java.security.SecurityPermission "configurationPermission";
-  permission java.security.SecurityPermission "tablesPermission";
-  permission java.security.SecurityPermission "zookeeperWriterPermission";
-  permission java.security.SecurityPermission "tableManagerPermission";
-  permission java.security.SecurityPermission "transportPoolPermission";
-  permission java.security.SecurityPermission "systemCredentialsPermission";
-  permission java.lang.reflect.ReflectPermission "suppressAccessChecks";
-  // need to accept web requests, and talk to job tracker, name node, etc.
-  permission java.net.SocketPermission "*", "accept, listen, resolve, connect, resolve";
-  permission java.lang.RuntimePermission "getenv.*";
-  permission java.lang.RuntimePermission "loadLibrary.*";
-  permission java.util.PropertyPermission "org.mortbay.*", "read";
-  permission java.util.PropertyPermission "VERBOSE", "read";
-  permission java.util.PropertyPermission "IGNORED", "read";
-  permission java.util.PropertyPermission "ISO_8859_1", "read";
-  permission java.util.PropertyPermission "org.apache.commons.logging.*", "read";
-  permission java.util.PropertyPermission "accumulo.*", "read";
-  permission java.util.PropertyPermission "org.jfree.*", "read";
-  permission java.util.PropertyPermission "elementAttributeLimit", "read";
-  permission java.util.PropertyPermission "entityExpansionLimit", "read";
-  permission java.util.PropertyPermission "maxOccurLimit", "read";
-  // some resources come out of accumulo jars
-  permission java.lang.RuntimePermission "getClassLoader";
-  permission java.io.FilePermission "${org.apache.accumulo.core.home.dir}/lib/*", "read";
-  permission java.io.FilePermission "${org.apache.accumulo.core.home.dir}/src/-", "read";
-  permission java.io.FilePermission "${hadoop.home.dir}/lib/*", "read";
-  // images are cached in /tmp
-  permission java.io.FilePermission "/tmp/*", "read, write";
-  permission java.io.FilePermission "/", "write";
-};
-
-grant codebase "file:${zookeeper.home.dir}/*" {
-  permission java.net.SocketPermission "*", "connect, resolve";
-  permission java.util.PropertyPermission "user.*", "read";
-  permission java.util.PropertyPermission "java.*", "read";
-  permission java.util.PropertyPermission "zookeeper.*", "read";
-  permission java.util.PropertyPermission "jute.*", "read";
-  permission java.util.PropertyPermission "os.*", "read";
-  // accumulo properties read in callbacks
-  permission java.util.PropertyPermission "accumulo.*", "read";
-  permission java.security.SecurityPermission "configurationPermission";
-  permission java.security.SecurityPermission "tablesPermission";
-  permission java.security.SecurityPermission "zookeeperWriterPermission";
-  permission java.security.SecurityPermission "tableManagerPermission";
-  permission java.security.SecurityPermission "transportPoolPermission";
-  permission java.security.SecurityPermission "systemCredentialsPermission";
-  permission java.lang.reflect.ReflectPermission "suppressAccessChecks";
-  permission java.lang.RuntimePermission "exitVM";
-};
-
-grant codebase "file:${org.apache.accumulo.core.home.dir}/lib/ext/*" {
-};
-
-grant codebase "file:${org.apache.accumulo.core.home.dir}/lib/*" {
-  permission java.lang.reflect.ReflectPermission "suppressAccessChecks";
-  // logging, configuration and getting user id
-  permission java.io.FilePermission "<<ALL FILES>>", "read, write, execute, delete";
-  permission java.util.PropertyPermission "*", "read, write";
-  permission java.lang.RuntimePermission "getenv.*";
-  permission java.lang.RuntimePermission "getClassLoader";
-  permission java.lang.RuntimePermission "loadLibrary.*";
-  permission java.lang.RuntimePermission "accessDeclaredMembers";
-  permission java.lang.RuntimePermission "selectorProvider";
-  permission java.lang.RuntimePermission "accessClassInPackage.*";
-  permission java.lang.RuntimePermission "readFileDescriptor";
-  permission java.lang.RuntimePermission "writeFileDescriptor";
-  permission java.lang.RuntimePermission "modifyThread";
-  permission java.lang.RuntimePermission "modifyThreadGroup";
-  permission java.lang.RuntimePermission "createClassLoader";
-  permission java.lang.RuntimePermission "setContextClassLoader";
-  permission java.lang.RuntimePermission "exitVM";
-  permission java.lang.RuntimePermission "shutdownHooks";
-  permission java.security.SecurityPermission "getPolicy";
-  permission java.security.SecurityPermission "getProperty.*";
-  permission java.security.SecurityPermission "putProviderProperty.*";
-  permission java.security.SecurityPermission "setSystemScope";
-  permission java.security.SecurityPermission "configurationPermission";
-  permission java.security.SecurityPermission "tablesPermission";
-  permission java.security.SecurityPermission "zookeeperWriterPermission";
-  permission java.security.SecurityPermission "tableManagerPermission";
-  permission java.security.SecurityPermission "transportPoolPermission";
-  permission java.security.SecurityPermission "systemCredentialsPermission";
-  permission java.util.logging.LoggingPermission "control";
-  permission java.net.NetPermission "getProxySelector";
-  permission javax.management.MBeanServerPermission "createMBeanServer";
-  permission javax.management.MBeanTrustPermission "register";
-  permission javax.management.MBeanPermission "*", "registerMBean";
-  permission java.net.SocketPermission "*", "accept, connect, listen, resolve";
-};

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/accumulo-env.sh
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/accumulo-env.sh b/conf/examples/1GB/native-standalone/accumulo-env.sh
deleted file mode 100755
index 9e9b6a6..0000000
--- a/conf/examples/1GB/native-standalone/accumulo-env.sh
+++ /dev/null
@@ -1,66 +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.
-
-###
-### Configure these environment variables to point to your local installations.
-###
-### The functional tests require conditional values, so keep this style:
-###
-### test -z "$JAVA_HOME" && export JAVA_HOME=/usr/local/lib/jdk-1.6.0
-###
-###
-### Note that the -Xmx -Xms settings below require substantial free memory: 
-### you may want to use smaller values, especially when running everything
-### on a single machine.
-###
-if [ -z "$HADOOP_HOME" ]
-then
-   test -z "$HADOOP_PREFIX"      && export HADOOP_PREFIX=/path/to/hadoop
-else
-   HADOOP_PREFIX="$HADOOP_HOME"
-   unset HADOOP_HOME
-fi
-
-# hadoop-1.2:
-#test -z "$HADOOP_CONF_DIR"       && export HADOOP_CONF_DIR="$HADOOP_PREFIX/conf"
-test -z "$HADOOP_CONF_DIR"     && export HADOOP_CONF_DIR="$HADOOP_PREFIX/etc/hadoop"
-
-
-test -z "$JAVA_HOME"             && export JAVA_HOME=/path/to/java
-test -z "$ZOOKEEPER_HOME"        && export ZOOKEEPER_HOME=/path/to/zookeeper
-test -z "$ACCUMULO_LOG_DIR"      && export ACCUMULO_LOG_DIR=$ACCUMULO_HOME/logs
-if [ -f ${ACCUMULO_CONF_DIR}/accumulo.policy ]
-then
-   POLICY="-Djava.security.manager -Djava.security.policy=${ACCUMULO_CONF_DIR}/accumulo.policy"
-fi
-test -z "$ACCUMULO_TSERVER_OPTS" && export ACCUMULO_TSERVER_OPTS="${POLICY} -Xmx128m -Xms128m "
-test -z "$ACCUMULO_MASTER_OPTS"  && export ACCUMULO_MASTER_OPTS="${POLICY} -Xmx128m -Xms128m"
-test -z "$ACCUMULO_MONITOR_OPTS" && export ACCUMULO_MONITOR_OPTS="${POLICY} -Xmx64m -Xms64m" 
-test -z "$ACCUMULO_GC_OPTS"      && export ACCUMULO_GC_OPTS="-Xmx64m -Xms64m"
-test -z "$ACCUMULO_GENERAL_OPTS" && export ACCUMULO_GENERAL_OPTS="-XX:+UseConcMarkSweepGC -XX:CMSInitiatingOccupancyFraction=75 -Djava.net.preferIPv4Stack=true"
-test -z "$ACCUMULO_OTHER_OPTS"   && export ACCUMULO_OTHER_OPTS="-Xmx128m -Xms64m"
-# what do when the JVM runs out of heap memory
-export ACCUMULO_KILL_CMD='kill -9 %p'
-
-### Optionally look for hadoop and accumulo native libraries for your
-### platform in additional directories. (Use DYLD_LIBRARY_PATH on Mac OS X.)
-### May not be necessary for Hadoop 2.x or using an RPM that installs to
-### the correct system library directory.
-# export LD_LIBRARY_PATH=${HADOOP_PREFIX}/lib/native/${PLATFORM}:${LD_LIBRARY_PATH}
-
-# Should the monitor bind to all network interfaces -- default: false
-# export ACCUMULO_MONITOR_BIND_ALL="true"

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/accumulo-metrics.xml
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/accumulo-metrics.xml b/conf/examples/1GB/native-standalone/accumulo-metrics.xml
deleted file mode 100644
index 60f9f8d..0000000
--- a/conf/examples/1GB/native-standalone/accumulo-metrics.xml
+++ /dev/null
@@ -1,60 +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.
--->
-<!--
-  This file follows the conventions for XMLConfiguration files specified in the Apache Commons Configuration 1.5 Library. Changes to this file will be noticed
-  at runtime (see the FileChangedReloadingStrategy class in Commons Configuration).
--->
-<config>
-<!--
-   Metrics log directory
--->
-  <logging>
-    <dir>${ACCUMULO_HOME}/metrics</dir>
-  </logging>
-<!--
- Enable/Disable metrics accumulation on the different servers and their components
- NOTE: Turning on logging can be expensive because it will use several more file handles and will create a lot of short lived objects.
--->
-  <master>
-    <enabled type="boolean">false</enabled>
-    <logging type="boolean">false</logging>
-  </master>
-  <logger>
-    <enabled type="boolean">false</enabled>
-    <logging type="boolean">false</logging>
-  </logger>
-  <tserver>
-    <enabled type="boolean">false</enabled>
-    <logging type="boolean">false</logging>
-    <update>
-      <enabled type="boolean">false</enabled>
-      <logging type="boolean">false</logging>
-    </update>
-    <scan>
-      <enabled type="boolean">false</enabled>
-      <logging type="boolean">false</logging>
-    </scan>
-    <minc>
-      <enabled type="boolean">false</enabled>
-      <logging type="boolean">false</logging>
-    </minc>
-  </tserver>
-  <thrift>
-    <enabled type="boolean">false</enabled>
-    <logging type="boolean">false</logging>
-  </thrift>
-</config>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/accumulo-site.xml
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/accumulo-site.xml b/conf/examples/1GB/native-standalone/accumulo-site.xml
deleted file mode 100644
index cc06eea..0000000
--- a/conf/examples/1GB/native-standalone/accumulo-site.xml
+++ /dev/null
@@ -1,122 +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.
--->
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-
-<configuration>
-  <!-- Put your site-specific accumulo configurations here. The available configuration values along with their defaults are documented in docs/config.html Unless 
-    you are simply testing at your workstation, you will most definitely need to change the three entries below. -->
-
-  <property>
-    <name>instance.zookeeper.host</name>
-    <value>localhost:2181</value>
-    <description>comma separated list of zookeeper servers</description>
-  </property>
-
-  <property>
-    <name>logger.dir.walog</name>
-    <value>walogs</value>
-    <description>The property only needs to be set if upgrading from 1.4 which used to store write-ahead logs on the local 
-      filesystem. In 1.5 write-ahead logs are stored in DFS.  When 1.5 is started for the first time it will copy any 1.4 
-      write ahead logs into DFS.  It is possible to specify a comma-separated list of directories.
-    </description>
-  </property>
-
-  <property>
-    <name>instance.secret</name>
-    <value>DEFAULT</value>
-    <description>A secret unique to a given instance that all servers must know in order to communicate with one another.
-      Change it before initialization. To
-      change it later use ./bin/accumulo org.apache.accumulo.server.util.ChangeSecret --old [oldpasswd] --new [newpasswd],
-      and then update this file.
-    </description>
-  </property>
-
-  <property>
-    <name>tserver.memory.maps.max</name>
-    <value>256M</value>
-  </property>
-
-  <property>
-    <name>tserver.cache.data.size</name>
-    <value>15M</value>
-  </property>
-
-  <property>
-    <name>tserver.cache.index.size</name>
-    <value>40M</value>
-  </property>
-
-  <property>
-    <name>trace.token.property.password</name>
-    <!-- change this to the root user's password, and/or change the user below -->
-    <value>secret</value>
-  </property>
-
-  <property>
-    <name>trace.user</name>
-    <value>root</value>
-  </property>
-
-  <property>
-    <name>tserver.sort.buffer.size</name>
-    <value>50M</value>
-  </property>
-
-  <property>
-    <name>tserver.walog.max.size</name>
-    <value>256M</value>
-  </property>
-
-  <property>
-    <name>tserver.walog.max.size</name>
-    <value>100M</value>
-  </property>
-
-  <property>
-    <name>general.maven.project.basedir</name>
-    <value></value>
-  </property>
-
-  <property>
-    <name>general.classpaths</name>
-    <value>
-      $ACCUMULO_HOME/lib/accumulo-server.jar,
-      $ACCUMULO_HOME/lib/accumulo-core.jar,
-      $ACCUMULO_HOME/lib/accumulo-start.jar,
-      $ACCUMULO_HOME/lib/accumulo-fate.jar,
-      $ACCUMULO_HOME/lib/accumulo-proxy.jar,
-      $ACCUMULO_HOME/lib/[^.].*.jar,
-      $ZOOKEEPER_HOME/zookeeper[^.].*.jar,
-      $HADOOP_CONF_DIR,
-      $HADOOP_PREFIX/[^.].*.jar,
-      $HADOOP_PREFIX/lib/[^.].*.jar,
-      <!-- Comment the following for hadoop-1 -->
-      $HADOOP_PREFIX/share/hadoop/common/.*.jar,
-      $HADOOP_PREFIX/share/hadoop/common/lib/(?!slf4j)[^.].*.jar,
-      $HADOOP_PREFIX/share/hadoop/hdfs/.*.jar,
-      $HADOOP_PREFIX/share/hadoop/mapreduce/.*.jar,
-      $HADOOP_PREFIX/share/hadoop/yarn/.*.jar,
-      /usr/lib/hadoop/.*.jar,
-      /usr/lib/hadoop/lib/.*.jar,
-      /usr/lib/hadoop-hdfs/.*.jar,
-      /usr/lib/hadoop-mapreduce/.*.jar,
-      /usr/lib/hadoop-yarn/.*.jar,
-    </value>
-    <description>Classpaths that accumulo checks for updates and class files.</description>
-  </property>
-</configuration>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/auditLog.xml
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/auditLog.xml b/conf/examples/1GB/native-standalone/auditLog.xml
deleted file mode 100644
index 9b7987e..0000000
--- a/conf/examples/1GB/native-standalone/auditLog.xml
+++ /dev/null
@@ -1,41 +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.
--->
-<!DOCTYPE log4j:configuration SYSTEM "log4j.dtd">
-<log4j:configuration xmlns:log4j="http://jakarta.apache.org/log4j/">
-
-
-
-    <!--  Write out Audit info to an Audit file -->
-    <appender name="Audit" class="org.apache.log4j.DailyRollingFileAppender">
-        <param name="File"           value="${org.apache.accumulo.core.dir.log}/${org.apache.accumulo.core.ip.localhost.hostname}.audit"/>
-        <param name="MaxBackupIndex" value="10"/>
-        <param name="DatePattern" value="'.'yyyy-MM-dd"/>
-        <layout class="org.apache.log4j.PatternLayout">
-            <param name="ConversionPattern" value="%d{yyyy-MM-dd HH:mm:ss,SSS/Z} [%c{2}] %-5p: %m%n"/>
-        </layout>
-    </appender>
-    <logger name="Audit"  additivity="false">
-        <appender-ref ref="Audit" />
-        <level value="OFF"/>
-    </logger>
-
-
-
-
-
-</log4j:configuration>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/gc
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/gc b/conf/examples/1GB/native-standalone/gc
deleted file mode 100644
index 63fb8bb..0000000
--- a/conf/examples/1GB/native-standalone/gc
+++ /dev/null
@@ -1,16 +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.
-
-localhost

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/generic_logger.xml
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/generic_logger.xml b/conf/examples/1GB/native-standalone/generic_logger.xml
deleted file mode 100644
index 4d2af90..0000000
--- a/conf/examples/1GB/native-standalone/generic_logger.xml
+++ /dev/null
@@ -1,83 +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.
--->
-<!DOCTYPE log4j:configuration SYSTEM "log4j.dtd">
-<log4j:configuration xmlns:log4j="http://jakarta.apache.org/log4j/">
-
-  <!-- Write out everything at the DEBUG level to the debug log -->
-  <appender name="A2" class="org.apache.log4j.RollingFileAppender">
-     <param name="File"           value="${org.apache.accumulo.core.dir.log}/${org.apache.accumulo.core.application}_${org.apache.accumulo.core.ip.localhost.hostname}.debug.log"/>
-     <param name="MaxFileSize"    value="1000MB"/>
-     <param name="MaxBackupIndex" value="10"/>
-     <param name="Threshold"      value="DEBUG"/>
-     <layout class="org.apache.log4j.PatternLayout">
-       <param name="ConversionPattern" value="%d{ISO8601} [%-8c{2}] %-5p: %m%n"/>
-     </layout>	    
-  </appender>
-
-  <!--  Write out INFO and higher to the regular log -->
-  <appender name="A3" class="org.apache.log4j.RollingFileAppender">
-     <param name="File"           value="${org.apache.accumulo.core.dir.log}/${org.apache.accumulo.core.application}_${org.apache.accumulo.core.ip.localhost.hostname}.log"/>
-     <param name="MaxFileSize"    value="1000MB"/>
-     <param name="MaxBackupIndex" value="10"/>
-     <param name="Threshold"      value="INFO"/>
-     <layout class="org.apache.log4j.PatternLayout">
-       <param name="ConversionPattern" value="%d{ISO8601} [%-8c{2}] %-5p: %m%n"/>
-     </layout>	    
-  </appender>
-
-  <!-- Send all logging data to a centralized logger -->
-  <appender name="N1" class="org.apache.log4j.net.SocketAppender">
-     <param name="remoteHost"     value="${org.apache.accumulo.core.host.log}"/>
-     <param name="port"           value="${org.apache.accumulo.core.host.log.port}"/>
-     <param name="application"    value="${org.apache.accumulo.core.application}:${org.apache.accumulo.core.ip.localhost.hostname}"/>
-     <param name="Threshold"      value="WARN"/>
-  </appender>
-
-  <!--  If the centralized logger is down, buffer the log events, but drop them if it stays down -->
-  <appender name="ASYNC" class="org.apache.log4j.AsyncAppender">
-     <appender-ref ref="N1" />
-  </appender>
-
-  <!-- Log accumulo events to the debug, normal and remote logs. -->
-  <logger name="org.apache.accumulo" additivity="false">
-     <level value="DEBUG"/>
-     <appender-ref ref="A2" />
-     <appender-ref ref="A3" />
-     <appender-ref ref="ASYNC" />
-  </logger>
-
-  <logger name="org.apache.accumulo.core.file.rfile.bcfile">
-     <level value="INFO"/>
-  </logger>
-
-  <logger name="org.mortbay.log">
-     <level value="WARN"/>
-  </logger>
-
-  <logger name="org.apache.zookeeper">
-     <level value="ERROR"/>
-  </logger>
-
-  <!-- Log non-accumulo events to the debug and normal logs. -->
-  <root>
-     <level value="INFO"/>
-     <appender-ref ref="A2" />
-     <appender-ref ref="A3" />
-  </root>
-
-</log4j:configuration>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/log4j.properties
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/log4j.properties b/conf/examples/1GB/native-standalone/log4j.properties
deleted file mode 100644
index f3eaddc..0000000
--- a/conf/examples/1GB/native-standalone/log4j.properties
+++ /dev/null
@@ -1,42 +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.
-
-# default logging properties:
-#  by default, log everything at INFO or higher to the console
-log4j.rootLogger=INFO,A1
-
-# hide Jetty junk
-log4j.logger.org.mortbay.log=WARN,A1
-
-# hide "Got brand-new compressor" messages
-log4j.logger.org.apache.hadoop.io.compress=WARN,A1
-log4j.logger.org.apache.accumulo.core.file.rfile.bcfile.Compression=WARN,A1
-
-# hide junk from TestRandomDeletes
-log4j.logger.org.apache.accumulo.test.TestRandomDeletes=WARN,A1
-
-# hide junk from VFS
-log4j.logger.org.apache.commons.vfs2.impl.DefaultFileSystemManager=WARN,A1
-
-# hide almost everything from zookeeper
-log4j.logger.org.apache.zookeeper=ERROR,A1
-
-# hide AUDIT messages in the shell, alternatively you could send them to a different logger
-log4j.logger.org.apache.accumulo.core.util.shell.Shell.audit=WARN,A1
-
-# Send most things to the console
-log4j.appender.A1=org.apache.log4j.ConsoleAppender
-log4j.appender.A1.layout.ConversionPattern=%d{ISO8601} [%-8c{2}] %-5p: %m%n
-log4j.appender.A1.layout=org.apache.log4j.PatternLayout

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/masters
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/masters b/conf/examples/1GB/native-standalone/masters
deleted file mode 100644
index 63fb8bb..0000000
--- a/conf/examples/1GB/native-standalone/masters
+++ /dev/null
@@ -1,16 +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.
-
-localhost

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/monitor
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/monitor b/conf/examples/1GB/native-standalone/monitor
deleted file mode 100644
index 63fb8bb..0000000
--- a/conf/examples/1GB/native-standalone/monitor
+++ /dev/null
@@ -1,16 +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.
-
-localhost

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/monitor_logger.xml
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/monitor_logger.xml b/conf/examples/1GB/native-standalone/monitor_logger.xml
deleted file mode 100644
index 3a63bf4..0000000
--- a/conf/examples/1GB/native-standalone/monitor_logger.xml
+++ /dev/null
@@ -1,64 +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.
--->
-<!DOCTYPE log4j:configuration SYSTEM "log4j.dtd">
-<log4j:configuration xmlns:log4j="http://jakarta.apache.org/log4j/">
-
-  <!-- Write out everything at the DEBUG level to the debug log -->
-  <appender name="A2" class="org.apache.log4j.RollingFileAppender">
-     <param name="File"           value="${org.apache.accumulo.core.dir.log}/${org.apache.accumulo.core.application}_${org.apache.accumulo.core.ip.localhost.hostname}.debug.log"/>
-     <param name="MaxFileSize"    value="100MB"/>
-     <param name="MaxBackupIndex" value="10"/>
-     <param name="Threshold"      value="DEBUG"/>
-     <layout class="org.apache.log4j.PatternLayout">
-       <param name="ConversionPattern" value="%d{ISO8601} [%-8c{2}] %-5p: %X{application} %m%n"/>
-     </layout>	    
-  </appender>
-
-  <!--  Write out INFO and higher to the regular log -->
-  <appender name="A3" class="org.apache.log4j.RollingFileAppender">
-     <param name="File"           value="${org.apache.accumulo.core.dir.log}/${org.apache.accumulo.core.application}_${org.apache.accumulo.core.ip.localhost.hostname}.log"/>
-     <param name="MaxFileSize"    value="100MB"/>
-     <param name="MaxBackupIndex" value="10"/>
-     <param name="Threshold"      value="INFO"/>
-     <layout class="org.apache.log4j.PatternLayout">
-       <param name="ConversionPattern" value="%d{ISO8601} [%-8c{2}] %-5p: %X{application} %m%n"/>
-     </layout>	    
-  </appender>
-
-  <!-- Keep the last few log messages for display to the user -->
-  <appender name="GUI" class="org.apache.accumulo.server.monitor.LogService">
-     <param name="keep"           value="40"/>
-     <param name="Threshold"      value="WARN"/>
-  </appender>
-
-  <!-- Log accumulo messages to debug, normal and GUI -->
-  <logger name="org.apache.accumulo" additivity="false">
-     <level value="DEBUG"/>
-     <appender-ref ref="A2" />
-     <appender-ref ref="A3" />
-     <appender-ref ref="GUI" />
-  </logger>
-
-  <!-- Log non-accumulo messages to debug, normal logs. -->
-  <root>
-     <level value="INFO"/>
-     <appender-ref ref="A2" />
-     <appender-ref ref="A3" />
-  </root>
-
-</log4j:configuration>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/slaves
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/slaves b/conf/examples/1GB/native-standalone/slaves
deleted file mode 100644
index 63fb8bb..0000000
--- a/conf/examples/1GB/native-standalone/slaves
+++ /dev/null
@@ -1,16 +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.
-
-localhost

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/native-standalone/tracers
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/native-standalone/tracers b/conf/examples/1GB/native-standalone/tracers
deleted file mode 100644
index 63fb8bb..0000000
--- a/conf/examples/1GB/native-standalone/tracers
+++ /dev/null
@@ -1,16 +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.
-
-localhost

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/standalone/accumulo-env.sh
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/standalone/accumulo-env.sh b/conf/examples/1GB/standalone/accumulo-env.sh
deleted file mode 100755
index 8b904ac..0000000
--- a/conf/examples/1GB/standalone/accumulo-env.sh
+++ /dev/null
@@ -1,66 +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.
-
-###
-### Configure these environment variables to point to your local installations.
-###
-### The functional tests require conditional values, so keep this style:
-###
-### test -z "$JAVA_HOME" && export JAVA_HOME=/usr/local/lib/jdk-1.6.0
-###
-###
-### Note that the -Xmx -Xms settings below require substantial free memory: 
-### you may want to use smaller values, especially when running everything
-### on a single machine.
-###
-if [ -z "$HADOOP_HOME" ]
-then
-   test -z "$HADOOP_PREFIX"      && export HADOOP_PREFIX=/path/to/hadoop
-else
-   HADOOP_PREFIX="$HADOOP_HOME"
-   unset HADOOP_HOME
-fi
-
-# hadoop-1.2:
-# test -z "$HADOOP_CONF_DIR"       && export HADOOP_CONF_DIR="$HADOOP_PREFIX/conf"
-test -z "$HADOOP_CONF_DIR"     && export HADOOP_CONF_DIR="$HADOOP_PREFIX/etc/hadoop"
-
-
-test -z "$JAVA_HOME"             && export JAVA_HOME=/path/to/java
-test -z "$ZOOKEEPER_HOME"        && export ZOOKEEPER_HOME=/path/to/zookeeper
-test -z "$ACCUMULO_LOG_DIR"      && export ACCUMULO_LOG_DIR=$ACCUMULO_HOME/logs
-if [ -f ${ACCUMULO_CONF_DIR}/accumulo.policy ]
-then
-   POLICY="-Djava.security.manager -Djava.security.policy=${ACCUMULO_CONF_DIR}/accumulo.policy"
-fi
-test -z "$ACCUMULO_TSERVER_OPTS" && export ACCUMULO_TSERVER_OPTS="${POLICY} -Xmx384m -Xms384m "
-test -z "$ACCUMULO_MASTER_OPTS"  && export ACCUMULO_MASTER_OPTS="${POLICY} -Xmx128m -Xms128m"
-test -z "$ACCUMULO_MONITOR_OPTS" && export ACCUMULO_MONITOR_OPTS="${POLICY} -Xmx64m -Xms64m" 
-test -z "$ACCUMULO_GC_OPTS"      && export ACCUMULO_GC_OPTS="-Xmx64m -Xms64m"
-test -z "$ACCUMULO_GENERAL_OPTS" && export ACCUMULO_GENERAL_OPTS="-XX:+UseConcMarkSweepGC -XX:CMSInitiatingOccupancyFraction=75 -Djava.net.preferIPv4Stack=true"
-test -z "$ACCUMULO_OTHER_OPTS"   && export ACCUMULO_OTHER_OPTS="-Xmx128m -Xms64m"
-# what do when the JVM runs out of heap memory
-export ACCUMULO_KILL_CMD='kill -9 %p'
-
-### Optionally look for hadoop and accumulo native libraries for your
-### platform in additional directories. (Use DYLD_LIBRARY_PATH on Mac OS X.)
-### May not be necessary for Hadoop 2.x or using an RPM that installs to
-### the correct system library directory.
-# export LD_LIBRARY_PATH=${HADOOP_PREFIX}/lib/native/${PLATFORM}:${LD_LIBRARY_PATH}
-
-# Should the monitor bind to all network interfaces -- default: false
-# export ACCUMULO_MONITOR_BIND_ALL="true"

http://git-wip-us.apache.org/repos/asf/accumulo/blob/037ad964/conf/examples/1GB/standalone/accumulo-metrics.xml
----------------------------------------------------------------------
diff --git a/conf/examples/1GB/standalone/accumulo-metrics.xml b/conf/examples/1GB/standalone/accumulo-metrics.xml
deleted file mode 100644
index 60f9f8d..0000000
--- a/conf/examples/1GB/standalone/accumulo-metrics.xml
+++ /dev/null
@@ -1,60 +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.
--->
-<!--
-  This file follows the conventions for XMLConfiguration files specified in the Apache Commons Configuration 1.5 Library. Changes to this file will be noticed
-  at runtime (see the FileChangedReloadingStrategy class in Commons Configuration).
--->
-<config>
-<!--
-   Metrics log directory
--->
-  <logging>
-    <dir>${ACCUMULO_HOME}/metrics</dir>
-  </logging>
-<!--
- Enable/Disable metrics accumulation on the different servers and their components
- NOTE: Turning on logging can be expensive because it will use several more file handles and will create a lot of short lived objects.
--->
-  <master>
-    <enabled type="boolean">false</enabled>
-    <logging type="boolean">false</logging>
-  </master>
-  <logger>
-    <enabled type="boolean">false</enabled>
-    <logging type="boolean">false</logging>
-  </logger>
-  <tserver>
-    <enabled type="boolean">false</enabled>
-    <logging type="boolean">false</logging>
-    <update>
-      <enabled type="boolean">false</enabled>
-      <logging type="boolean">false</logging>
-    </update>
-    <scan>
-      <enabled type="boolean">false</enabled>
-      <logging type="boolean">false</logging>
-    </scan>
-    <minc>
-      <enabled type="boolean">false</enabled>
-      <logging type="boolean">false</logging>
-    </minc>
-  </tserver>
-  <thrift>
-    <enabled type="boolean">false</enabled>
-    <logging type="boolean">false</logging>
-  </thrift>
-</config>