You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@usergrid.apache.org by sn...@apache.org on 2015/11/17 13:55:49 UTC

[1/4] usergrid git commit: Fix spelling error in class names.

Repository: usergrid
Updated Branches:
  refs/heads/ignores 13853662e -> 41dde128c


Fix spelling error in class names.


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

Branch: refs/heads/ignores
Commit: f62e0aa5869785b459571cab306579ca21bf0be1
Parents: 1385366
Author: Dave Johnson <sn...@apache.org>
Authored: Tue Nov 17 07:51:29 2015 -0500
Committer: Dave Johnson <sn...@apache.org>
Committed: Tue Nov 17 07:51:29 2015 -0500

----------------------------------------------------------------------
 .../usergrid/batch/job/OnlyOnceExceution.java   | 123 -----------------
 .../usergrid/batch/job/OnlyOnceExecution.java   | 122 +++++++++++++++++
 .../job/OnlyOnceUnlockOnFailExceution.java      | 133 -------------------
 .../job/OnlyOnceUnlockOnFailExecution.java      | 132 ++++++++++++++++++
 4 files changed, 254 insertions(+), 256 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/usergrid/blob/f62e0aa5/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceExceution.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceExceution.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceExceution.java
deleted file mode 100644
index 6109f1f..0000000
--- a/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceExceution.java
+++ /dev/null
@@ -1,123 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.usergrid.batch.job;
-
-
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.TimeUnit;
-
-import org.junit.Ignore;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.springframework.stereotype.Component;
-
-import org.apache.usergrid.batch.JobExecution;
-
-
-/**
- * A job that will sleep for the amount of time specified. Used to check that our counter is only ever run once.
- *
- * @author tnine
- */
-@Component("onlyOnceExceution")
-@Ignore("Not a test")
-public class OnlyOnceExceution extends OnlyOnceJob {
-
-    private static final Logger logger = LoggerFactory.getLogger( OnlyOnceExceution.class );
-
-    private CountDownLatch latch = null;
-    private CountDownLatch sleptLatch = new CountDownLatch( 1 );
-    private long timeout;
-    private boolean slept = false;
-    private long delay;
-
-
-    /**
-     *
-     */
-    public OnlyOnceExceution() {
-    }
-
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see
-     * org.apache.usergrid.batch.job.OnlyOnceJob#doJob(org.apache.usergrid.batch.JobExecution)
-     */
-    @Override
-    protected void doJob( JobExecution execution ) throws Exception {
-        logger.info( "Running only once execution" );
-
-        latch.countDown();
-
-
-        if ( !slept ) {
-            logger.info( "Sleeping in only once execution" );
-            Thread.sleep( timeout );
-            slept = true;
-            sleptLatch.countDown();
-        }
-    }
-
-
-    /* (non-Javadoc)
-     * @see org.apache.usergrid.batch.job.OnlyOnceJob#getDelay(org.apache.usergrid.batch.JobExecution)
-     */
-    @Override
-    protected long getDelay( JobExecution execution ) throws Exception {
-        return delay;
-    }
-
-
-    public void setDelay( long delay ) {
-        this.delay = delay;
-    }
-
-
-    public void setLatch( int calls ) {
-        latch = new CountDownLatch( calls );
-    }
-
-
-    public boolean waitForCount( long timeout, TimeUnit unit ) throws InterruptedException {
-        return latch.await( timeout, unit );
-    }
-
-
-    public boolean waitForSleep( long timeout, TimeUnit unit ) throws InterruptedException {
-        return sleptLatch.await( timeout, unit );
-    }
-
-
-    /** @return the timeout */
-    public long getTimeout() {
-        return timeout;
-    }
-
-
-    /** @param timeout the timeout to set */
-    public void setTimeout( long timeout ) {
-        this.timeout = timeout;
-    }
-
-
-    @Override
-    public void dead( final JobExecution execution ) throws Exception {
-        //To change body of implemented methods use File | Settings | File Templates.
-    }
-}

