You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@usergrid.apache.org by to...@apache.org on 2014/11/03 23:20:11 UTC

[1/2] git commit: Updated configurations to match Matt's system. Changed some threads

Repository: incubator-usergrid
Updated Branches:
  refs/heads/key-row-sharding c9c627bb3 -> 2aeefd516


Updated configurations to match Matt's system.  Changed some threads


Project: http://git-wip-us.apache.org/repos/asf/incubator-usergrid/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-usergrid/commit/71822f54
Tree: http://git-wip-us.apache.org/repos/asf/incubator-usergrid/tree/71822f54
Diff: http://git-wip-us.apache.org/repos/asf/incubator-usergrid/diff/71822f54

Branch: refs/heads/key-row-sharding
Commit: 71822f544048eeea8fa615d75e50d426ab09d203
Parents: c9c627b
Author: Todd Nine <tn...@apigee.com>
Authored: Mon Nov 3 14:42:13 2014 -0700
Committer: Todd Nine <tn...@apigee.com>
Committed: Mon Nov 3 14:42:13 2014 -0700

----------------------------------------------------------------------
 .../main/dist/init_instance/create_keyspaces.sh |   2 +
 .../src/main/dist/init_instance/create_raid0.sh |   9 +-
 .../main/dist/init_instance/init_db_server.sh   |   8 +-
 .../main/dist/init_instance/init_es_server.sh   |   8 +-
 .../dist/init_instance/init_opscenter_server.sh | 178 ++++++++++++++++++-
 .../main/dist/init_instance/init_rest_server.sh |  54 +++++-
 .../dist/init_instance/install_elasticsearch.sh |  17 +-
 .../init_instance/install_opscenter_agent.sh    |   5 +-
 .../main/groovy/configure_elasticsearch.groovy  |  10 +-
 .../groovy/configure_opscenter_usergrid.groovy  |   9 +-
 stack/awscluster/ugcluster-cf.json              |   6 +-
 11 files changed, 269 insertions(+), 37 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/dist/init_instance/create_keyspaces.sh
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/dist/init_instance/create_keyspaces.sh b/stack/awscluster/src/main/dist/init_instance/create_keyspaces.sh
index 5cf0f7f..e2451e8 100644
--- a/stack/awscluster/src/main/dist/init_instance/create_keyspaces.sh
+++ b/stack/awscluster/src/main/dist/init_instance/create_keyspaces.sh
@@ -28,6 +28,8 @@ FIRSTHOST="$(groovy get_first_instance.groovy cassandra)"
 
 if [ "$FIRSTHOST"=="$PUBLIC_HOSTNAME" ]; then
 
+#We have to wait for cass to actually start before we can run our CQL.   Sleep 5 seconds between retries
+while ! echo exit | nc localhost 9160; do sleep 5; done
 
 #WE have to remove our -1 from the end, since us-east and us-west dont support -1 in cassandra
 CASS_REGION=${EC2_REGION%-1}

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/dist/init_instance/create_raid0.sh
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/dist/init_instance/create_raid0.sh b/stack/awscluster/src/main/dist/init_instance/create_raid0.sh
index 43d9f37..c9122d7 100644
--- a/stack/awscluster/src/main/dist/init_instance/create_raid0.sh
+++ b/stack/awscluster/src/main/dist/init_instance/create_raid0.sh
@@ -20,7 +20,7 @@
 
 
 
-# WARNING: this does not work yet (and is not used by any other script)
+# WARNING: this does not work for any instances that have more than 2 ephemeral disks
 
 
 
@@ -38,8 +38,11 @@ umount /mnt
 
 
 #We only support 2 ephemeral disks.  Most c3.x instances only have 2 disks and they're our target
-# create striped RAID0 device with our four disks
-yes | mdadm --create --verbose /dev/md0 --level=stripe --raid-devices=2 -c 256  /dev/xvdb /dev/xvdc
+# create striped RAID0 device with our 2 disks
+yes | mdadm --create --verbose /dev/md0 --level=0 --raid-devices=2 -c 256  /dev/xvdb /dev/xvdc
+
+
+
 
 # save config
 mdadm --detail --scan | tee /etc/mdadm/mdadm.conf

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/dist/init_instance/init_db_server.sh
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/dist/init_instance/init_db_server.sh b/stack/awscluster/src/main/dist/init_instance/init_db_server.sh
index 25ca6bf..a9bae98 100644
--- a/stack/awscluster/src/main/dist/init_instance/init_db_server.sh
+++ b/stack/awscluster/src/main/dist/init_instance/init_db_server.sh
@@ -32,8 +32,6 @@ dpkg-reconfigure -f noninteractive tzdata
 . /etc/profile.d/aws-credentials.sh
 . /etc/profile.d/usergrid-env.sh
 
-cd /usr/share/usergrid/init_instance
-./create_raid0.sh
 
 # Install the easy stuff
 PKGS="ntp unzip groovy curl"