http://git-wip-us.apache.org/repos/asf/usergrid/blob/f62e0aa5/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceExecution.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceExecution.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceExecution.java
new file mode 100644
index 0000000..ed9e8f4
--- /dev/null
+++ b/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceExecution.java
@@ -0,0 +1,122 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.usergrid.batch.job;
+
+
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.TimeUnit;
+
+import org.junit.Ignore;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+import org.springframework.stereotype.Component;
+
+import org.apache.usergrid.batch.JobExecution;
+
+
+/**
+ * A job that will sleep for the amount of time specified. Used to check that our counter is only ever run once.
+ *
+ * @author tnine
+ */
+@Component("onlyOnceExecution")
+public class OnlyOnceExecution extends OnlyOnceJob {
+
+    private static final Logger logger = LoggerFactory.getLogger( OnlyOnceExecution.class );
+
+    private CountDownLatch latch = null;
+    private CountDownLatch sleptLatch = new CountDownLatch( 1 );
+    private long timeout;
+    private boolean slept = false;
+    private long delay;
+
+
+    /**
+     *
+     */
+    public OnlyOnceExecution() {
+    }
+
+
+    /*
+     * (non-Javadoc)
+     *
+     * @see
+     * org.apache.usergrid.batch.job.OnlyOnceJob#doJob(org.apache.usergrid.batch.JobExecution)
+     */
+    @Override
+    protected void doJob( JobExecution execution ) throws Exception {
+        logger.info( "Running only once execution" );
+
+        latch.countDown();
+
+
+        if ( !slept ) {
+            logger.info( "Sleeping in only once execution" );
+            Thread.sleep( timeout );
+            slept = true;
+            sleptLatch.countDown();
+        }
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.apache.usergrid.batch.job.OnlyOnceJob#getDelay(org.apache.usergrid.batch.JobExecution)
+     */
+    @Override
+    protected long getDelay( JobExecution execution ) throws Exception {
+        return delay;
+    }
+
+
+    public void setDelay( long delay ) {
+        this.delay = delay;
+    }
+
+
+    public void setLatch( int calls ) {
+        latch = new CountDownLatch( calls );
+    }
+
+
+    public boolean waitForCount( long timeout, TimeUnit unit ) throws InterruptedException {
+        return latch.await( timeout, unit );
+    }
+
+
+    public boolean waitForSleep( long timeout, TimeUnit unit ) throws InterruptedException {
+        return sleptLatch.await( timeout, unit );
+    }
+
+
+    /** @return the timeout */
+    public long getTimeout() {
+        return timeout;
+    }
+
+
+    /** @param timeout the timeout to set */
+    public void setTimeout( long timeout ) {
+        this.timeout = timeout;
+    }
+
+
+    @Override
+    public void dead( final JobExecution execution ) throws Exception {
+        //To change body of implemented methods use File | Settings | File Templates.
+    }
+}

http://git-wip-us.apache.org/repos/asf/usergrid/blob/f62e0aa5/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceUnlockOnFailExceution.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceUnlockOnFailExceution.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceUnlockOnFailExceution.java
deleted file mode 100644
index 6dd826a..0000000
--- a/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceUnlockOnFailExceution.java
+++ /dev/null
@@ -1,133 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.usergrid.batch.job;
-
-
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.TimeUnit;
-
-import org.junit.Ignore;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.springframework.stereotype.Component;
-
-import org.apache.usergrid.batch.JobExecution;
-
-
-/**
- * A job that will sleep for the amount of time specified. Used to check that our counter is only ever run once.  Checks
- * the lock is released on fail
- *
- * @author tnine
- */
-@Component("onlyOnceUnlockOnFailExceution")
-@Ignore("Not a test")
-public class OnlyOnceUnlockOnFailExceution extends OnlyOnceJob {
-
-    private static final Logger logger = LoggerFactory.getLogger( OnlyOnceUnlockOnFailExceution.class );
-
-    private CountDownLatch latch = null;
-    private CountDownLatch exception = new CountDownLatch( 1 );
-    private CountDownLatch completed = new CountDownLatch( 1 );
-    private long timeout;
-    private boolean slept = false;
-    private long delay;
-
-
-    /**
-     *
-     */
-    public OnlyOnceUnlockOnFailExceution() {
-    }
-
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see
-     * org.apache.usergrid.batch.job.OnlyOnceJob#doJob(org.apache.usergrid.batch.JobExecution)
-     */
-    @Override
-    protected void doJob( JobExecution execution ) throws Exception {
-        logger.info( "Running only once execution" );
-
-
-        latch.countDown();
-
-        if ( !slept ) {
-            logger.info( "Sleeping in only once execution" );
-            Thread.sleep( timeout );
-            slept = true;
-            exception.countDown();
-            throw new RuntimeException( "I failed to run correctly, I should be retried" );
-        }
-
-        completed.countDown();
-    }
-
-
-    /* (non-Javadoc)
-     * @see org.apache.usergrid.batch.job.OnlyOnceJob#getDelay(org.apache.usergrid.batch.JobExecution)
-     */
-    @Override
-    protected long getDelay( JobExecution execution ) throws Exception {
-        return delay;
-    }
-
-
-    public void setDelay( long delay ) {
-        this.delay = delay;
-    }
-
-
-    public void setLatch( int calls ) {
-        latch = new CountDownLatch( calls );
-    }
-
-
-    public boolean waitForCount( long timeout, TimeUnit unit ) throws InterruptedException {
-        return latch.await( timeout, unit );
-    }
-
-
-    public boolean waitForException( long timeout, TimeUnit unit ) throws InterruptedException {
-        return exception.await( timeout, unit );
-    }
-
-
-    public boolean waitForCompletion( long timeout, TimeUnit unit ) throws InterruptedException {
-        return completed.await( timeout, unit );
-    }
-
-
-    /** @return the timeout */
-    public long getTimeout() {
-        return timeout;
-    }
-
-
-    /** @param timeout the timeout to set */
-    public void setTimeout( long timeout ) {
-        this.timeout = timeout;
-    }
-
-
-    @Override
-    public void dead( final JobExecution execution ) throws Exception {
-        //To change body of implemented methods use File | Settings | File Templates.
-    }
-}

http://git-wip-us.apache.org/repos/asf/usergrid/blob/f62e0aa5/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceUnlockOnFailExecution.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceUnlockOnFailExecution.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceUnlockOnFailExecution.java
new file mode 100644
index 0000000..53fde15
--- /dev/null
+++ b/stack/core/src/test/java/org/apache/usergrid/batch/job/OnlyOnceUnlockOnFailExecution.java
@@ -0,0 +1,132 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.usergrid.batch.job;
+
+
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.TimeUnit;
+
+import org.junit.Ignore;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+import org.springframework.stereotype.Component;
+
+import org.apache.usergrid.batch.JobExecution;
+
+
+/**
+ * A job that will sleep for the amount of time specified. Used to check that our counter is only ever run once.  Checks
+ * the lock is released on fail
+ *
+ * @author tnine
+ */
+@Component("onlyOnceUnlockOnFailExecution")
+public class OnlyOnceUnlockOnFailExecution extends OnlyOnceJob {
+
+    private static final Logger logger = LoggerFactory.getLogger( OnlyOnceUnlockOnFailExecution.class );
+
+    private CountDownLatch latch = null;
+    private CountDownLatch exception = new CountDownLatch( 1 );
+    private CountDownLatch completed = new CountDownLatch( 1 );
+    private long timeout;
+    private boolean slept = false;
+    private long delay;
+
+
+    /**
+     *
+     */
+    public OnlyOnceUnlockOnFailExecution() {
+    }
+
+
+    /*
+     * (non-Javadoc)
+     *
+     * @see
+     * org.apache.usergrid.batch.job.OnlyOnceJob#doJob(org.apache.usergrid.batch.JobExecution)
+     */
+    @Override
+    protected void doJob( JobExecution execution ) throws Exception {
+        logger.info( "Running only once execution" );
+
+
+        latch.countDown();
+
+        if ( !slept ) {
+            logger.info( "Sleeping in only once execution" );
+            Thread.sleep( timeout );
+            slept = true;
+            exception.countDown();
+            throw new RuntimeException( "I failed to run correctly, I should be retried" );
+        }
+
+        completed.countDown();
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.apache.usergrid.batch.job.OnlyOnceJob#getDelay(org.apache.usergrid.batch.JobExecution)
+     */
+    @Override
+    protected long getDelay( JobExecution execution ) throws Exception {
+        return delay;
+    }
+
+
+    public void setDelay( long delay ) {
+        this.delay = delay;
+    }
+
+
+    public void setLatch( int calls ) {
+        latch = new CountDownLatch( calls );
+    }
+
+
+    public boolean waitForCount( long timeout, TimeUnit unit ) throws InterruptedException {
+        return latch.await( timeout, unit );
+    }
+
+
+    public boolean waitForException( long timeout, TimeUnit unit ) throws InterruptedException {
+        return exception.await( timeout, unit );
+    }
+
+
+    public boolean waitForCompletion( long timeout, TimeUnit unit ) throws InterruptedException {
+        return completed.await( timeout, unit );
+    }
+
+
+    /** @return the timeout */
+    public long getTimeout() {
+        return timeout;
+    }
+
+
+    /** @param timeout the timeout to set */
+    public void setTimeout( long timeout ) {
+        this.timeout = timeout;
+    }
+
+
+    @Override
+    public void dead( final JobExecution execution ) throws Exception {
+        //To change body of implemented methods use File | Settings | File Templates.
+    }
+}


[3/4] usergrid git commit: Use JUnut Categories to exclude too heavy (aka stress) tests and experimental tests.

Posted by sn...@apache.org.
Use JUnut Categories to exclude too heavy (aka stress) tests and experimental tests.


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

Branch: refs/heads/ignores
Commit: 99b932ada3809a33ad8a824b9177d427edb6feba
Parents: d1f1710
Author: Dave Johnson <sn...@apache.org>
Authored: Tue Nov 17 07:54:39 2015 -0500
Committer: Dave Johnson <sn...@apache.org>
Committed: Tue Nov 17 07:54:39 2015 -0500

----------------------------------------------------------------------
 stack/build-tools/pom.xml                       | 11 +++++
 stack/config/pom.xml                            | 10 +++++
 .../clustering/hazelcast/HazelcastTest.java     |  5 ++-
 .../usergrid/corepersistence/index/RxTest.java  |  6 ++-
 .../persistence/PerformanceEntityReadTest.java  |  4 +-
 .../persistence/PerformanceEntityWriteTest.java |  4 +-
 .../EntityCollectionManagerStressTest.java      |  6 ++-
 .../impl/SerializationComparison.java           |  5 ++-
 stack/corepersistence/common/pom.xml            |  1 +
 stack/corepersistence/graph/pom.xml             |  1 +
 .../persistence/graph/GraphManagerLoadTest.java |  7 ++--
 .../graph/GraphManagerShardConsistencyIT.java   |  4 +-
 .../graph/GraphManagerStressTest.java           | 44 +++++++++-----------
 .../serialization/EdgeSerializationTest.java    |  6 ++-
 stack/corepersistence/map/pom.xml               |  1 +
 .../org/apache/usergrid/ExperimentalTest.java   | 22 ++++++++++
 .../java/org/apache/usergrid/StressTest.java    | 22 ++++++++++
 stack/corepersistence/pom.xml                   |  2 +
 stack/corepersistence/queryindex/pom.xml        |  5 +--
 .../index/impl/IndexLoadTestsIT.java            |  3 ++
 stack/pom.xml                                   | 12 ++----
 stack/rest/pom.xml                              |  2 +
 stack/services/pom.xml                          |  8 +---
 .../providers/PingIdentityProviderIT.java       |  4 +-
 .../AbstractServiceNotificationIT.java          |  1 +
 .../apns/NotificationsServiceIT.java            |  1 +
 .../gcm/NotificationsServiceIT.java             |  2 +
 27 files changed, 139 insertions(+), 60 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/build-tools/pom.xml
----------------------------------------------------------------------
diff --git a/stack/build-tools/pom.xml b/stack/build-tools/pom.xml
index 149c1a7..2001396 100644
--- a/stack/build-tools/pom.xml
+++ b/stack/build-tools/pom.xml
@@ -38,4 +38,15 @@
         o to adjust checkstyle settings or suppress reporting please us the
           files contained under src/main/resources/usergrid
   -->
+
+    <!-- the surefire excludedGroups configuration in parent requires this dependency here -->
+    <dependencies>
+        <dependency>
+            <groupId>junit</groupId>
+            <artifactId>junit</artifactId>
+            <version>4.12</version>
+            <scope>test</scope>
+        </dependency>
+    </dependencies>
+
 </project>

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/config/pom.xml
----------------------------------------------------------------------
diff --git a/stack/config/pom.xml b/stack/config/pom.xml
index 915d32a..4ee1a3b 100644
--- a/stack/config/pom.xml
+++ b/stack/config/pom.xml
@@ -42,4 +42,14 @@
       </resource>
     </resources>
   </build>
+
+    <dependencies>
+        <dependency>
+            <groupId>junit</groupId>
+            <artifactId>junit</artifactId>
+            <version>4.12</version>
+            <scope>test</scope>
+        </dependency>
+    </dependencies>
+
 </project>

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/core/src/test/java/org/apache/usergrid/clustering/hazelcast/HazelcastTest.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/clustering/hazelcast/HazelcastTest.java b/stack/core/src/test/java/org/apache/usergrid/clustering/hazelcast/HazelcastTest.java
index 8f6226b..63a181e 100644
--- a/stack/core/src/test/java/org/apache/usergrid/clustering/hazelcast/HazelcastTest.java
+++ b/stack/core/src/test/java/org/apache/usergrid/clustering/hazelcast/HazelcastTest.java
@@ -20,10 +20,13 @@ package org.apache.usergrid.clustering.hazelcast;
 import java.util.Collection;
 import java.util.Set;
 
+import org.apache.usergrid.ExperimentalTest;
+import org.apache.usergrid.StressTest;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Ignore;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.springframework.beans.factory.config.AutowireCapableBeanFactory;
@@ -38,7 +41,7 @@ import com.hazelcast.core.Member;
 import com.hazelcast.core.MessageListener;
 
 
-@Ignore("Experimental test")
+@Category(ExperimentalTest.class)
 public class HazelcastTest implements InstanceListener, MessageListener<Object> {
 
     private static final Logger logger = LoggerFactory.getLogger( HazelcastTest.class );

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/core/src/test/java/org/apache/usergrid/corepersistence/index/RxTest.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/corepersistence/index/RxTest.java b/stack/core/src/test/java/org/apache/usergrid/corepersistence/index/RxTest.java
index 1a94aac..6bb8947 100644
--- a/stack/core/src/test/java/org/apache/usergrid/corepersistence/index/RxTest.java
+++ b/stack/core/src/test/java/org/apache/usergrid/corepersistence/index/RxTest.java
@@ -23,9 +23,11 @@ package org.apache.usergrid.corepersistence.index;
 import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.TimeUnit;
 
+import org.apache.usergrid.ExperimentalTest;
 import org.junit.Ignore;
 import org.junit.Test;
 
+import org.junit.experimental.categories.Category;
 import rx.Observable;
 import rx.Subscription;
 import rx.observables.ConnectableObservable;
@@ -41,7 +43,7 @@ import static org.junit.Assert.assertTrue;
 public class RxTest {
 
     @Test
-    @Ignore("This fails intermittently.  Possible race condition with Rx.  Need to investigate more.")
+    @Category(ExperimentalTest.class )
     public void testPublish() throws InterruptedException {
 
         final int count = 10;
@@ -64,7 +66,7 @@ public class RxTest {
 
 
     @Test
-    @Ignore("Experimental - seems like it should work, yet blocks forever")
+    @Category(ExperimentalTest.class )
     public void testConnectableObserver() throws InterruptedException {
 
         final int count = 10;

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityReadTest.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityReadTest.java b/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityReadTest.java
index f7435ef..88144c8 100644
--- a/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityReadTest.java
+++ b/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityReadTest.java
@@ -24,11 +24,13 @@ import java.util.Map;
 import java.util.UUID;
 import java.util.concurrent.TimeUnit;
 
+import org.apache.usergrid.StressTest;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Ignore;
 import org.junit.Rule;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -44,7 +46,7 @@ import com.codahale.metrics.Slf4jReporter;
 //@RunWith(JukitoRunner.class)
 //@UseModules({ GuiceModule.class })
 
-@Ignore("Kills embedded cassandra")
+@Category(StressTest.class)
 public class PerformanceEntityReadTest extends AbstractCoreIT {
     private static final Logger logger = LoggerFactory.getLogger(PerformanceEntityReadTest.class );
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityWriteTest.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityWriteTest.java b/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityWriteTest.java
index 341af90..3997615 100644
--- a/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityWriteTest.java
+++ b/stack/core/src/test/java/org/apache/usergrid/persistence/PerformanceEntityWriteTest.java
@@ -23,11 +23,13 @@ import java.util.List;
 import java.util.Map;
 import java.util.concurrent.TimeUnit;
 
+import org.apache.usergrid.StressTest;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Ignore;
 import org.junit.Rule;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -43,7 +45,7 @@ import com.codahale.metrics.Slf4jReporter;
 //@RunWith(JukitoRunner.class)
 //@UseModules({ GuiceModule.class })
 
-@Ignore("Kills embedded cassandra")
+@Category(StressTest.class)
 public class PerformanceEntityWriteTest extends AbstractCoreIT {
     private static final Logger LOG = LoggerFactory.getLogger( PerformanceEntityWriteTest.class );
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/EntityCollectionManagerStressTest.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/EntityCollectionManagerStressTest.java b/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/EntityCollectionManagerStressTest.java
index 20cf24e..1aabf75 100644
--- a/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/EntityCollectionManagerStressTest.java
+++ b/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/EntityCollectionManagerStressTest.java
@@ -21,9 +21,11 @@ package org.apache.usergrid.persistence.collection;
 import java.util.HashSet;
 import java.util.Set;
 
+import org.apache.usergrid.StressTest;
 import org.junit.Ignore;
 import org.junit.Rule;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 import org.junit.runner.RunWith;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -50,7 +52,7 @@ import static org.junit.Assert.assertNotNull;
 
 @RunWith(ITRunner.class)
 @UseModules(TestCollectionModule.class)
-@Ignore("Stress test should not be run in embedded mode")
+@Category(StressTest.class)
 public class EntityCollectionManagerStressTest {
     private static final Logger log = LoggerFactory.getLogger(
             EntityCollectionManagerStressTest.class );
@@ -58,7 +60,7 @@ public class EntityCollectionManagerStressTest {
     @Inject
     private EntityCollectionManagerFactory factory;
 
-      @Inject
+    @Inject
     @Rule
     public MigrationManagerRule migrationManagerRule;
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/serialization/impl/SerializationComparison.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/serialization/impl/SerializationComparison.java b/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/serialization/impl/SerializationComparison.java
index 660a6a9..a2ed6c7 100644
--- a/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/serialization/impl/SerializationComparison.java
+++ b/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/serialization/impl/SerializationComparison.java
@@ -23,8 +23,9 @@ package org.apache.usergrid.persistence.collection.serialization.impl;
 import java.io.IOException;
 import java.util.UUID;
 
-import org.junit.Ignore;
+import org.apache.usergrid.StressTest;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -48,6 +49,7 @@ import com.fasterxml.jackson.dataformat.smile.SmileFactory;
  *
  * @author tnine
  */
+@Category(StressTest.class)
 public class SerializationComparison {
 
     private static final Logger logger = LoggerFactory.getLogger( SerializationComparison.class );
@@ -56,7 +58,6 @@ public class SerializationComparison {
 
 
     @Test
-    @Ignore("Too heavy for normal build process?")
     public void smileSerialization() throws IOException {
         SmileFactory smile = new SmileFactory();
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/common/pom.xml
----------------------------------------------------------------------
diff --git a/stack/corepersistence/common/pom.xml b/stack/corepersistence/common/pom.xml
index 2082b04..0f54896 100644
--- a/stack/corepersistence/common/pom.xml
+++ b/stack/corepersistence/common/pom.xml
@@ -183,6 +183,7 @@
                         <version>${surefire.plugin.version}</version>
                         <configuration>
                             <argLine>-javaagent:${settings.localRepository}/org/jacoco/org.jacoco.agent/${jacoco.version}/org.jacoco.agent-${jacoco.version}-runtime.jar=destfile=${project.build.directory}/jacoco.exec</argLine>
+                            <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                         </configuration>
                     </plugin>
                 </plugins>

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/graph/pom.xml
----------------------------------------------------------------------
diff --git a/stack/corepersistence/graph/pom.xml b/stack/corepersistence/graph/pom.xml
index 23621fb..93fbbd5 100644
--- a/stack/corepersistence/graph/pom.xml
+++ b/stack/corepersistence/graph/pom.xml
@@ -104,6 +104,7 @@
                         <version>${surefire.plugin.version}</version>
                         <configuration>
                             <argLine>-javaagent:${settings.localRepository}/org/jacoco/org.jacoco.agent/${jacoco.version}/org.jacoco.agent-${jacoco.version}-runtime.jar=destfile=${project.build.directory}/jacoco.exec</argLine>
+                            <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                         </configuration>
                     </plugin>
                 </plugins>

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerLoadTest.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerLoadTest.java b/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerLoadTest.java
index 22683f6..a0be6a6 100644
--- a/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerLoadTest.java
+++ b/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerLoadTest.java
@@ -29,10 +29,12 @@ import java.util.concurrent.ExecutorService;
 import java.util.concurrent.Executors;
 import java.util.concurrent.Future;
 
+import org.apache.usergrid.StressTest;
 import org.junit.Before;
 import org.junit.Ignore;
 import org.junit.Rule;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 import org.junit.runner.RunWith;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -63,7 +65,7 @@ import static org.junit.Assert.fail;
 
 @RunWith( ITRunner.class )
 @UseModules( TestGraphModule.class )
-@Ignore("Not for testing during build.  Kills embedded Cassandra")
+@Category(StressTest.class)
 public class GraphManagerLoadTest {
     private static final Logger log = LoggerFactory.getLogger( GraphManagerLoadTest.class );
 
@@ -95,7 +97,6 @@ public class GraphManagerLoadTest {
     }
 
 
-//    @Ignore
     @Test
     public void writeThousandsSingleSource() throws InterruptedException, ExecutionException {
         EdgeGenerator generator = new EdgeGenerator() {
@@ -124,7 +125,7 @@ public class GraphManagerLoadTest {
 
 
     @Test
-    @Ignore("Too heavy for normal build process")
+    @Category(StressTest.class)
     public void writeThousandsSingleTarget() throws InterruptedException, ExecutionException {
         EdgeGenerator generator = new EdgeGenerator() {
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerShardConsistencyIT.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerShardConsistencyIT.java b/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerShardConsistencyIT.java
index 9000c75..45c3d80 100644
--- a/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerShardConsistencyIT.java
+++ b/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerShardConsistencyIT.java
@@ -39,10 +39,12 @@ import java.util.concurrent.atomic.AtomicLong;
 
 import javax.annotation.Nullable;
 
+import org.apache.usergrid.StressTest;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Ignore;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -393,7 +395,7 @@ public class GraphManagerShardConsistencyIT {
 
 
     @Test(timeout=120000)
-    @Ignore("This works, but is occasionally causing cassandra to fall over.  Unignore when merged with new shard strategy")
+    @Category(StressTest.class)
     public void writeThousandsDelete()
         throws InterruptedException, ExecutionException, MigrationException, UnsupportedEncodingException {
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerStressTest.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerStressTest.java b/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerStressTest.java
index 6a2efc9..98065ce 100644
--- a/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerStressTest.java
+++ b/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/GraphManagerStressTest.java
@@ -19,20 +19,10 @@
 package org.apache.usergrid.persistence.graph;
 
 
-import java.util.HashSet;
-import java.util.Set;
-import java.util.concurrent.CountDownLatch;
-
-import org.junit.Before;
-import org.junit.Ignore;
-import org.junit.Rule;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
+import com.google.common.base.Optional;
+import com.google.inject.Inject;
 import org.apache.commons.lang3.time.StopWatch;
-
+import org.apache.usergrid.StressTest;
 import org.apache.usergrid.persistence.core.guice.MigrationManagerRule;
 import org.apache.usergrid.persistence.core.scope.ApplicationScope;
 import org.apache.usergrid.persistence.core.test.ITRunner;
@@ -42,25 +32,29 @@ import org.apache.usergrid.persistence.graph.guice.TestGraphModule;
 import org.apache.usergrid.persistence.graph.impl.SimpleSearchByEdgeType;
 import org.apache.usergrid.persistence.model.entity.Id;
 import org.apache.usergrid.persistence.model.util.UUIDGenerator;
-
-import com.google.common.base.Optional;
-import com.google.inject.Inject;
-
+import org.junit.Before;
+import org.junit.Rule;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+import org.junit.runner.RunWith;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import rx.Observable;
 import rx.Subscriber;
 
+import java.util.HashSet;
+import java.util.Set;
+import java.util.concurrent.CountDownLatch;
+
 import static org.apache.usergrid.persistence.graph.test.util.EdgeTestUtils.createEdge;
-import static org.apache.usergrid.persistence.core.util.IdGenerator.createId;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.fail;
+import static org.junit.Assert.*;
 import static org.mockito.Mockito.mock;
 import static org.mockito.Mockito.when;
 
 
 @RunWith(ITRunner.class)
 @UseModules(TestGraphModule.class)
-@Ignore("Stress test should not be run in embedded mode")
+@Category(StressTest.class)
 public class GraphManagerStressTest {
     private static final Logger log = LoggerFactory.getLogger( GraphManagerStressTest.class );
 
@@ -89,7 +83,7 @@ public class GraphManagerStressTest {
 
 
     @Test
-    @Ignore("Too heavy for normal build process")
+    @Category(StressTest.class)
     public void writeThousands() throws InterruptedException {
         EdgeGenerator generator = new EdgeGenerator() {
 
@@ -177,7 +171,7 @@ public class GraphManagerStressTest {
     }
 
 
-    @Ignore("Too heavy for normal build process")
+    @Category(StressTest.class)
     @Test
     public void writeThousandsSingleSource() throws InterruptedException {
         EdgeGenerator generator = new EdgeGenerator() {
@@ -205,7 +199,7 @@ public class GraphManagerStressTest {
 
 
     @Test
-    @Ignore("Too heavy for normal build process")
+    @Category(StressTest.class)
     public void writeThousandsSingleTarget() throws InterruptedException {
         EdgeGenerator generator = new EdgeGenerator() {
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/serialization/EdgeSerializationTest.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/serialization/EdgeSerializationTest.java b/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/serialization/EdgeSerializationTest.java
index d875e83..d81413e 100644
--- a/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/serialization/EdgeSerializationTest.java
+++ b/stack/corepersistence/graph/src/test/java/org/apache/usergrid/persistence/graph/serialization/EdgeSerializationTest.java
@@ -25,10 +25,12 @@ import java.util.Iterator;
 import java.util.Set;
 import java.util.UUID;
 
+import org.apache.usergrid.StressTest;
 import org.junit.Before;
 import org.junit.Ignore;
 import org.junit.Rule;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -650,7 +652,7 @@ public abstract class EdgeSerializationTest {
      * Test paging by resuming the search from the edge
      */
     @Test
-    @Ignore("Kills embedded cassandra")
+    @Category(StressTest.class)
     public void pageIteration() throws ConnectionException {
 
         int size = graphFig.getScanPageSize() * 2;
@@ -690,7 +692,7 @@ public abstract class EdgeSerializationTest {
      * edge types
      */
     @Test
-    @Ignore("Kills embedded cassandra")
+    @Category(StressTest.class)
     public void testIteratorPaging() throws ConnectionException {
 
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/map/pom.xml
----------------------------------------------------------------------
diff --git a/stack/corepersistence/map/pom.xml b/stack/corepersistence/map/pom.xml
index e6f4d54..8589716 100644
--- a/stack/corepersistence/map/pom.xml
+++ b/stack/corepersistence/map/pom.xml
@@ -81,6 +81,7 @@ limitations under the License.
                         <version>${surefire.plugin.version}</version>
                         <configuration>
                             <argLine>-javaagent:${settings.localRepository}/org/jacoco/org.jacoco.agent/${jacoco.version}/org.jacoco.agent-${jacoco.version}-runtime.jar=destfile=${project.build.directory}/jacoco.exec</argLine>
+                            <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                         </configuration>
                     </plugin>
                 </plugins>

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/model/src/main/java/org/apache/usergrid/ExperimentalTest.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/model/src/main/java/org/apache/usergrid/ExperimentalTest.java b/stack/corepersistence/model/src/main/java/org/apache/usergrid/ExperimentalTest.java
new file mode 100644
index 0000000..5138fa4
--- /dev/null
+++ b/stack/corepersistence/model/src/main/java/org/apache/usergrid/ExperimentalTest.java
@@ -0,0 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.usergrid;
+
+public interface ExperimentalTest {}

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/model/src/main/java/org/apache/usergrid/StressTest.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/model/src/main/java/org/apache/usergrid/StressTest.java b/stack/corepersistence/model/src/main/java/org/apache/usergrid/StressTest.java
new file mode 100644
index 0000000..a51439e
--- /dev/null
+++ b/stack/corepersistence/model/src/main/java/org/apache/usergrid/StressTest.java
@@ -0,0 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.usergrid;
+
+public interface StressTest {}

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/pom.xml
----------------------------------------------------------------------
diff --git a/stack/corepersistence/pom.xml b/stack/corepersistence/pom.xml
index dab863b..66129ed 100644
--- a/stack/corepersistence/pom.xml
+++ b/stack/corepersistence/pom.xml
@@ -54,6 +54,7 @@ limitations under the License.
                       <version>${surefire.plugin.version}</version>
                       <configuration>
                           <argLine>-javaagent:${settings.localRepository}/org/jacoco/org.jacoco.agent/${jacoco.version}/org.jacoco.agent-${jacoco.version}-runtime.jar=destfile=${project.build.directory}/jacoco.exec</argLine>
+                          <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                       </configuration>
                   </plugin>
               </plugins>
@@ -126,6 +127,7 @@ limitations under the License.
                             <archaius.deployment.environment>UNIT</archaius.deployment.environment>
                         </systemPropertyVariables>
                         <argLine>-Xms2G -Xmx4G</argLine>
+                        <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                     </configuration>
                 </plugin>
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/queryindex/pom.xml
----------------------------------------------------------------------
diff --git a/stack/corepersistence/queryindex/pom.xml b/stack/corepersistence/queryindex/pom.xml
index 59f4f56..003281e 100644
--- a/stack/corepersistence/queryindex/pom.xml
+++ b/stack/corepersistence/queryindex/pom.xml
@@ -55,10 +55,7 @@
                         <include>**/*IT.java</include>
                         <include>**/*Test.java</include>
                     </includes>
-                    <!-- run this one manually to stress test -->
-                    <excludes>
-                        <exclude>**/IndexLoadTestsIT.java</exclude>
-                    </excludes>
+                    <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                 </configuration>
 
             </plugin>

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/corepersistence/queryindex/src/test/java/org/apache/usergrid/persistence/index/impl/IndexLoadTestsIT.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/queryindex/src/test/java/org/apache/usergrid/persistence/index/impl/IndexLoadTestsIT.java b/stack/corepersistence/queryindex/src/test/java/org/apache/usergrid/persistence/index/impl/IndexLoadTestsIT.java
index 1be1195..2343784 100644
--- a/stack/corepersistence/queryindex/src/test/java/org/apache/usergrid/persistence/index/impl/IndexLoadTestsIT.java
+++ b/stack/corepersistence/queryindex/src/test/java/org/apache/usergrid/persistence/index/impl/IndexLoadTestsIT.java
@@ -23,12 +23,14 @@ import java.util.UUID;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.atomic.AtomicLong;
 
+import org.apache.usergrid.StressTest;
 import org.apache.usergrid.persistence.core.astyanax.CassandraFig;
 import org.apache.usergrid.persistence.index.*;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Rule;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 import org.junit.runner.RunWith;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -77,6 +79,7 @@ import static org.junit.Assert.assertEquals;
  */
 @RunWith( EsRunner.class )
 @UseModules( { TestIndexModule.class } )
+@Category( StressTest.class )
 public class IndexLoadTestsIT extends BaseIT {
     private static final Logger log = LoggerFactory.getLogger( IndexLoadTestsIT.class );
     public static final String FIELD_WORKER_INDEX = "workerIndex";

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/pom.xml
----------------------------------------------------------------------
diff --git a/stack/pom.xml b/stack/pom.xml
index 3f7b68b..1df8463 100644
--- a/stack/pom.xml
+++ b/stack/pom.xml
@@ -127,7 +127,7 @@
       <usergrid.it.threads>8</usergrid.it.threads>
 
       <metrics.version>3.0.0</metrics.version>
-        <surefire.plugin.artifactName>surefire-junit47</surefire.plugin.artifactName>
+      <surefire.plugin.artifactName>surefire-junit47</surefire.plugin.artifactName>
       <surefire.plugin.version>2.18.1</surefire.plugin.version>
       <powermock.version>1.6.1</powermock.version>
 
@@ -1344,6 +1344,7 @@
                           <systemPropertyVariables>
                               <jacoco-agent.destfile>target/jacoco.exec</jacoco-agent.destfile>
                           </systemPropertyVariables>
+                          <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                       </configuration>
 
                       <!-- TODO, we may need an exclusion. Appears to be a classloader bug
@@ -1354,14 +1355,6 @@
                               <groupId>org.apache.maven.surefire</groupId>
                               <artifactId>${surefire.plugin.artifactName}</artifactId>
                               <version>${surefire.plugin.version}</version>
-<!--
-                              <exclusions>
-                                  <exclusion>
-                                      <groupId>org.apache.maven.surfire</groupId>
-                                      <artifactId>common-junit3</artifactId>
-                                  </exclusion>
-                              </exclusions>
--->
                           </dependency>
 
                           <!-- override plex utils, otherwise bug from above SO post happens-->
@@ -1585,6 +1578,7 @@
                         <version>${surefire.plugin.version}</version>
                         <configuration>
                             <argLine>-javaagent:${settings.localRepository}/com/github/stephenc/jamm/0.2.5/jamm-0.2.5.jar ${ug.argline} -javaagent:${settings.localRepository}/org/jacoco/org.jacoco.agent/${jacoco.version}/org.jacoco.agent-${jacoco.version}-runtime.jar=destfile=${project.build.directory}/jacoco.exec</argLine>
+                            <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                         </configuration>
                     </plugin>
                 </plugins>

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/rest/pom.xml
----------------------------------------------------------------------
diff --git a/stack/rest/pom.xml b/stack/rest/pom.xml
index 601ed61..f0ce7b3 100644
--- a/stack/rest/pom.xml
+++ b/stack/rest/pom.xml
@@ -85,6 +85,7 @@
                         <include>**/*IT.java</include>
                         <include>**/*Test.java</include>
                    </includes>
+                    <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
 
                 </configuration>
 
@@ -422,6 +423,7 @@
                         <version>${surefire.plugin.version}</version>
                         <configuration>
                             <argLine>-javaagent:${settings.localRepository}/org/jacoco/org.jacoco.agent/${jacoco.version}/org.jacoco.agent-${jacoco.version}-runtime.jar=destfile=${project.build.directory}/jacoco.exec  -Dwebapp.directory=${basedir}/src/main/webapp -Dtest.barrier.timestamp=${maven.build.timestamp} -Dtest.clean.storage=true -Xmx${ug.heapmax} -Xms${ug.heapmin} -Dfile.encoding=UTF-8 -Dsun.jnu.encoding=UTF-8  -javaagent:${settings.localRepository}/com/github/stephenc/jamm/0.2.5/jamm-0.2.5.jar -Djava.util.logging.config.file=${basedir}/src/test/resources/logging.properties ${ug.argline}</argLine>
+                            <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                         </configuration>
                     </plugin>
                 </plugins>

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/services/pom.xml
----------------------------------------------------------------------
diff --git a/stack/services/pom.xml b/stack/services/pom.xml
index 9837e76..bfd2f3b 100644
--- a/stack/services/pom.xml
+++ b/stack/services/pom.xml
@@ -103,12 +103,7 @@
                     <include>**/*IT.java</include>
                     <include>**/*Test.java</include>
                 </includes>
-                <excludes>
-                    <exclude>**/*Scheduler*IT.java</exclude>
-                    <exclude>**/*Notification*IT.java</exclude>
-                    <exclude>**/ExportServiceIT.java</exclude>
-                    <exclude>**/ImportServiceIT.java</exclude>
-                </excludes>
+                <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
             </configuration>
             <dependencies>
                 <dependency>
@@ -474,6 +469,7 @@
                         <version>${surefire.plugin.version}</version>
                         <configuration>
                             <argLine>-Dtest.barrier.timestamp=${maven.build.timestamp} -Dtest.clean.storage=true -Xmx${ug.heapmax} -Xms${ug.heapmin} -Dfile.encoding=UTF-8 -Dsun.jnu.encoding=UTF-8 -javaagent:${settings.localRepository}/com/github/stephenc/jamm/0.2.5/jamm-0.2.5.jar ${ug.argline} -javaagent:${settings.localRepository}/org/jacoco/org.jacoco.agent/${jacoco.version}/org.jacoco.agent-${jacoco.version}-runtime.jar=destfile=${project.build.directory}/jacoco.exec</argLine>
+                            <excludedGroups>org.apache.usergrid.StressTest,org.apache.usergrid.ExperimentalTest</excludedGroups>
                         </configuration>
                     </plugin>
                 </plugins>

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/services/src/test/java/org/apache/usergrid/security/providers/PingIdentityProviderIT.java
----------------------------------------------------------------------
diff --git a/stack/services/src/test/java/org/apache/usergrid/security/providers/PingIdentityProviderIT.java b/stack/services/src/test/java/org/apache/usergrid/security/providers/PingIdentityProviderIT.java
index c47b954..df63d1f 100644
--- a/stack/services/src/test/java/org/apache/usergrid/security/providers/PingIdentityProviderIT.java
+++ b/stack/services/src/test/java/org/apache/usergrid/security/providers/PingIdentityProviderIT.java
@@ -20,6 +20,7 @@ package org.apache.usergrid.security.providers;
 import java.util.Map;
 import java.util.UUID;
 
+import org.apache.usergrid.ExperimentalTest;
 import org.junit.BeforeClass;
 import org.junit.ClassRule;
 import org.junit.Ignore;
@@ -37,13 +38,14 @@ import org.apache.usergrid.persistence.entities.Application;
 import org.apache.usergrid.persistence.entities.User;
 import org.apache.usergrid.persistence.index.impl.ElasticSearchResource;
 import org.apache.usergrid.utils.MapUtils;
+import org.junit.experimental.categories.Category;
 
 import static junit.framework.Assert.assertNotNull;
 
 
 /** @author zznate */
-@Ignore("Experimental Ping Indentiyy test")
 
+@Category(ExperimentalTest.class )
 public class PingIdentityProviderIT {
     private static UserInfo adminUser;
     private static OrganizationInfo organization;

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/services/src/test/java/org/apache/usergrid/services/notifications/AbstractServiceNotificationIT.java
----------------------------------------------------------------------
diff --git a/stack/services/src/test/java/org/apache/usergrid/services/notifications/AbstractServiceNotificationIT.java b/stack/services/src/test/java/org/apache/usergrid/services/notifications/AbstractServiceNotificationIT.java
index 798f183..d0d2c29 100644
--- a/stack/services/src/test/java/org/apache/usergrid/services/notifications/AbstractServiceNotificationIT.java
+++ b/stack/services/src/test/java/org/apache/usergrid/services/notifications/AbstractServiceNotificationIT.java
@@ -23,6 +23,7 @@ import org.apache.usergrid.persistence.Query;
 import org.apache.usergrid.services.ServiceManagerFactory;
 import org.junit.Before;
 import org.junit.BeforeClass;
+import org.junit.Ignore;
 import org.junit.Rule;
 import org.junit.rules.TestName;
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/services/src/test/java/org/apache/usergrid/services/notifications/apns/NotificationsServiceIT.java
----------------------------------------------------------------------
diff --git a/stack/services/src/test/java/org/apache/usergrid/services/notifications/apns/NotificationsServiceIT.java b/stack/services/src/test/java/org/apache/usergrid/services/notifications/apns/NotificationsServiceIT.java
index 8b94661..a3ff449 100644
--- a/stack/services/src/test/java/org/apache/usergrid/services/notifications/apns/NotificationsServiceIT.java
+++ b/stack/services/src/test/java/org/apache/usergrid/services/notifications/apns/NotificationsServiceIT.java
@@ -41,6 +41,7 @@ import static org.apache.usergrid.services.notifications.impl.ApplicationQueueMa
 
 // todo: test reschedule on delivery time change
 // todo: test restart of queuing
+@Ignore
 public class NotificationsServiceIT extends AbstractServiceNotificationIT {
 
     private static final Logger LOG = LoggerFactory.getLogger(NotificationsServiceIT.class);

http://git-wip-us.apache.org/repos/asf/usergrid/blob/99b932ad/stack/services/src/test/java/org/apache/usergrid/services/notifications/gcm/NotificationsServiceIT.java
----------------------------------------------------------------------
diff --git a/stack/services/src/test/java/org/apache/usergrid/services/notifications/gcm/NotificationsServiceIT.java b/stack/services/src/test/java/org/apache/usergrid/services/notifications/gcm/NotificationsServiceIT.java
index 3218137..3369786 100644
--- a/stack/services/src/test/java/org/apache/usergrid/services/notifications/gcm/NotificationsServiceIT.java
+++ b/stack/services/src/test/java/org/apache/usergrid/services/notifications/gcm/NotificationsServiceIT.java
@@ -142,6 +142,7 @@ public class NotificationsServiceIT extends AbstractServiceNotificationIT {
     }
 
     @Test
+    @Ignore
     public void singlePushNotification() throws Exception {
 
         app.clear();
@@ -167,6 +168,7 @@ public class NotificationsServiceIT extends AbstractServiceNotificationIT {
     }
 
     @Test
+    @Ignore
     public void singlePushNotificationViaUser() throws Exception {
 
         app.clear();


[4/4] usergrid git commit: Remove unnecessary ignores in some places, add new ignores for broken tests that were once excluded via moms.

Posted by sn...@apache.org.
Remove unnecessary ignores in some places, add new ignores for broken tests that were once excluded via moms.


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

Branch: refs/heads/ignores
Commit: 41dde128cc04d211a29bf5af13520a7755246325
Parents: 99b932a
Author: Dave Johnson <sn...@apache.org>
Authored: Tue Nov 17 07:55:32 2015 -0500
Committer: Dave Johnson <sn...@apache.org>
Committed: Tue Nov 17 07:55:32 2015 -0500

----------------------------------------------------------------------
 .../usergrid/batch/job/CountdownLatchJob.java   |  1 -
 .../usergrid/batch/job/DelayExecution.java      |  1 -
 .../usergrid/batch/job/DelayHeartbeat.java      |  1 -
 .../usergrid/batch/job/FailureJobExecution.java |  1 -
 .../usergrid/persistence/CoreSchemaManager.java |  1 -
 .../mvcc/stage/delete/UniqueCleanupTest.java    |  1 -
 .../apache/usergrid/rest/NotificationsIT.java   |  2 +
 .../applications/ApplicationResourceIT.java     | 61 ----------------
 .../users/extensions/TestResource.java          |  1 -
 .../rest/applications/utils/TestUtils.java      |  1 -
 .../usergrid/rest/management/AdminUsersIT.java  |  1 -
 .../rest/management/ExportResourceIT.java       | 22 +-----
 .../rest/management/ImportResourceIT.java       | 11 +--
 .../management/export/ExportServiceIT.java      | 75 --------------------
 .../management/importer/ImportServiceIT.java    |  1 -
 15 files changed, 4 insertions(+), 177 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/core/src/test/java/org/apache/usergrid/batch/job/CountdownLatchJob.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/CountdownLatchJob.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/CountdownLatchJob.java
index 53996a2..4149150 100644
--- a/stack/core/src/test/java/org/apache/usergrid/batch/job/CountdownLatchJob.java
+++ b/stack/core/src/test/java/org/apache/usergrid/batch/job/CountdownLatchJob.java
@@ -33,7 +33,6 @@ import org.apache.usergrid.batch.JobExecution;
  * @author tnine
  */
 @Component("countdownLatch")
-@Ignore("Not a test")
 public class CountdownLatchJob implements Job {
 
     private CountDownLatch latch = null;

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayExecution.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayExecution.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayExecution.java
index aaa7071..4c8bda6 100644
--- a/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayExecution.java
+++ b/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayExecution.java
@@ -35,7 +35,6 @@ import org.apache.usergrid.batch.JobExecution;
  * @author tnine
  */
 @Component("delayExecution")
-@Ignore("Not a test")
 public class DelayExecution implements Job {
 
     private static final Logger logger = LoggerFactory.getLogger( DelayExecution.class );

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayHeartbeat.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayHeartbeat.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayHeartbeat.java
index 0fc104b..391b18b 100644
--- a/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayHeartbeat.java
+++ b/stack/core/src/test/java/org/apache/usergrid/batch/job/DelayHeartbeat.java
@@ -35,7 +35,6 @@ import org.apache.usergrid.batch.JobExecution;
  * @author tnine
  */
 @Component("delayHeartbeat")
-@Ignore("Not a test")
 public class DelayHeartbeat implements Job {
 
     private static final Logger logger = LoggerFactory.getLogger( DelayHeartbeat.class );

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/core/src/test/java/org/apache/usergrid/batch/job/FailureJobExecution.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/FailureJobExecution.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/FailureJobExecution.java
index b31b520..5072e4a 100644
--- a/stack/core/src/test/java/org/apache/usergrid/batch/job/FailureJobExecution.java
+++ b/stack/core/src/test/java/org/apache/usergrid/batch/job/FailureJobExecution.java
@@ -33,7 +33,6 @@ import org.apache.usergrid.batch.JobExecution;
  * @author tnine
  */
 @Component("failureJobExceuction")
-@Ignore("Not a test")
 public class FailureJobExecution implements Job {
 
     private CountDownLatch latch = null;

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/core/src/test/java/org/apache/usergrid/persistence/CoreSchemaManager.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/persistence/CoreSchemaManager.java b/stack/core/src/test/java/org/apache/usergrid/persistence/CoreSchemaManager.java
index adecc40..e9de76e 100644
--- a/stack/core/src/test/java/org/apache/usergrid/persistence/CoreSchemaManager.java
+++ b/stack/core/src/test/java/org/apache/usergrid/persistence/CoreSchemaManager.java
@@ -33,7 +33,6 @@ import me.prettyprint.hector.api.Cluster;
 
 
 /** @author zznate */
-@Ignore( "Not a test" )
 public class CoreSchemaManager implements SchemaManager {
     private static final Logger LOG = LoggerFactory.getLogger( CoreSchemaManager.class );
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/mvcc/stage/delete/UniqueCleanupTest.java
----------------------------------------------------------------------
diff --git a/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/mvcc/stage/delete/UniqueCleanupTest.java b/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/mvcc/stage/delete/UniqueCleanupTest.java
index c1f76f2..e361f42 100644
--- a/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/mvcc/stage/delete/UniqueCleanupTest.java
+++ b/stack/corepersistence/collection/src/test/java/org/apache/usergrid/persistence/collection/mvcc/stage/delete/UniqueCleanupTest.java
@@ -430,7 +430,6 @@ public class UniqueCleanupTest {
 //    /**
 //     * Tests what happens when our listeners are VERY slow
 //     */
-////    @Ignore( "Test is a work in progress" )
 //    @Test( timeout = 10000 )
 //    public void multipleListenerMultipleVersionsNoThreadsToRun()
 //            throws ExecutionException, InterruptedException, ConnectionException {

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/rest/src/test/java/org/apache/usergrid/rest/NotificationsIT.java
----------------------------------------------------------------------
diff --git a/stack/rest/src/test/java/org/apache/usergrid/rest/NotificationsIT.java b/stack/rest/src/test/java/org/apache/usergrid/rest/NotificationsIT.java
index 22785dc..63e7b49 100644
--- a/stack/rest/src/test/java/org/apache/usergrid/rest/NotificationsIT.java
+++ b/stack/rest/src/test/java/org/apache/usergrid/rest/NotificationsIT.java
@@ -35,6 +35,7 @@ import org.junit.After;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -43,6 +44,7 @@ import org.slf4j.LoggerFactory;
 /**
  * Test creating, sending and paging through Notifications via the REST API.
  */
+@Ignore
 public class NotificationsIT extends org.apache.usergrid.rest.test.resource.AbstractRestIT {
     private static final Logger logger = LoggerFactory.getLogger( NotificationsIT.class );
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/rest/src/test/java/org/apache/usergrid/rest/applications/ApplicationResourceIT.java
----------------------------------------------------------------------
diff --git a/stack/rest/src/test/java/org/apache/usergrid/rest/applications/ApplicationResourceIT.java b/stack/rest/src/test/java/org/apache/usergrid/rest/applications/ApplicationResourceIT.java
index cd42262..5915eca 100644
--- a/stack/rest/src/test/java/org/apache/usergrid/rest/applications/ApplicationResourceIT.java
+++ b/stack/rest/src/test/java/org/apache/usergrid/rest/applications/ApplicationResourceIT.java
@@ -225,40 +225,6 @@ public class ApplicationResourceIT extends AbstractRestIT {
 
     }
 
-    /**
-     * Verifies that we return JSON even when text/html is requested.
-     * (for backwards compatibility)
-     */
-    @Test
-    @Ignore("no longer relevant - this type of backwards compatibility no longer needed")
-    public void jsonForAcceptsTextHtml() throws Exception {
-
-        //Create the organization resource
-        OrganizationResource orgResource = clientSetup.getRestClient()
-            .management().orgs().org( clientSetup.getOrganizationName() );
-
-        //retrieve the credentials
-        Credentials orgCredentials = new Credentials( orgResource.credentials().get(ApiResponse.class));
-        String clientId = orgCredentials.getClientId();
-        String clientSecret = orgCredentials.getClientSecret();
-
-        //retrieve the users collection, setting the "Accept" header to text/html
-        Invocation.Builder builder = this.app().collection( "users" ).getTarget()
-            //Add the org credentials to the query
-            .queryParam( "grant_type", "client_credentials" )
-            .queryParam( "client_id", clientId )
-            .queryParam( "client_secret", clientSecret )
-            .request();
-
-        ApiResponse apiResponse = builder
-            .accept(MediaType.TEXT_HTML)
-            .get(ApiResponse.class);
-
-        Collection users = new Collection(apiResponse);
-        //make sure that a valid response is returned without error
-        assertNotNull(users);
-        assertNull(users.getResponse().getError());
-    }
 
     /**
      * Retrieve an application using password credentials
@@ -762,33 +728,6 @@ public class ApplicationResourceIT extends AbstractRestIT {
         assertNotNull("It has expires_in.", apiResponse.getExpirationDate());
     }
 
-    /**
-     * Ensure that the Apigee Mobile Analytics config returns valid JSON
-     */
-    @Test
-    @Ignore("No longer relevant - Apigee internal")
-    public void validateApigeeApmConfigAPP() throws IOException {
-        String orgName = clientSetup.getOrganizationName().toLowerCase();
-        String appName = clientSetup.getAppName().toLowerCase();
-
-        try {
-            //GET the APM endpoint
-            String response = target().path( String.format( "/%s/%s/apm/apigeeMobileConfig", orgName, appName ) )
-                .request()
-                .accept( MediaType.APPLICATION_JSON )
-                .get(String.class);
-            //Parse the response
-            JsonNode node = mapper.readTree(response);
-
-            //if things are kosher then JSON should have value for instaOpsApplicationId
-            assertTrue("it's valid json for APM", node.has("instaOpsApplicationId"));
-        } catch (ClientErrorException uie) {
-            //Validate that APM config exists
-            assertNotEquals("APM Config API exists", Response.Status.NOT_FOUND,
-                uie.getResponse().getStatus()); //i.e It should not be "Not Found"
-        }
-    }
-
 
     /**
      * Retrieve an application token using organization credentials

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/rest/src/test/java/org/apache/usergrid/rest/applications/collection/users/extensions/TestResource.java
----------------------------------------------------------------------
diff --git a/stack/rest/src/test/java/org/apache/usergrid/rest/applications/collection/users/extensions/TestResource.java b/stack/rest/src/test/java/org/apache/usergrid/rest/applications/collection/users/extensions/TestResource.java
index b74a162..969430e 100644
--- a/stack/rest/src/test/java/org/apache/usergrid/rest/applications/collection/users/extensions/TestResource.java
+++ b/stack/rest/src/test/java/org/apache/usergrid/rest/applications/collection/users/extensions/TestResource.java
@@ -29,7 +29,6 @@ import org.springframework.stereotype.Component;
 import org.apache.usergrid.rest.applications.users.AbstractUserExtensionResource;
 
 
-@Ignore("Not a test")
 @Component("TestResource")
 @Scope("prototype")
 @Produces(MediaType.APPLICATION_JSON)

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/rest/src/test/java/org/apache/usergrid/rest/applications/utils/TestUtils.java
----------------------------------------------------------------------
diff --git a/stack/rest/src/test/java/org/apache/usergrid/rest/applications/utils/TestUtils.java b/stack/rest/src/test/java/org/apache/usergrid/rest/applications/utils/TestUtils.java
index fa8356d..9a7d71c 100644
--- a/stack/rest/src/test/java/org/apache/usergrid/rest/applications/utils/TestUtils.java
+++ b/stack/rest/src/test/java/org/apache/usergrid/rest/applications/utils/TestUtils.java
@@ -27,7 +27,6 @@ import org.apache.usergrid.utils.UUIDUtils;
 
 
 /** @author tnine */
-@Ignore("Not a test")
 public class TestUtils {
 
     /** Get the uuid at the given index for the root node.  If it doesn't exist, null is returned */

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/rest/src/test/java/org/apache/usergrid/rest/management/AdminUsersIT.java
----------------------------------------------------------------------
diff --git a/stack/rest/src/test/java/org/apache/usergrid/rest/management/AdminUsersIT.java b/stack/rest/src/test/java/org/apache/usergrid/rest/management/AdminUsersIT.java
index 3aed997..fba0c43 100644
--- a/stack/rest/src/test/java/org/apache/usergrid/rest/management/AdminUsersIT.java
+++ b/stack/rest/src/test/java/org/apache/usergrid/rest/management/AdminUsersIT.java
@@ -437,7 +437,6 @@ public class AdminUsersIT extends AbstractRestIT {
 
 //    // TODO: will work once resetpw viewables work
 //    @Test
-//    @Ignore( "causes problems in build" )
 //    public void passwordResetIncorrectUserName() throws Exception {
 //
 //        String email = "test2@usergrid.com";

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/rest/src/test/java/org/apache/usergrid/rest/management/ExportResourceIT.java
----------------------------------------------------------------------
diff --git a/stack/rest/src/test/java/org/apache/usergrid/rest/management/ExportResourceIT.java b/stack/rest/src/test/java/org/apache/usergrid/rest/management/ExportResourceIT.java
index 939363f..79590b8 100644
--- a/stack/rest/src/test/java/org/apache/usergrid/rest/management/ExportResourceIT.java
+++ b/stack/rest/src/test/java/org/apache/usergrid/rest/management/ExportResourceIT.java
@@ -32,6 +32,7 @@ import java.util.UUID;
 import static org.junit.Assert.*;
 
 
+@Ignore
 public class ExportResourceIT extends AbstractRestIT {
 
 
@@ -40,7 +41,6 @@ public class ExportResourceIT extends AbstractRestIT {
 
     }
 
-    @Ignore
     @Test
     public void exportApplicationUUIDRetTest() throws Exception {
 
@@ -54,7 +54,6 @@ public class ExportResourceIT extends AbstractRestIT {
 
     }
 
-    @Ignore
     @Test
     public void exportCollectionUUIDRetTest() throws Exception {
 
@@ -81,7 +80,6 @@ public class ExportResourceIT extends AbstractRestIT {
      * Check that you can get the org export uuid returned and that you can check the status of the job using that uuid.
      * @throws Exception
      */
-    @Ignore
     @Test
     public void exportGetOrganizationJobStatTest() throws Exception {
 
@@ -123,7 +121,6 @@ public class ExportResourceIT extends AbstractRestIT {
      * @throws Exception
      */
 
-    @Ignore
     @Test
     public void exportGetApplicationJobStatTest() throws Exception {
 
@@ -160,7 +157,6 @@ public class ExportResourceIT extends AbstractRestIT {
     }
 
 
-    @Ignore
     @Test
     public void exportGetCollectionJobStatTest() throws Exception {
 
@@ -192,7 +188,6 @@ public class ExportResourceIT extends AbstractRestIT {
 //
 //
 //    //    //do an unauthorized test for both post and get
-@Ignore
 @Test
     public void exportGetWrongUUID() throws Exception {
         UUID fake = UUID.fromString( "AAAAAAAA-FFFF-FFFF-FFFF-AAAAAAAAAAAA" );
@@ -209,7 +204,6 @@ public class ExportResourceIT extends AbstractRestIT {
 
 
     //
-    @Ignore
     @Test
     public void exportPostApplicationNullPointerProperties() throws Exception {
         try {
@@ -225,7 +219,6 @@ public class ExportResourceIT extends AbstractRestIT {
     }
 
 
-    @Ignore
     @Test
     public void exportPostOrganizationNullPointerProperties() throws Exception {
         try {
@@ -239,7 +232,6 @@ public class ExportResourceIT extends AbstractRestIT {
     }
 
     //
-    @Ignore
     @Test
     public void exportPostCollectionNullPointer() throws Exception {
         try {
@@ -255,7 +247,6 @@ public class ExportResourceIT extends AbstractRestIT {
         }
     }
 
-    @Ignore
     @Test
     public void exportGetCollectionUnauthorized() throws Exception {
         UUID fake = UUID.fromString( "AAAAAAAA-FFFF-FFFF-FFFF-AAAAAAAAAAAA" );
@@ -272,7 +263,6 @@ public class ExportResourceIT extends AbstractRestIT {
         }
     }
 
-    @Ignore
     @Test
     public void exportGetApplicationUnauthorized() throws Exception {
         UUID fake = UUID.fromString( "AAAAAAAA-FFFF-FFFF-FFFF-AAAAAAAAAAAA" );
@@ -288,7 +278,6 @@ public class ExportResourceIT extends AbstractRestIT {
         }
     }
 
-    @Ignore
     @Test
     public void exportGetOrganizationUnauthorized() throws Exception {
         UUID fake = UUID.fromString( "AAAAAAAA-FFFF-FFFF-FFFF-AAAAAAAAAAAA" );
@@ -303,7 +292,6 @@ public class ExportResourceIT extends AbstractRestIT {
         }
     }
 
-    @Ignore
     @Test
     public void exportPostOrganizationNullPointerStorageInfo() throws Exception {
         HashMap<String, Object> payload = payloadBuilder();
@@ -323,7 +311,6 @@ public class ExportResourceIT extends AbstractRestIT {
     }
 
 
-    @Ignore
     @Test
     public void exportPostApplicationNullPointerStorageInfo() throws Exception {
         HashMap<String, Object> payload = payloadBuilder();
@@ -344,7 +331,6 @@ public class ExportResourceIT extends AbstractRestIT {
         }
     }
 
-    @Ignore
     @Test
     public void exportPostCollectionNullPointerStorageInfo() throws Exception {
         HashMap<String, Object> payload = payloadBuilder();
@@ -366,7 +352,6 @@ public class ExportResourceIT extends AbstractRestIT {
         }
     }
 
-    @Ignore
     @Test
     public void exportPostOrganizationNullPointerStorageProvider() throws Exception {
         HashMap<String, Object> payload = payloadBuilder();
@@ -386,7 +371,6 @@ public class ExportResourceIT extends AbstractRestIT {
     }
 
 
-    @Ignore
     @Test
     public void exportPostApplicationNullPointerStorageProvider() throws Exception {
         HashMap<String, Object> payload = payloadBuilder();
@@ -407,7 +391,6 @@ public class ExportResourceIT extends AbstractRestIT {
         }
     }
 
-    @Ignore
     @Test
     public void exportPostCollectionNullPointerStorageProvider() throws Exception {
         HashMap<String, Object> payload = payloadBuilder();
@@ -430,7 +413,6 @@ public class ExportResourceIT extends AbstractRestIT {
     }
 
 
-    @Ignore
     @Test
     public void exportPostOrganizationNullPointerStorageVerification() throws Exception {
         HashMap<String, Object> payload = payloadBuilder();
@@ -482,7 +464,6 @@ public class ExportResourceIT extends AbstractRestIT {
         }
     }
 
-    @Ignore
     @Test
     public void exportPostApplicationNullPointerStorageVerification() throws Exception {
         HashMap<String, Object> payload = payloadBuilder();
@@ -537,7 +518,6 @@ public class ExportResourceIT extends AbstractRestIT {
         }
     }
 
-    @Ignore
     @Test
     public void exportPostCollectionNullPointerStorageVerification() throws Exception {
         HashMap<String, Object> payload = payloadBuilder();

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/rest/src/test/java/org/apache/usergrid/rest/management/ImportResourceIT.java
----------------------------------------------------------------------
diff --git a/stack/rest/src/test/java/org/apache/usergrid/rest/management/ImportResourceIT.java b/stack/rest/src/test/java/org/apache/usergrid/rest/management/ImportResourceIT.java
index 784ff67..ee6ed8e 100644
--- a/stack/rest/src/test/java/org/apache/usergrid/rest/management/ImportResourceIT.java
+++ b/stack/rest/src/test/java/org/apache/usergrid/rest/management/ImportResourceIT.java
@@ -60,6 +60,7 @@ import java.util.Properties;
 import static org.junit.Assert.*;
 
 
+@Ignore
 public class ImportResourceIT extends AbstractRestIT {
 
     private static final Logger logger = LoggerFactory.getLogger(ImportResourceIT.class);
@@ -127,7 +128,6 @@ public class ImportResourceIT extends AbstractRestIT {
      *
      * @throws Exception
      */
-    @Ignore
     @Test
     public void importGetCollectionJobStatTest() throws Exception {
 
@@ -162,7 +162,6 @@ public class ImportResourceIT extends AbstractRestIT {
      * Verify that import job can only be read with an authorized token and cannot be read
      * with an invalid/notAllowed token.
      */
-    @Ignore
     @Test
     public void importTokenAuthorizationTest() throws Exception {
 
@@ -218,7 +217,6 @@ public class ImportResourceIT extends AbstractRestIT {
     }
 
 
-    @Ignore
     @Test
     public void importPostApplicationNullPointerProperties() throws Exception {
         String org = clientSetup.getOrganizationName();
@@ -235,7 +233,6 @@ public class ImportResourceIT extends AbstractRestIT {
         assertEquals(Response.Status.BAD_REQUEST, responseStatus);
     }
 
-    @Ignore
     @Test
     public void importPostApplicationNullPointerStorageInfo() throws Exception {
         String org = clientSetup.getOrganizationName();
@@ -256,7 +253,6 @@ public class ImportResourceIT extends AbstractRestIT {
     }
 
 
-    @Ignore
     @Test
     public void importPostApplicationNullPointerStorageProvider() throws Exception {
         String org = clientSetup.getOrganizationName();
@@ -278,7 +274,6 @@ public class ImportResourceIT extends AbstractRestIT {
     }
 
 
-    @Ignore
     @Test
     public void importPostApplicationNullPointerStorageVerification() throws Exception {
         String org = clientSetup.getOrganizationName();
@@ -412,7 +407,6 @@ public class ImportResourceIT extends AbstractRestIT {
     /**
      * TODO: Test that importing bad JSON will result in an informative error message.
      */
-    @Ignore
     @Test
     public void testImportGoodJson() throws Exception {
         // import from a bad JSON file
@@ -484,7 +478,6 @@ public class ImportResourceIT extends AbstractRestIT {
     /**
      * TODO: Test that importing bad JSON will result in an informative error message.
      */
-    @Ignore
     @Test
     public void testImportOneGoodOneBad() throws Exception {
 
@@ -532,7 +525,6 @@ public class ImportResourceIT extends AbstractRestIT {
     /**
      * TODO: Test that importing bad JSON will result in an informative error message.
      */
-    @Ignore
     @Test
     public void testImportOneBadFile() throws Exception {
         // import from a bad JSON file
@@ -581,7 +573,6 @@ public class ImportResourceIT extends AbstractRestIT {
     /**
      * TODO: Test that importing bad JSON will result in an informative error message.
      */
-    @Ignore
     @Test
     public void testImportBadJson() throws Exception {
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/services/src/test/java/org/apache/usergrid/management/export/ExportServiceIT.java
----------------------------------------------------------------------
diff --git a/stack/services/src/test/java/org/apache/usergrid/management/export/ExportServiceIT.java b/stack/services/src/test/java/org/apache/usergrid/management/export/ExportServiceIT.java
index 8f67e85..4f78b92 100644
--- a/stack/services/src/test/java/org/apache/usergrid/management/export/ExportServiceIT.java
+++ b/stack/services/src/test/java/org/apache/usergrid/management/export/ExportServiceIT.java
@@ -663,81 +663,6 @@ public class ExportServiceIT {
 
 
     @Test
-    @Ignore("this is a meaningless test because our export format does not support export of organizations")
-    public void testExportOneOrganization() throws Exception {
-
-        // create a bunch of organizations, each with applications and collections of entities
-
-        int maxOrgs = 3;
-        int maxApps = 3;
-        int maxEntities = 20;
-
-        List<ApplicationInfo> appsMade = new ArrayList<>();
-        List<OrganizationInfo> orgsMade = new ArrayList<>();
-
-        for ( int orgIndex = 0; orgIndex < maxOrgs; orgIndex++ ) {
-
-
-            String orgName = "org_" + RandomStringUtils.randomAlphanumeric(10);
-            OrganizationInfo orgMade = setup.getMgmtSvc().createOrganization( orgName, adminUser, true );
-            orgsMade.add( orgMade );
-            logger.debug("Created org {}", orgName);
-
-            for ( int appIndex = 0; appIndex < maxApps; appIndex++ ) {
-
-                String appName =  "app_" + RandomStringUtils.randomAlphanumeric(10);
-                ApplicationInfo appMade = setup.getMgmtSvc().createApplication( orgMade.getUuid(), appName );
-                appsMade.add( appMade );
-                logger.debug("Created app {}", appName);
-
-                for (int entityIndex = 0; entityIndex < maxEntities; entityIndex++) {
-
-                    EntityManager appEm = setup.getEmf().getEntityManager( appMade.getId() );
-                    appEm.create( appName + "_type", new HashMap<String, Object>() {{
-                        put("property1", "value1");
-                        put("property2", "value2");
-                    }});
-                }
-            }
-        }
-
-        // export one of the organizations only, using mock S3 export that writes to local disk
-
-        String exportFileName = "exportOneOrganization.json";
-        S3Export s3Export = new MockS3ExportImpl( exportFileName );
-
-        HashMap<String, Object> payload = payloadBuilder(appsMade.get(0).getName());
-        payload.put("organizationId", orgsMade.get(0).getUuid() );
-        payload.put( "applicationId", appsMade.get(0).getId() );
-
-        ExportService exportService = setup.getExportService();
-        UUID exportUUID = exportService.schedule( payload );
-
-        JobData jobData = jobDataCreator( payload, exportUUID, s3Export );
-        JobExecution jobExecution = mock( JobExecution.class );
-        when( jobExecution.getJobData() ).thenReturn(jobData);
-
-        exportService.doExport( jobExecution );
-
-        // finally, we check that file was created and contains the right number of entities in the array
-
-        File exportedFile = new File( exportFileName );
-        exportedFile.deleteOnExit();
-
-        TypeReference<HashMap<String,Object>> typeRef
-            = new TypeReference<HashMap<String,Object>>() {};
-
-        ObjectMapper mapper = new ObjectMapper();
-        Map<String,Object> jsonMap = mapper.readValue(new FileReader( exportedFile ), typeRef);
-        Map collectionsMap = (Map)jsonMap.get("collections");
-
-        List collectionList = (List)collectionsMap.get("users");
-
-        assertEquals( 3, collectionList.size() );
-    }
-
-
-    @Test
     public void testExportDoJob() throws Exception {
 
         String appName = newOrgAppAdminRule.getApplicationInfo().getName();

http://git-wip-us.apache.org/repos/asf/usergrid/blob/41dde128/stack/services/src/test/java/org/apache/usergrid/management/importer/ImportServiceIT.java
----------------------------------------------------------------------
diff --git a/stack/services/src/test/java/org/apache/usergrid/management/importer/ImportServiceIT.java b/stack/services/src/test/java/org/apache/usergrid/management/importer/ImportServiceIT.java
index e8d6081..d7d7028 100644
--- a/stack/services/src/test/java/org/apache/usergrid/management/importer/ImportServiceIT.java
+++ b/stack/services/src/test/java/org/apache/usergrid/management/importer/ImportServiceIT.java
@@ -64,7 +64,6 @@ import static org.mockito.Mockito.mock;
 import static org.mockito.Mockito.when;
 
 
-//@Concurrent
 public class ImportServiceIT {
 
     private static final Logger logger = LoggerFactory.getLogger(ImportServiceIT.class);


[2/4] usergrid git commit: Fix spelling error in class names.

Posted by sn...@apache.org.
Fix spelling error in class names.


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

Branch: refs/heads/ignores
Commit: d1f17107631c3e7c83ae0efccb371e3979c174ed
Parents: f62e0aa
Author: Dave Johnson <sn...@apache.org>
Authored: Tue Nov 17 07:52:21 2015 -0500
Committer: Dave Johnson <sn...@apache.org>
Committed: Tue Nov 17 07:52:21 2015 -0500

----------------------------------------------------------------------
 .../java/org/apache/usergrid/batch/job/SchedulerRuntime6IT.java  | 2 +-
 .../java/org/apache/usergrid/batch/job/SchedulerRuntime7IT.java  | 4 ++--
 2 files changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/usergrid/blob/d1f17107/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime6IT.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime6IT.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime6IT.java
index 239101c..5d2e00d 100644
--- a/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime6IT.java
+++ b/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime6IT.java
@@ -50,7 +50,7 @@ public class SchedulerRuntime6IT extends AbstractSchedulerRuntimeIT {
         long customRetry = sleepTime + 1000;
         int numberOfRuns = 1;
 
-        OnlyOnceExceution job = springResource.getBean( "onlyOnceExceution", OnlyOnceExceution.class );
+        OnlyOnceExecution job = springResource.getBean( "onlyOnceExceution", OnlyOnceExecution.class );
 
         job.setTimeout( customRetry );
         job.setLatch( numberOfRuns );

http://git-wip-us.apache.org/repos/asf/usergrid/blob/d1f17107/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime7IT.java
----------------------------------------------------------------------
diff --git a/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime7IT.java b/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime7IT.java
index 091c875..000996d 100644
--- a/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime7IT.java
+++ b/stack/core/src/test/java/org/apache/usergrid/batch/job/SchedulerRuntime7IT.java
@@ -46,8 +46,8 @@ public class SchedulerRuntime7IT extends AbstractSchedulerRuntimeIT {
         long customRetry = sleepTime * 2;
         int numberOfRuns = 2;
 
-        OnlyOnceUnlockOnFailExceution job =
-                springResource.getBean( "onlyOnceUnlockOnFailExceution", OnlyOnceUnlockOnFailExceution.class );
+        OnlyOnceUnlockOnFailExecution job =
+                springResource.getBean( "onlyOnceUnlockOnFailExceution", OnlyOnceUnlockOnFailExecution.class );
 
         job.setTimeout( customRetry );
         job.setLatch( numberOfRuns );