@@ -52,10 +50,16 @@ cp /usr/share/aws-java-sdk-*/lib/* /home/ubuntu/.groovy/lib
 rm /home/ubuntu/.groovy/lib/stax*
 ln -s /home/ubuntu/.groovy /root/.groovy
 
+
+
 # tag last so we can see in the console so that we know what's running
 cd /usr/share/usergrid/scripts
 groovy tag_instance.groovy -BUILD-IN-PROGRESS
 
+#Create our raid 0 array
+cd /usr/share/usergrid/init_instance
+./create_raid0.sh
+
 cd /usr/share/usergrid/init_instance
 ./install_oraclejdk.sh 
 

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/dist/init_instance/init_es_server.sh
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/dist/init_instance/init_es_server.sh b/stack/awscluster/src/main/dist/init_instance/init_es_server.sh
index 4b6a7ec..836b1d9 100644
--- a/stack/awscluster/src/main/dist/init_instance/init_es_server.sh
+++ b/stack/awscluster/src/main/dist/init_instance/init_es_server.sh
@@ -31,8 +31,6 @@ dpkg-reconfigure -f noninteractive tzdata
 . /etc/profile.d/aws-credentials.sh
 . /etc/profile.d/usergrid-env.sh
 
-cd /usr/share/usergrid/init_instance
-./create_raid0.sh
 
 # Install the easy stuff
 PKGS="ntp unzip groovy curl"
@@ -55,6 +53,12 @@ ln -s /home/ubuntu/.groovy /root/.groovy
 cd /usr/share/usergrid/scripts
 groovy tag_instance.groovy -BUILD-IN-PROGRESS
 
+
+#Configure our RAID 0 arrays
+cd /usr/share/usergrid/init_instance
+./create_raid0.sh
+
+
 cd /usr/share/usergrid/init_instance
 ./install_oraclejdk.sh 
 

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/dist/init_instance/init_opscenter_server.sh
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/dist/init_instance/init_opscenter_server.sh b/stack/awscluster/src/main/dist/init_instance/init_opscenter_server.sh
index 728cb6d..b63a710 100644
--- a/stack/awscluster/src/main/dist/init_instance/init_opscenter_server.sh
+++ b/stack/awscluster/src/main/dist/init_instance/init_opscenter_server.sh
@@ -89,7 +89,177 @@ popd
 
 /etc/init.d/cassandra start
 
+#We have to wait for cass to actually start before we can run our CQL.   Sleep 5 seconds between retries
+while ! echo exit | nc localhost 9160; do sleep 5; done
+
+CASS_REGION=${EC2_REGION%-1}
 #create our keyspace
+cat >> /tmp/opscenter.cql << EOF
+CREATE KEYSPACE "OpsCenter" WITH REPLICATION = {'class' : 'NetworkTopologyStrategy', '${CASS_REGION}' : 1};
+
+USE "OpsCenter";
+
+CREATE TABLE bestpractice_results (
+  key text,
+  column1 varint,
+  value blob,
+  PRIMARY KEY (key, column1)
+) WITH COMPACT STORAGE AND
+  CLUSTERING ORDER BY (column1 DESC) AND
+  bloom_filter_fp_chance=0.010000 AND
+  caching='KEYS_ONLY' AND
+  comment='{"info": "OpsCenter management data.", "version": [5, 0, 1]}' AND
+  dclocal_read_repair_chance=0.000000 AND
+  gc_grace_seconds=0 AND
+  read_repair_chance=0.250000 AND
+  replicate_on_write='true' AND
+  populate_io_cache_on_flush='false' AND
+  compaction={'class': 'SizeTieredCompactionStrategy'} AND
+  compression={'sstable_compression': 'SnappyCompressor'};
+
+CREATE TABLE events (
+  key text PRIMARY KEY,
+  action bigint,
+  level bigint,
+  success boolean,
+  time bigint
+) WITH COMPACT STORAGE AND
+  bloom_filter_fp_chance=0.010000 AND
+  caching='KEYS_ONLY' AND
+  comment='{"info": "OpsCenter management data.", "version": [5, 0, 1]}' AND
+  dclocal_read_repair_chance=0.000000 AND
+  gc_grace_seconds=864000 AND
+  read_repair_chance=0.250000 AND
+  replicate_on_write='true' AND
+  populate_io_cache_on_flush='false' AND
+  compaction={'class': 'SizeTieredCompactionStrategy'} AND
+  compression={'sstable_compression': 'SnappyCompressor'};
+
+CREATE TABLE events_timeline (
+  key text,
+  column1 bigint,
+  value blob,
+  PRIMARY KEY (key, column1)
+) WITH COMPACT STORAGE AND
+  bloom_filter_fp_chance=0.010000 AND
+  caching='KEYS_ONLY' AND
+  comment='{"info": "OpsCenter management data.", "version": [5, 0, 1]}' AND
+  dclocal_read_repair_chance=0.000000 AND
+  gc_grace_seconds=864000 AND
+  read_repair_chance=0.250000 AND
+  replicate_on_write='true' AND
+  populate_io_cache_on_flush='false' AND
+  compaction={'class': 'SizeTieredCompactionStrategy'} AND
+  compression={'sstable_compression': 'SnappyCompressor'};
+
+CREATE TABLE pdps (
+  key text,
+  column1 text,
+  value blob,
+  PRIMARY KEY (key, column1)
+) WITH COMPACT STORAGE AND
+  bloom_filter_fp_chance=0.010000 AND
+  caching='KEYS_ONLY' AND
+  comment='{"info": "OpsCenter management data.", "version": [5, 0, 1]}' AND
+  dclocal_read_repair_chance=0.000000 AND
+  gc_grace_seconds=0 AND
+  read_repair_chance=0.250000 AND
+  replicate_on_write='true' AND
+  populate_io_cache_on_flush='false' AND
+  compaction={'class': 'SizeTieredCompactionStrategy'} AND
+  compression={'sstable_compression': 'SnappyCompressor'};
+
+CREATE TABLE rollups300 (
+  key text,
+  column1 varint,
+  value blob,
+  PRIMARY KEY (key, column1)
+) WITH COMPACT STORAGE AND
+  bloom_filter_fp_chance=0.010000 AND
+  caching='KEYS_ONLY' AND
+  comment='{"info": "OpsCenter management data.", "version": [5, 0, 1]}' AND
+  dclocal_read_repair_chance=0.000000 AND
+  gc_grace_seconds=0 AND
+  read_repair_chance=0.250000 AND
+  replicate_on_write='true' AND
+  populate_io_cache_on_flush='false' AND
+  compaction={'class': 'SizeTieredCompactionStrategy'} AND
+  compression={'sstable_compression': 'SnappyCompressor'};
+
+CREATE TABLE rollups60 (
+  key text,
+  column1 varint,
+  value blob,
+  PRIMARY KEY (key, column1)
+) WITH COMPACT STORAGE AND
+  bloom_filter_fp_chance=0.010000 AND
+  caching='KEYS_ONLY' AND
+  comment='{"info": "OpsCenter management data.", "version": [5, 0, 1]}' AND
+  dclocal_read_repair_chance=0.000000 AND
+  gc_grace_seconds=0 AND
+  read_repair_chance=0.250000 AND
+  replicate_on_write='true' AND
+  populate_io_cache_on_flush='false' AND
+  compaction={'class': 'SizeTieredCompactionStrategy'} AND
+  compression={'sstable_compression': 'SnappyCompressor'};
+
+CREATE TABLE rollups7200 (
+  key text,
+  column1 varint,
+  value blob,
+  PRIMARY KEY (key, column1)
+) WITH COMPACT STORAGE AND
+  bloom_filter_fp_chance=0.010000 AND
+  caching='KEYS_ONLY' AND
+  comment='{"info": "OpsCenter management data.", "version": [5, 0, 1]}' AND
+  dclocal_read_repair_chance=0.000000 AND
+  gc_grace_seconds=0 AND
+  read_repair_chance=0.250000 AND
+  replicate_on_write='true' AND
+  populate_io_cache_on_flush='false' AND
+  compaction={'class': 'SizeTieredCompactionStrategy'} AND
+  compression={'sstable_compression': 'SnappyCompressor'};
+
+CREATE TABLE rollups86400 (
+  key text,
+  column1 varint,
+  value blob,
+  PRIMARY KEY (key, column1)
+) WITH COMPACT STORAGE AND
+  bloom_filter_fp_chance=0.010000 AND
+  caching='KEYS_ONLY' AND
+  comment='{"info": "OpsCenter management data.", "version": [5, 0, 1]}' AND
+  dclocal_read_repair_chance=0.000000 AND
+  gc_grace_seconds=0 AND
+  read_repair_chance=0.250000 AND
+  replicate_on_write='true' AND
+  populate_io_cache_on_flush='false' AND
+  compaction={'class': 'SizeTieredCompactionStrategy'} AND
+  compression={'sstable_compression': 'SnappyCompressor'};
+
+CREATE TABLE settings (
+  key blob,
+  column1 blob,
+  value blob,
+  PRIMARY KEY (key, column1)
+) WITH COMPACT STORAGE AND
+  bloom_filter_fp_chance=0.010000 AND
+  caching='KEYS_ONLY' AND
+  comment='{"info": "OpsCenter management data.", "version": [5, 0, 1]}' AND
+  dclocal_read_repair_chance=0.000000 AND
+  gc_grace_seconds=864000 AND
+  read_repair_chance=1.000000 AND
+  replicate_on_write='true' AND
+  populate_io_cache_on_flush='false' AND
+  compaction={'class': 'SizeTieredCompactionStrategy'} AND
+  compression={'sstable_compression': 'SnappyCompressor'};
+
+EOF
+
+
+echo "Creating opscenter keyspace"
+/usr/bin/cqlsh -f  /tmp/opscenter.cql
+
 
 
 
@@ -103,15 +273,15 @@ apt-get  --force-yes -y install opscenter
 sudo service opscenterd stop
 
 #Configure the usergrid cluster to store data locally, not on the target cluster and auto boostrap it
-pushd /usr/share/usergrid/scripts
+cd /usr/share/usergrid/scripts
 groovy wait_for_instances.groovy cassandra 1
 mkdir -p /etc/opscenter/clusters
 groovy configure_opscenter_usergrid.groovy > /etc/opscenter/clusters/$CASSANDRA_CLUSTER_NAME.conf
-popd
+
 
 sudo service opscenterd start
 
 # tag last so we can see in the console that the script ran to completion
-pushd /usr/share/usergrid/scripts
+cd /usr/share/usergrid/scripts
 groovy tag_instance.groovy
-popd
+

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/dist/init_instance/init_rest_server.sh
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/dist/init_instance/init_rest_server.sh b/stack/awscluster/src/main/dist/init_instance/init_rest_server.sh
index 28fbc48..0e65c9a 100644
--- a/stack/awscluster/src/main/dist/init_instance/init_rest_server.sh
+++ b/stack/awscluster/src/main/dist/init_instance/init_rest_server.sh
@@ -62,7 +62,12 @@ cd /usr/share/usergrid/init_instance
 
 # set Tomcat memory and threads based on instance type
 # use about 70% of RAM for heap
-export NOFILE=100000
+export NOFILE=150000
+export TOMCAT_CONNECTIONS=10000
+export ACCEPT_COUNT=1600
+export NR_OPEN=1048576
+export FILE_MAX=761773
+
 case `(curl http://169.254.169.254/latest/meta-data/instance-type)` in
 'm1.small' )
     # total of 1.7g
@@ -96,8 +101,8 @@ case `(curl http://169.254.169.254/latest/meta-data/instance-type)` in
 ;;
 'c3.xlarge' )
     # total of 7.5g
-    export TOMCAT_RAM=5250m
-    export TOMCAT_THREADS=1000
+    export TOMCAT_RAM=4096m
+    export TOMCAT_THREADS=7000
 ;;
 'c3.2xlarge' )
     # total of 15g
@@ -110,29 +115,60 @@ case `(curl http://169.254.169.254/latest/meta-data/instance-type)` in
     export TOMCAT_THREADS=4000
 esac
 
-export TOMCAT_CONNECTIONS=10000
+
 sed -i.bak "s/Xmx128m/Xmx${TOMCAT_RAM} -Xms${TOMCAT_RAM} -Dlog4j\.configuration=file:\/usr\/share\/usergrid\/lib\/log4j\.properties/g" /etc/default/tomcat7
-sed -i.bak "s/<Connector/<Connector maxThreads=\"${TOMCAT_THREADS}\" acceptCount=\"${TOMCAT_THREADS}\" maxConnections=\"${TOMCAT_CONNECTIONS}\"/g" /var/lib/tomcat7/conf/server.xml
+sed -i.bak "s/<Connector/<Connector maxThreads=\"${TOMCAT_THREADS}\" acceptCount=\"${ACCEPT_COUNT}\" maxConnections=\"${TOMCAT_CONNECTIONS}\"/g" /var/lib/tomcat7/conf/server.xml
 
 
 #Append our java opts for secret key
 echo "JAVA_OPTS=\"\${JAVA_OPTS} -DAWS_SECRET_KEY=${AWS_SECRET_KEY} -DAWS_ACCESS_KEY_ID=${AWS_ACCESS_KEY}\"" >> /etc/default/tomcat7
 
+ulimit -n $NOFILE
 
 # set file limits
 sed -i.bak "s/# \/etc\/init\.d\/tomcat7 -- startup script for the Tomcat 6 servlet engine/ulimit -n ${NOFILE}/" /etc/init.d/tomcat7
-sed -i.bak "s/@student/a *\t\thard\tnofile\t\t${NOFILE}\n*\t\tsoft\tnofile\t\t${NOFILE}" /etc/security/limits.conf
-echo "$NOFILE" | sudo tee > /proc/sys/fs/nr_open
-echo "$NOFILE" | sudo tee > /proc/sys/fs/file-max
+
+
+cat >>  /etc/security/limits.conf  << EOF
+* - nofile ${NOFILE}
+root - nofile ${NOFILE}
+EOF
+
+
+
+echo "${NR_OPEN}" | sudo tee > /proc/sys/fs/nr_open
+echo "${FILE_MAX}" | sudo tee > /proc/sys/fs/file-max
+
+
 cat >> /etc/pam.d/su << EOF
 session    required   pam_limits.so
 EOF
-ulimit -n $NOFILE
+
+
 
 # increase system IP port limits (do we really need this for Tomcat?)
 sysctl -w net.ipv4.ip_local_port_range="1024 65535"
 cat >> /etc/sysctl.conf << EOF
+####
+# Set by usergrid rest setup
+####
 net.ipv4.ip_local_port_range = 1024 65535
+
+# Controls the default maxmimum size of a mesage queue
+kernel.msgmnb = 65536
+
+# Controls the maximum size of a message, in bytes
+kernel.msgmax = 65536
+
+# Controls the maximum shared segment size, in bytes
+kernel.shmmax = 68719476736
+
+# Controls the maximum number of shared memory segments, in pages
+kernel.shmall = 4294967296
+
+######
+# End usergrid setup
+######
 EOF
 
 # wait for enough Cassandra nodes then delpoy and configure Usergrid 

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/dist/init_instance/install_elasticsearch.sh
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/dist/init_instance/install_elasticsearch.sh b/stack/awscluster/src/main/dist/init_instance/install_elasticsearch.sh
index 604cb14..73195dc 100644
--- a/stack/awscluster/src/main/dist/init_instance/install_elasticsearch.sh
+++ b/stack/awscluster/src/main/dist/init_instance/install_elasticsearch.sh
@@ -36,12 +36,13 @@ mkdir -p /mnt/log/elasticsearch
 chown elasticsearch /mnt/log/elasticsearch
 
 # Configure ElasticSearch
-cd /usr/share/usergrid/scripts
+
 
 echo "vm.swappiness = 0" >> /etc/sysctl.conf
 sysctl -p
 
 # No need to do this, elasticsearch nodes are also cassandra nodes
+cd /usr/share/usergrid/scripts
 groovy registry_register.groovy elasticsearch
 groovy wait_for_instances.groovy elasticsearch ${ES_NUM_SERVERS}
 
@@ -90,10 +91,13 @@ esac
 cat >> /etc/default/elasticsearch << EOF
 ES_HEAP_SIZE=${ES_HEAP_SIZE}
 MAX_OPEN_FILES=65535
-MAX_LOCKED_MEMORY=unlimited
+MAX_MAP_COUNT=262144
+#MAX_LOCKED_MEMORY=unlimited
 JAVA_HOME=/usr/lib/jvm/jdk1.7.0
 EOF
 
+#Set it because Matt says so
+ulimit -l unlimited
 
 cat >> /etc/security/limits.conf << EOF
 elasticsearch - nofile 65535
@@ -101,6 +105,7 @@ elasticsearch - memlock unlimited
 EOF
 
 
+cd /usr/share/usergrid/scripts
 groovy ./configure_elasticsearch.groovy > /etc/elasticsearch/elasticsearch.yml
 
 update-rc.d elasticsearch defaults 95 10
@@ -115,6 +120,14 @@ pushd /usr/share/elasticsearch/bin
 
 ./plugin --install lukas-vlcek/bigdesk
 
+./plugin --install mobz/elasticsearch-head
+
+./plugin -install royrusso/elasticsearch-HQ
+
+./plugin -install karmi/elasticsearch-paramedic
+
+./plugin -install xyu/elasticsearch-whatson/0.1.3
+
 popd
 
 

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/dist/init_instance/install_opscenter_agent.sh
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/dist/init_instance/install_opscenter_agent.sh b/stack/awscluster/src/main/dist/init_instance/install_opscenter_agent.sh
index 5e2ec4b..a5679e4 100644
--- a/stack/awscluster/src/main/dist/init_instance/install_opscenter_agent.sh
+++ b/stack/awscluster/src/main/dist/init_instance/install_opscenter_agent.sh
@@ -1,5 +1,4 @@
 #!/bin/bash
-
 # 
 #  Licensed to the Apache Software Foundation (ASF) under one or more
 #   contributor license agreements.  The ASF licenses this file to You
@@ -20,8 +19,6 @@
 
 
 # Install and stop Cassandra
-pushd /etc/apt/sources.list.d
-
 echo "deb http://debian.datastax.com/community stable main" | sudo tee -a /etc/apt/sources.list.d/datastax.community.list
 
 curl -L https://debian.datastax.com/debian/repo_key | sudo apt-key add -
@@ -42,4 +39,4 @@ groovy configure_opscenter_agent.groovy > /var/lib/datastax-agent/conf/address.y
 sudo service datastax-agent stop
 sudo service datastax-agent start
 
-popd
+

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy b/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy
index 1693777..3658d7f 100644
--- a/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy
+++ b/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy
@@ -64,13 +64,13 @@ es.logger.level: INFO
 
 threadpool.index.type: fixed
 threadpool.index.size: 160
-threadpool.index.queue_size: 401
+threadpool.index.queue_size: 0
 threadpool.bulk.type: fixed
-threadpool.bulk.size: 10000
-threadpool.bulk.queue_size: 800
-threadpool.search.size: 20000
+threadpool.bulk.size: 5000
+threadpool.bulk.queue_size: 0
+threadpool.search.size: 10000
 threadpool.search.type: fixed
-threadpool.search.queue_size: 1000
+threadpool.search.queue_size: 0
 
 action.auto_create_index: false
 

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/src/main/groovy/configure_opscenter_usergrid.groovy
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/groovy/configure_opscenter_usergrid.groovy b/stack/awscluster/src/main/groovy/configure_opscenter_usergrid.groovy
index 882a04a..df4dcae 100644
--- a/stack/awscluster/src/main/groovy/configure_opscenter_usergrid.groovy
+++ b/stack/awscluster/src/main/groovy/configure_opscenter_usergrid.groovy
@@ -47,9 +47,12 @@ def usergridConfig = """
 [cassandra]
 seed_hosts = ${seeds}
 
-[storage_cassandra]
-seed_hosts = ${hostName}
-api_port = 9160
+#TODO, this doesn't seem to work, I think opscenter is broken.  Try this again at a later time and remove opscenter exclusion below
+#[storage_cassandra]
+#seed_hosts = ${hostName}
+#api_port = 9160
+
+
 """
 
 println usergridConfig

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/71822f54/stack/awscluster/ugcluster-cf.json
----------------------------------------------------------------------
diff --git a/stack/awscluster/ugcluster-cf.json b/stack/awscluster/ugcluster-cf.json
index 78d575f..f9979b1 100644
--- a/stack/awscluster/ugcluster-cf.json
+++ b/stack/awscluster/ugcluster-cf.json
@@ -208,13 +208,13 @@
         },
         "AWSRegionArch2AMI": {
             "ap-southeast-2": {
-                "64": "ami-5993f663"
+                "64": "ami-c1335ffb"
             },
             "us-east-1": {
-                "64": "ami-7cbd4f14"
+                "64": "ami-b89f18d0"
             },
             "us-west-2": {
-                "64": "ami-2598ea15"
+                "64": "ami-194a0429"
             }
         },
         "TwoAZs": {


[2/2] git commit: Removed Jukito completely

Posted by to...@apache.org.
Removed  Jukito completely


Project: http://git-wip-us.apache.org/repos/asf/incubator-usergrid/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-usergrid/commit/2aeefd51
Tree: http://git-wip-us.apache.org/repos/asf/incubator-usergrid/tree/2aeefd51
Diff: http://git-wip-us.apache.org/repos/asf/incubator-usergrid/diff/2aeefd51

Branch: refs/heads/key-row-sharding
Commit: 2aeefd516a9398673348998a874064e2116959ad
Parents: 71822f5
Author: Todd Nine <tn...@apigee.com>
Authored: Mon Nov 3 15:20:04 2014 -0700
Committer: Todd Nine <tn...@apigee.com>
Committed: Mon Nov 3 15:20:04 2014 -0700

----------------------------------------------------------------------
 .../main/groovy/configure_elasticsearch.groovy  |   2 +-
 stack/core/pom.xml                              |  15 +-
 .../CpEntityDeleteListenerTest.java             |   3 +-
 .../CpEntityIndexDeleteListenerTest.java        |   3 -
 .../1.4-UG/_maven.repositories                  |   4 -
 .../1.4-UG/jukito-build-tools-1.4-UG.jar        | Bin 4603 -> 0 bytes
 .../1.4-UG/jukito-build-tools-1.4-UG.pom        |  13 -
 .../jukito-build-tools/maven-metadata-local.xml |  12 -
 .../jukito-parent/1.4-UG/_maven.repositories    |   3 -
 .../1.4-UG/jukito-parent-1.4-UG.pom             | 313 -------------------
 .../jukito-parent/maven-metadata-local.xml      |  12 -
 .../jukito-samples/1.4-UG/_maven.repositories   |   4 -
 .../1.4-UG/jukito-samples-1.4-UG.jar            | Bin 5103 -> 0 bytes
 .../1.4-UG/jukito-samples-1.4-UG.pom            |  33 --
 .../jukito-samples/maven-metadata-local.xml     |  12 -
 .../jukito/jukito/1.4-UG/_maven.repositories    |   5 -
 .../jukito/1.4-UG/jukito-1.4-UG-sources.jar     | Bin 30660 -> 0 bytes
 .../org/jukito/jukito/1.4-UG/jukito-1.4-UG.jar  | Bin 42832 -> 0 bytes
 .../org/jukito/jukito/1.4-UG/jukito-1.4-UG.pom  |  93 ------
 .../org/jukito/jukito/maven-metadata-local.xml  |  12 -
 stack/pom.xml                                   |  15 +-
 21 files changed, 18 insertions(+), 536 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy
----------------------------------------------------------------------
diff --git a/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy b/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy
index 3658d7f..cd91026 100644
--- a/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy
+++ b/stack/awscluster/src/main/groovy/configure_elasticsearch.groovy
@@ -66,7 +66,7 @@ threadpool.index.type: fixed
 threadpool.index.size: 160
 threadpool.index.queue_size: 0
 threadpool.bulk.type: fixed
-threadpool.bulk.size: 5000
+threadpool.bulk.size: 1000
 threadpool.bulk.queue_size: 0
 threadpool.search.size: 10000
 threadpool.search.type: fixed

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/core/pom.xml
----------------------------------------------------------------------
diff --git a/stack/core/pom.xml b/stack/core/pom.xml
index 7bd4da4..a303d17 100644
--- a/stack/core/pom.xml
+++ b/stack/core/pom.xml
@@ -475,6 +475,14 @@
       <scope>test</scope>
     </dependency>
 
+
+    <dependency>
+      <groupId>org.mockito</groupId>
+      <artifactId>mockito-core</artifactId>
+      <version>${mockito.version}</version>
+      <scope>test</scope>
+    </dependency>
+
     <dependency>
       <groupId>org.jvnet.mock-javamail</groupId>
       <artifactId>mock-javamail</artifactId>
@@ -541,13 +549,6 @@
     </dependency>
 
     <dependency>
-        <groupId>org.jukito</groupId>
-        <artifactId>jukito</artifactId>
-        <version>1.4-UG</version>
-        <scope>test</scope>
-    </dependency>
-
-    <dependency>
       <groupId>com.codahale.metrics</groupId>
       <artifactId>metrics-core</artifactId>
       <version>${metrics.version}</version>

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityDeleteListenerTest.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityDeleteListenerTest.java b/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityDeleteListenerTest.java
index 16d2e79..6efab38 100644
--- a/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityDeleteListenerTest.java
+++ b/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityDeleteListenerTest.java
@@ -21,7 +21,6 @@ package org.apache.usergrid.corepersistence;
 import java.util.ArrayList;
 import java.util.UUID;
 
-import org.jukito.JukitoRunner;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
@@ -44,7 +43,7 @@ import static org.junit.Assert.assertEquals;
 import static org.mockito.Mockito.mock;
 import static org.mockito.Mockito.when;
 
-@RunWith(JukitoRunner.class)
+
 public class CpEntityDeleteListenerTest {
 
 

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityIndexDeleteListenerTest.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityIndexDeleteListenerTest.java b/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityIndexDeleteListenerTest.java
index 6b92d90..d1ee559 100644
--- a/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityIndexDeleteListenerTest.java
+++ b/stack/core/src/test/java/org/apache/usergrid/corepersistence/CpEntityIndexDeleteListenerTest.java
@@ -23,11 +23,9 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.UUID;
 
-import org.jukito.JukitoRunner;
 import org.junit.Before;
 import org.junit.Ignore;
 import org.junit.Test;
-import org.junit.runner.RunWith;
 
 import org.apache.usergrid.persistence.collection.CollectionScope;
 import org.apache.usergrid.persistence.collection.MvccEntity;
@@ -56,7 +54,6 @@ import static org.mockito.Mockito.mock;
 import static org.mockito.Mockito.verify;
 import static org.mockito.Mockito.when;
 
-@RunWith( JukitoRunner.class )
 @Ignore("Needs updated")
 public class CpEntityIndexDeleteListenerTest {
     EntityIndex entityIndex;

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/_maven.repositories
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/_maven.repositories b/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/_maven.repositories
deleted file mode 100644
index 49ede0f..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/_maven.repositories
+++ /dev/null
@@ -1,4 +0,0 @@
-#NOTE: This is an internal implementation file, its format can be changed without prior notice.
-#Thu Dec 12 21:34:16 EET 2013
-jukito-build-tools-1.4-UG.pom>=
-jukito-build-tools-1.4-UG.jar>=

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/jukito-build-tools-1.4-UG.jar
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/jukito-build-tools-1.4-UG.jar b/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/jukito-build-tools-1.4-UG.jar
deleted file mode 100644
index 9cc5b09..0000000
Binary files a/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/jukito-build-tools-1.4-UG.jar and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/jukito-build-tools-1.4-UG.pom
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/jukito-build-tools-1.4-UG.pom b/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/jukito-build-tools-1.4-UG.pom
deleted file mode 100644
index 7d34775..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/1.4-UG/jukito-build-tools-1.4-UG.pom
+++ /dev/null
@@ -1,13 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<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/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-
-    <parent>
-        <groupId>org.jukito</groupId>
-        <artifactId>jukito-parent</artifactId>
-        <version>1.4-UG</version>
-    </parent>
-
-    <artifactId>jukito-build-tools</artifactId>
-    <name>Jukito Build Tools</name>
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/maven-metadata-local.xml
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/maven-metadata-local.xml b/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/maven-metadata-local.xml
deleted file mode 100644
index 63b0601..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito-build-tools/maven-metadata-local.xml
+++ /dev/null
@@ -1,12 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<metadata>
-  <groupId>org.jukito</groupId>
-  <artifactId>jukito-build-tools</artifactId>
-  <versioning>
-    <release>1.4-UG</release>
-    <versions>
-      <version>1.4-UG</version>
-    </versions>
-    <lastUpdated>20131212193416</lastUpdated>
-  </versioning>
-</metadata>

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-parent/1.4-UG/_maven.repositories
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-parent/1.4-UG/_maven.repositories b/stack/corepersistence/m2/repository/org/jukito/jukito-parent/1.4-UG/_maven.repositories
deleted file mode 100644
index 851dbbd..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito-parent/1.4-UG/_maven.repositories
+++ /dev/null
@@ -1,3 +0,0 @@
-#NOTE: This is an internal implementation file, its format can be changed without prior notice.
-#Thu Dec 12 21:34:15 EET 2013
-jukito-parent-1.4-UG.pom>=

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-parent/1.4-UG/jukito-parent-1.4-UG.pom
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-parent/1.4-UG/jukito-parent-1.4-UG.pom b/stack/corepersistence/m2/repository/org/jukito/jukito-parent/1.4-UG/jukito-parent-1.4-UG.pom
deleted file mode 100644
index 809106e..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito-parent/1.4-UG/jukito-parent-1.4-UG.pom
+++ /dev/null
@@ -1,313 +0,0 @@
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-
-    <parent>
-        <groupId>org.sonatype.oss</groupId>
-        <artifactId>oss-parent</artifactId>
-        <version>7</version>
-    </parent>
-
-    <groupId>org.jukito</groupId>
-    <artifactId>jukito-parent</artifactId>
-    <version>1.4-UG</version>
-    <packaging>pom</packaging>
-    <name>Jukito</name>
-    <inceptionYear>2010</inceptionYear>
-    <description>A testing framework with automocking base on JUnit, Guice and Mokito.</description>
-    <url>http://jukito.org</url>
-
-    <licenses>
-        <license>
-            <name>Apache 2</name>
-            <url>http://www.apache.org/licenses/LICENSE-2.0.txt</url>
-            <distribution>repo</distribution>
-            <comments>A business-friendly OSS license</comments>
-        </license>
-    </licenses>
-
-    <organization>
-        <name>ArcBees Inc.</name>
-        <url>http://arcbees.com</url>
-    </organization>
-
-    <developers>
-        <developer>
-            <name>Philippe Beaudoin</name>
-            <email>philippe.beaudoin@gmail.com</email>
-            <url>http://www.google.com/profiles/philippe.beaudoin</url>
-            <organization>ArcBees</organization>
-            <organizationUrl>http://arcbees.com</organizationUrl>
-            <roles>
-                <role>architect</role>
-                <role>lead developer</role>
-            </roles>
-            <timezone>-8</timezone>
-            <properties>
-                <picUrl>http://goo.gl/xV2K8</picUrl>
-            </properties>
-        </developer>
-        <developer>
-            <name>Christian Goudreau</name>
-            <email>goudreau.christian@gmail.com</email>
-            <organization>ArcBees</organization>
-            <organizationUrl>http://arcbees.com</organizationUrl>
-            <roles>
-                <role>developer</role>
-            </roles>
-            <timezone>-5</timezone>
-        </developer>
-    </developers>
-
-    <scm>
-        <connection>scm:git:git://github.com/ArcBees/Jukito.git/</connection>
-        <developerConnection>scm:git:https://git@github.com/ArcBees/Jukito.git</developerConnection>
-        <url>https://github.com/ArcBees/Jukito</url>
-    </scm>
-
-    <issueManagement>
-        <system>GitHub Issues</system>
-        <url>https://github.com/ArcBees/Jukito/issues</url>
-    </issueManagement>
-
-    <ciManagement>
-        <system>Team City</system>
-        <url>http://teamcity.gonevertical.org</url>
-    </ciManagement>
-
-    <mailingLists>
-        <mailingList>
-            <name>Development</name>
-            <subscribe>jukito+subscribe@googlegroups.com</subscribe>
-            <unsubscribe>jukito+unsubscribe@googlegroups.com</unsubscribe>
-            <post>jukito@googlegroups.com</post>
-            <archive>http://groups.google.com/group/jukito</archive>
-        </mailingList>
-    </mailingLists>
-
-    <properties>
-        <target.jdk>1.6</target.jdk>
-        <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
-        <project.reporting.outputEncoding>UTF-8</project.reporting.outputEncoding>
-
-        <guice.version>3.0</guice.version>
-        <junit.version>4.11</junit.version>
-        <mockito.version>1.9.5</mockito.version>
-
-        <maven-checkstyle-plugin.version>2.10</maven-checkstyle-plugin.version>
-        <maven-compiler-plugin.version>3.0</maven-compiler-plugin.version>
-        <maven-deploy-plugin.version>2.7</maven-deploy-plugin.version>
-        <maven-eclipse-plugin.version>2.9</maven-eclipse-plugin.version>
-        <maven-javadoc-plugin.version>2.9</maven-javadoc-plugin.version>
-        <maven-source-plugin.version>2.2.1</maven-source-plugin.version>
-        <maven-surefire-plugin.version>2.14.1</maven-surefire-plugin.version>
-        <animal-sniffer-maven-plugin.version>1.9</animal-sniffer-maven-plugin.version>
-        <github.version>0.7</github.version>
-    </properties>
-
-    <modules>
-        <module>jukito-build-tools</module>
-        <module>jukito</module>
-        <module>jukito-samples</module>
-    </modules>
-
-    <build>
-        <pluginManagement>
-            <plugins>
-                <plugin>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-compiler-plugin</artifactId>
-                    <version>${maven-compiler-plugin.version}</version>
-                    <configuration>
-                        <source>${target.jdk}</source>
-                        <target>${target.jdk}</target>
-                        <encoding>${project.build.sourceEncoding}</encoding>
-                    </configuration>
-                </plugin>
-
-                <plugin>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-surefire-plugin</artifactId>
-                    <version>${maven-surefire-plugin.version}</version>
-                    <configuration>
-                        <includes>
-                            <include>**/*Test.java</include>
-                            <include>**/*TestCase.java</include>
-                        </includes>
-                    </configuration>
-                </plugin>
-
-                <plugin>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-deploy-plugin</artifactId>
-                    <version>${maven-deploy-plugin.version}</version>
-                </plugin>
-
-                <plugin>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-checkstyle-plugin</artifactId>
-                    <version>${maven-checkstyle-plugin.version}</version>
-                    <configuration>
-                        <configLocation>/org/jukito/checkstyle.xml</configLocation>
-                        <suppressionsLocation>/org/jukito/suppressions.xml</suppressionsLocation>
-                        <propertyExpansion>checkstyle.root=/org/jukito/</propertyExpansion>
-                        <consoleOutput>true</consoleOutput>
-                        <failsOnError>true</failsOnError>
-                        <linkXRef>false</linkXRef>
-                        <includeTestSourceDirectory>true</includeTestSourceDirectory>
-                    </configuration>
-                    <executions>
-                        <execution>
-                            <id>validate</id>
-                            <phase>validate</phase>
-                            <goals>
-                                <goal>checkstyle</goal>
-                            </goals>
-                        </execution>
-                    </executions>
-                    <dependencies>
-                        <dependency>
-                            <groupId>org.jukito</groupId>
-                            <artifactId>jukito-build-tools</artifactId>
-                            <version>${project.version}</version>
-                        </dependency>
-                    </dependencies>
-                </plugin>
-
-                <plugin>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-source-plugin</artifactId>
-                    <version>${maven-source-plugin.version}</version>
-                    <executions>
-                        <execution>
-                            <goals>
-                                <goal>jar</goal>
-                            </goals>
-                        </execution>
-                    </executions>
-                </plugin>
-
-                <plugin>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-release-plugin</artifactId>
-                    <configuration>
-                        <autoVersionSubmodules>true</autoVersionSubmodules>
-                        <useReleaseProfile>false</useReleaseProfile>
-                        <releaseProfiles>release</releaseProfiles>
-                        <arguments>-Psonatype-oss-release -Prelease -Dgpg.passphrase=${gpg.passphrase}</arguments>
-                    </configuration>
-                </plugin>
-
-                <plugin>
-                    <groupId>org.codehaus.mojo</groupId>
-                    <artifactId>animal-sniffer-maven-plugin</artifactId>
-                    <version>${animal-sniffer-maven-plugin.version}</version>
-                    <configuration>
-                        <signature>
-                            <groupId>org.codehaus.mojo.signature</groupId>
-                            <artifactId>java15</artifactId>
-                            <version>1.0</version>
-                        </signature>
-                    </configuration>
-                    <executions>
-                        <execution>
-                            <phase>process-classes</phase>
-                            <goals>
-                                <goal>check</goal>
-                            </goals>
-                        </execution>
-                    </executions>
-                </plugin>
-
-                <!-- run 'mvn javadoc:aggregate' to generate -->
-                <!-- run 'mvn javadoc:aggregate -X' to debug -->
-                <plugin>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-javadoc-plugin</artifactId>
-                    <version>${maven-javadoc-plugin.version}</version>
-                    <configuration>
-                        <maxmemory>2048</maxmemory>
-                        <failOnError>true</failOnError>
-                        <doctitle>Jukito Javadocs</doctitle>
-                        <links>
-                            <link>http://download.oracle.com/javase/6/docs/api/</link>
-                            <link>http://google-web-toolkit.googlecode.com/svn/javadoc/latest/</link>
-                            <link>http://google-gin.googlecode.com/svn/trunk/javadoc/</link>
-                            <link>http://google-guice.googlecode.com/svn/trunk/javadoc/</link>
-                            <link>http://aopalliance.sourceforge.net/doc/</link>
-                            <link>https://developers.google.com/appengine/docs/java/javadoc/</link>
-                            <link>http://docs.guava-libraries.googlecode.com/git/javadoc/</link>
-                        </links>
-                        <outputDirectory>${project.build.directory}/javadoc</outputDirectory>
-                        <reportOutputDirectory>${project.reporting.outputDirectory}/javadoc</reportOutputDirectory>
-                        <excludes>
-                            <exclude>**/*.txt</exclude>
-                        </excludes>
-                        <header>
-                            <![CDATA[
-                            <a href="https://github.com/ArcBees/Jukito" target="_blank">Back to Jukito Home</a>
-                        ]]>
-                        </header>
-                    </configuration>
-                </plugin>
-
-                <!-- run 'mvn site' to upload -->
-                <!-- run 'mvn site -X' to debug and upload. -->
-                <plugin>
-                    <groupId>com.github.github</groupId>
-                    <artifactId>site-maven-plugin</artifactId>
-                    <version>${github.version}</version>
-                    <configuration>
-                        <!-- <dryRun>true</dryRun> -->
-                        <message>Creating site for ${project.version}</message>
-                        <!-- github > sets the ~/.m2/setting.xml server id profile -->
-                        <server>github</server>
-                        <excludes>
-                            <exclude>*.DS_Store</exclude>
-                            <exclude>*.sh</exclude>
-                            <exclude>options</exclude>
-                            <exclude>packages</exclude>
-                        </excludes>
-                        <force>true</force>
-                        <merge>true</merge>
-                    </configuration>
-                    <executions>
-                        <execution>
-                            <phase>site</phase>
-                            <goals>
-                                <goal>site</goal>
-                            </goals>
-                        </execution>
-                    </executions>
-                </plugin>
-            </plugins>
-        </pluginManagement>
-    </build>
-
-    <dependencyManagement>
-        <dependencies>
-            <dependency>
-                <groupId>org.mockito</groupId>
-                <artifactId>mockito-core</artifactId>
-                <version>${mockito.version}</version>
-            </dependency>
-
-            <dependency>
-                <groupId>junit</groupId>
-                <artifactId>junit</artifactId>
-                <version>${junit.version}</version>
-            </dependency>
-
-            <dependency>
-                <groupId>com.google.inject</groupId>
-                <artifactId>guice</artifactId>
-                <version>${guice.version}</version>
-            </dependency>
-
-            <dependency>
-                <groupId>com.google.inject.extensions</groupId>
-                <artifactId>guice-assistedinject</artifactId>
-                <version>${guice.version}</version>
-            </dependency>
-        </dependencies>
-    </dependencyManagement>
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-parent/maven-metadata-local.xml
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-parent/maven-metadata-local.xml b/stack/corepersistence/m2/repository/org/jukito/jukito-parent/maven-metadata-local.xml
deleted file mode 100644
index 436d7df..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito-parent/maven-metadata-local.xml
+++ /dev/null
@@ -1,12 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<metadata>
-  <groupId>org.jukito</groupId>
-  <artifactId>jukito-parent</artifactId>
-  <versioning>
-    <release>1.4-UG</release>
-    <versions>
-      <version>1.4-UG</version>
-    </versions>
-    <lastUpdated>20131212193415</lastUpdated>
-  </versioning>
-</metadata>

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/_maven.repositories
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/_maven.repositories b/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/_maven.repositories
deleted file mode 100644
index f034661..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/_maven.repositories
+++ /dev/null
@@ -1,4 +0,0 @@
-#NOTE: This is an internal implementation file, its format can be changed without prior notice.
-#Thu Dec 12 21:34:50 EET 2013
-jukito-samples-1.4-UG.jar>=
-jukito-samples-1.4-UG.pom>=

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/jukito-samples-1.4-UG.jar
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/jukito-samples-1.4-UG.jar b/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/jukito-samples-1.4-UG.jar
deleted file mode 100644
index fd53ad9..0000000
Binary files a/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/jukito-samples-1.4-UG.jar and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/jukito-samples-1.4-UG.pom
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/jukito-samples-1.4-UG.pom b/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/jukito-samples-1.4-UG.pom
deleted file mode 100644
index c424410..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito-samples/1.4-UG/jukito-samples-1.4-UG.pom
+++ /dev/null
@@ -1,33 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<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/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-
-    <parent>
-        <groupId>org.jukito</groupId>
-        <artifactId>jukito-parent</artifactId>
-        <version>1.4-UG</version>
-    </parent>
-
-    <artifactId>jukito-samples</artifactId>
-    <name>Jukito Samples</name>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.jukito</groupId>
-            <artifactId>jukito-build-tools</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>com.google.inject</groupId>
-            <artifactId>guice</artifactId>
-        </dependency>
-
-        <!-- Test dependencies -->
-        <dependency>
-            <groupId>org.jukito</groupId>
-            <artifactId>jukito</artifactId>
-            <version>${project.version}</version>
-            <scope>test</scope>
-        </dependency>
-    </dependencies>
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito-samples/maven-metadata-local.xml
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito-samples/maven-metadata-local.xml b/stack/corepersistence/m2/repository/org/jukito/jukito-samples/maven-metadata-local.xml
deleted file mode 100644
index 4ecb506..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito-samples/maven-metadata-local.xml
+++ /dev/null
@@ -1,12 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<metadata>
-  <groupId>org.jukito</groupId>
-  <artifactId>jukito-samples</artifactId>
-  <versioning>
-    <release>1.4-UG</release>
-    <versions>
-      <version>1.4-UG</version>
-    </versions>
-    <lastUpdated>20131212193450</lastUpdated>
-  </versioning>
-</metadata>

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/_maven.repositories
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/_maven.repositories b/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/_maven.repositories
deleted file mode 100644
index bbe77c7..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/_maven.repositories
+++ /dev/null
@@ -1,5 +0,0 @@
-#NOTE: This is an internal implementation file, its format can be changed without prior notice.
-#Thu Dec 12 21:34:49 EET 2013
-jukito-1.4-UG.pom>=
-jukito-1.4-UG-sources.jar>=
-jukito-1.4-UG.jar>=

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG-sources.jar
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG-sources.jar b/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG-sources.jar
deleted file mode 100644
index dfd6cfc..0000000
Binary files a/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG-sources.jar and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG.jar
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG.jar b/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG.jar
deleted file mode 100644
index ade247c..0000000
Binary files a/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG.jar and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG.pom
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG.pom b/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG.pom
deleted file mode 100644
index 25884e8..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito/1.4-UG/jukito-1.4-UG.pom
+++ /dev/null
@@ -1,93 +0,0 @@
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-
-    <parent>
-        <groupId>org.jukito</groupId>
-        <artifactId>jukito-parent</artifactId>
-        <version>1.4-UG</version>
-    </parent>
-
-    <artifactId>jukito</artifactId>
-    <packaging>jar</packaging>
-    <name>jukito</name>
-
-    <build>
-        <plugins>
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-compiler-plugin</artifactId>
-            </plugin>
-
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-surefire-plugin</artifactId>
-            </plugin>
-
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-deploy-plugin</artifactId>
-            </plugin>
-
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-checkstyle-plugin</artifactId>
-            </plugin>
-
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-source-plugin</artifactId>
-            </plugin>
-
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-eclipse-plugin</artifactId>
-            </plugin>
-
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-release-plugin</artifactId>
-            </plugin>
-
-            <plugin>
-                <groupId>org.codehaus.mojo</groupId>
-                <artifactId>animal-sniffer-maven-plugin</artifactId>
-            </plugin>
-
-            <!-- run 'mvn javadoc:aggregate' to generate -->
-            <!-- run 'mvn javadoc:aggregate -X' to debug -->
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-javadoc-plugin</artifactId>
-            </plugin>
-
-            <!-- run 'mvn site' to upload -->
-            <!-- run 'mvn site -X' to debug and upload. -->
-            <plugin>
-                <groupId>com.github.github</groupId>
-                <artifactId>site-maven-plugin</artifactId>
-            </plugin>
-        </plugins>
-    </build>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.mockito</groupId>
-            <artifactId>mockito-core</artifactId>
-        </dependency>
-
-        <dependency>
-            <groupId>junit</groupId>
-            <artifactId>junit</artifactId>
-        </dependency>
-
-        <dependency>
-            <groupId>com.google.inject</groupId>
-            <artifactId>guice</artifactId>
-        </dependency>
-
-        <dependency>
-            <groupId>com.google.inject.extensions</groupId>
-            <artifactId>guice-assistedinject</artifactId>
-        </dependency>
-    </dependencies>
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/corepersistence/m2/repository/org/jukito/jukito/maven-metadata-local.xml
----------------------------------------------------------------------
diff --git a/stack/corepersistence/m2/repository/org/jukito/jukito/maven-metadata-local.xml b/stack/corepersistence/m2/repository/org/jukito/jukito/maven-metadata-local.xml
deleted file mode 100644
index 1ad86bf..0000000
--- a/stack/corepersistence/m2/repository/org/jukito/jukito/maven-metadata-local.xml
+++ /dev/null
@@ -1,12 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<metadata>
-  <groupId>org.jukito</groupId>
-  <artifactId>jukito</artifactId>
-  <versioning>
-    <release>1.4-UG</release>
-    <versions>
-      <version>1.4-UG</version>
-    </versions>
-    <lastUpdated>20131212193449</lastUpdated>
-  </versioning>
-</metadata>

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/2aeefd51/stack/pom.xml
----------------------------------------------------------------------
diff --git a/stack/pom.xml b/stack/pom.xml
index 2a2fcb0..34cf5aa 100644
--- a/stack/pom.xml
+++ b/stack/pom.xml
@@ -116,6 +116,7 @@
     <antlr.version>3.4</antlr.version>
     <tika.version>1.4</tika.version>
     <elasticsearch.version>1.3.2</elasticsearch.version>
+    <mockito.version>1.10.8</mockito.version>
 
     <usergrid.it.forkCount>3</usergrid.it.forkCount>
     <usergrid.it.reuseForks>false</usergrid.it.reuseForks>
@@ -1977,13 +1978,13 @@
     </plugins>
   </reporting>
 
-    <repositories>
-        <repository>
-            <id>local-dependencies</id>
-            <name>local-depedendencies</name>
-            <url>file://${project.basedir}/../m2/repository</url>
-        </repository>
-    </repositories>
+    <!--<repositories>-->
+        <!--<repository>-->
+            <!--<id>local-dependencies</id>-->
+            <!--<name>local-depedendencies</name>-->
+            <!--<url>file://${project.basedir}/../m2/repository</url>-->
+        <!--</repository>-->
+    <!--</repositories>-->
 
     <scm>
     	<url>https://git-wip-us.apache.org/repos/asf/incubator-usergrid.git</url>