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 2014/10/10 15:00:45 UTC

git commit: Formatting and license header changes only.

Repository: incubator-usergrid
Updated Branches:
  refs/heads/two-dot-o 38d5885a9 -> 9d96f4cc3


Formatting and license header changes only.


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

Branch: refs/heads/two-dot-o
Commit: 9d96f4cc37337840b3a2bf0e81b4efab92c67bdc
Parents: 38d5885
Author: Dave Johnson <dm...@apigee.com>
Authored: Fri Oct 10 09:00:33 2014 -0400
Committer: Dave Johnson <dm...@apigee.com>
Committed: Fri Oct 10 09:00:33 2014 -0400

----------------------------------------------------------------------
 .../corepersistence/results/EntityVerifier.java | 23 ++------
 .../results/FilteringLoader.java                | 55 ++++++++------------
 .../corepersistence/results/IdsVerifier.java    | 23 +-------
 .../corepersistence/results/RefsVerifier.java   | 22 +-------
 .../corepersistence/results/ResultsLoader.java  | 24 +--------
 .../results/ResultsLoaderFactory.java           | 25 +--------
 .../results/ResultsLoaderFactoryImpl.java       | 27 ++--------
 .../results/ResultsVerifier.java                | 26 ++-------
 .../results/VersionVerifier.java                | 35 +++----------
 9 files changed, 45 insertions(+), 215 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/9d96f4cc/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/EntityVerifier.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/EntityVerifier.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/EntityVerifier.java
index 13bd91b..31018b6 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/EntityVerifier.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/EntityVerifier.java
@@ -18,24 +18,7 @@
  *
  */
 
-package org.apache.usergrid.corepersistence.results;/*
- * 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.corepersistence.results;
 
 
 import java.util.ArrayList;
@@ -112,8 +95,8 @@ public class EntityVerifier implements ResultsVerifier {
         final Optional<org.apache.usergrid.persistence.model.entity.Entity> entity = savedEntity.getEntity();
 
         if ( !entity.isPresent() ) {
-            logger.warn( "Entity uuid:{} version v:{} is deleted but indexed, this is a bug ", entityId.getUuid(),
-                    savedEntity.getEntity() );
+            logger.warn( "Entity uuid:{} version v:{} is deleted but indexed, this is a bug ", 
+                    entityId.getUuid(), savedEntity.getEntity() );
             return false;
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/9d96f4cc/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/FilteringLoader.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/FilteringLoader.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/FilteringLoader.java
index a7eb6ea..bb41070 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/FilteringLoader.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/FilteringLoader.java
@@ -1,24 +1,4 @@
 /*
- *
- *  * Licensed to the Apache Software Foundation (ASF) under one or more
- *  *  contributor license agreements.  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.  For additional information regarding
- *  * copyright in this work, please see the NOTICE file in the top level
- *  * directory of this distribution.
- *
- */
-
-package org.apache.usergrid.corepersistence.results;/*
  * 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
@@ -37,6 +17,8 @@ package org.apache.usergrid.corepersistence.results;/*
  * under the License.
  */
 
+package org.apache.usergrid.corepersistence.results;
+
 
 import java.util.Collection;
 import java.util.HashMap;
@@ -116,7 +98,8 @@ public class FilteringLoader implements ResultsLoader {
          * so we want to batch
          * fetch them more efficiently
          */
-        final HashMultimap<String, CandidateResult> groupedByScopes = HashMultimap.create( crs.size(), crs.size() );
+        final HashMultimap<String, CandidateResult> groupedByScopes = 
+                HashMultimap.create( crs.size(), crs.size() );
 
         final Iterator<CandidateResult> iter = crs.iterator();
 
@@ -128,7 +111,8 @@ public class FilteringLoader implements ResultsLoader {
 
             final CandidateResult currentCandidate = iter.next();
 
-            final String collectionType = CpNamingUtils.getCollectionScopeNameFromEntityType( currentCandidate.getId().getType() );
+            final String collectionType = CpNamingUtils.getCollectionScopeNameFromEntityType( 
+                    currentCandidate.getId().getType() );
 
             final Id entityId = currentCandidate.getId();
 
@@ -153,7 +137,8 @@ public class FilteringLoader implements ResultsLoader {
             if ( UUIDComparator.staticCompare( currentVersion, previousMaxVersion ) > 0 ) {
 
                 //de-index it
-                logger.debug( "Stale version of Entity uuid:{} type:{}, stale v:{}, latest v:{}", new Object[] {
+                logger.debug( "Stale version of Entity uuid:{} type:{}, stale v:{}, latest v:{}", 
+                        new Object[] {
                         entityId.getUuid(), entityId.getType(), previousMaxVersion, currentVersion
                 } );
 
@@ -172,8 +157,8 @@ public class FilteringLoader implements ResultsLoader {
         }
 
 
-        //now everything is ordered, and older versions are removed.  Batch fetch versions to verify existence and
-        // correct versions
+        //now everything is ordered, and older versions are removed.  Batch fetch versions to verify 
+        // existence and correct versions
 
         final TreeMap<Integer, Id> sortedResults = new TreeMap<>();
 
@@ -198,15 +183,15 @@ public class FilteringLoader implements ResultsLoader {
 
             //now using the scope, load the collection
 
-            /**
-             * Get the collection scope and batch load all the versions
-             */
-            final CollectionScope collScope =
-                    new CollectionScopeImpl( applicationScope.getApplication(), applicationScope.getApplication(),
-                            scopeName );
+            
+            // Get the collection scope and batch load all the versions
+            final CollectionScope collScope = new CollectionScopeImpl( 
+                    applicationScope.getApplication(), 
+                    applicationScope.getApplication(),
+                    scopeName );
 
 
-            final EntityCollectionManager ecm = managerCache.getEntityCollectionManager( collScope );
+            final EntityCollectionManager ecm = managerCache.getEntityCollectionManager( collScope);
 
 
             //load the results into the loader for this scope for validation
@@ -239,9 +224,11 @@ public class FilteringLoader implements ResultsLoader {
     }
 
 
-    protected void deIndex( final EntityIndexBatch batch, final Id ownerId, final CandidateResult candidateResult ) {
+    protected void deIndex( final EntityIndexBatch batch, final Id ownerId, 
+            final CandidateResult candidateResult ) {
+
         IndexScope indexScope = new IndexScopeImpl( ownerId,
-                CpNamingUtils.getCollectionScopeNameFromEntityType( candidateResult.getId().getType() ) );
+            CpNamingUtils.getCollectionScopeNameFromEntityType( candidateResult.getId().getType()));
 
         batch.deindex( indexScope, candidateResult );
     }

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/9d96f4cc/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/IdsVerifier.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/IdsVerifier.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/IdsVerifier.java
index cf13c74..fae6eb1 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/IdsVerifier.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/IdsVerifier.java
@@ -1,24 +1,4 @@
 /*
- *
- *  * Licensed to the Apache Software Foundation (ASF) under one or more
- *  *  contributor license agreements.  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.  For additional information regarding
- *  * copyright in this work, please see the NOTICE file in the top level
- *  * directory of this distribution.
- *
- */
-
-package org.apache.usergrid.corepersistence.results;/*
  * 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
@@ -37,6 +17,8 @@ package org.apache.usergrid.corepersistence.results;/*
  * under the License.
  */
 
+package org.apache.usergrid.corepersistence.results;
+
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -49,7 +31,6 @@ import org.apache.usergrid.persistence.model.entity.Id;
 
 public class IdsVerifier extends VersionVerifier {
 
-
     @Override
     public Results getResults( final Collection<Id> ids ) {
 

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/9d96f4cc/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/RefsVerifier.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/RefsVerifier.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/RefsVerifier.java
index 77443ee..096c271 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/RefsVerifier.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/RefsVerifier.java
@@ -1,24 +1,4 @@
 /*
- *
- *  * Licensed to the Apache Software Foundation (ASF) under one or more
- *  *  contributor license agreements.  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.  For additional information regarding
- *  * copyright in this work, please see the NOTICE file in the top level
- *  * directory of this distribution.
- *
- */
-
-package org.apache.usergrid.corepersistence.results;/*
  * 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
@@ -36,6 +16,7 @@ package org.apache.usergrid.corepersistence.results;/*
  * specific language governing permissions and limitations
  * under the License.
  */
+package org.apache.usergrid.corepersistence.results;
 
 
 import java.util.ArrayList;
@@ -50,7 +31,6 @@ import org.apache.usergrid.persistence.model.entity.Id;
 
 public class RefsVerifier extends VersionVerifier {
 
-
     @Override
     public Results getResults( final Collection<Id> ids ) {
         List<EntityRef> refs = new ArrayList<EntityRef>();

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/9d96f4cc/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoader.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoader.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoader.java
index 299327d..648ee0c 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoader.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoader.java
@@ -1,24 +1,4 @@
 /*
- *
- *  * Licensed to the Apache Software Foundation (ASF) under one or more
- *  *  contributor license agreements.  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.  For additional information regarding
- *  * copyright in this work, please see the NOTICE file in the top level
- *  * directory of this distribution.
- *
- */
-
-package org.apache.usergrid.corepersistence.results;/*
  * 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
@@ -37,11 +17,11 @@ package org.apache.usergrid.corepersistence.results;/*
  * under the License.
  */
 
+package org.apache.usergrid.corepersistence.results;
+
 
 import org.apache.usergrid.persistence.Results;
-import org.apache.usergrid.persistence.core.scope.ApplicationScope;
 import org.apache.usergrid.persistence.index.query.CandidateResults;
-import org.apache.usergrid.persistence.model.entity.Id;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/9d96f4cc/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactory.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactory.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactory.java
index 9954597..ebd9380 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactory.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactory.java
@@ -1,24 +1,4 @@
 /*
- *
- *  * Licensed to the Apache Software Foundation (ASF) under one or more
- *  *  contributor license agreements.  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.  For additional information regarding
- *  * copyright in this work, please see the NOTICE file in the top level
- *  * directory of this distribution.
- *
- */
-
-package org.apache.usergrid.corepersistence.results;/*
  * 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
@@ -37,20 +17,19 @@ package org.apache.usergrid.corepersistence.results;/*
  * under the License.
  */
 
+package org.apache.usergrid.corepersistence.results;
+
 
 import org.apache.usergrid.persistence.EntityRef;
 import org.apache.usergrid.persistence.core.scope.ApplicationScope;
 import org.apache.usergrid.persistence.index.query.Query;
-import org.apache.usergrid.persistence.model.entity.Id;
 
 
 /**
  * Factory for creating results
  */
-
 public interface ResultsLoaderFactory {
 
-
     /**
      * Get the load for results
      * @return

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/9d96f4cc/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactoryImpl.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactoryImpl.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactoryImpl.java
index 7839a13..e987882 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactoryImpl.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsLoaderFactoryImpl.java
@@ -1,24 +1,4 @@
 /*
- *
- *  * Licensed to the Apache Software Foundation (ASF) under one or more
- *  *  contributor license agreements.  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.  For additional information regarding
- *  * copyright in this work, please see the NOTICE file in the top level
- *  * directory of this distribution.
- *
- */
-
-package org.apache.usergrid.corepersistence.results;/*
  * 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
@@ -37,14 +17,13 @@ package org.apache.usergrid.corepersistence.results;/*
  * under the License.
  */
 
+package org.apache.usergrid.corepersistence.results;
 
-import org.junit.rules.Verifier;
 
 import org.apache.usergrid.corepersistence.CpManagerCache;
 import org.apache.usergrid.persistence.EntityRef;
 import org.apache.usergrid.persistence.core.scope.ApplicationScope;
 import org.apache.usergrid.persistence.index.query.Query;
-import org.apache.usergrid.persistence.model.entity.Id;
 
 import com.google.inject.Inject;
 
@@ -66,8 +45,8 @@ public class ResultsLoaderFactoryImpl implements ResultsLoaderFactory {
 
 
     @Override
-    public ResultsLoader getLoader( final ApplicationScope applicationScope, final EntityRef ownerId,
-                                    final Query.Level resultsLevel ) {
+    public ResultsLoader getLoader( final ApplicationScope applicationScope, 
+            final EntityRef ownerId, final Query.Level resultsLevel ) {
 
 
         ResultsVerifier verifier;

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/9d96f4cc/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsVerifier.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsVerifier.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsVerifier.java
index 1180ece..995c50a 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsVerifier.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/ResultsVerifier.java
@@ -1,24 +1,4 @@
 /*
- *
- *  * Licensed to the Apache Software Foundation (ASF) under one or more
- *  *  contributor license agreements.  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.  For additional information regarding
- *  * copyright in this work, please see the NOTICE file in the top level
- *  * directory of this distribution.
- *
- */
-
-package org.apache.usergrid.corepersistence.results;/*
  * 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
@@ -37,6 +17,8 @@ package org.apache.usergrid.corepersistence.results;/*
  * under the License.
  */
 
+package org.apache.usergrid.corepersistence.results;
+
 
 import java.util.Collection;
 
@@ -56,8 +38,8 @@ public interface ResultsVerifier {
     public void loadResults(Collection<Id> ids, EntityCollectionManager ecm);
 
     /**
-     * Return true if the candidate result is a valid result that should be retained.  If it should not
-     * it should also be removed from the list of possible return values in this loader
+     * Return true if the candidate result is a valid result that should be retained. * If it 
+     * should not it should also be removed from the list of possible return values in this loader
      * @param candidateResult
      * @return
      */

http://git-wip-us.apache.org/repos/asf/incubator-usergrid/blob/9d96f4cc/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/VersionVerifier.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/VersionVerifier.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/VersionVerifier.java
index 778b0c3..94a36af 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/VersionVerifier.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/results/VersionVerifier.java
@@ -1,24 +1,4 @@
 /*
- *
- *  * Licensed to the Apache Software Foundation (ASF) under one or more
- *  *  contributor license agreements.  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.  For additional information regarding
- *  * copyright in this work, please see the NOTICE file in the top level
- *  * directory of this distribution.
- *
- */
-
-package org.apache.usergrid.corepersistence.results;/*
  * 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
@@ -37,6 +17,8 @@ package org.apache.usergrid.corepersistence.results;/*
  * under the License.
  */
 
+package org.apache.usergrid.corepersistence.results;
+
 
 import java.util.Collection;
 import java.util.UUID;
@@ -45,8 +27,6 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 import org.apache.usergrid.persistence.collection.EntityCollectionManager;
-import org.apache.usergrid.persistence.collection.EntitySet;
-import org.apache.usergrid.persistence.collection.MvccEntity;
 import org.apache.usergrid.persistence.collection.MvccLogEntry;
 import org.apache.usergrid.persistence.collection.VersionSet;
 import org.apache.usergrid.persistence.index.query.CandidateResult;
@@ -79,8 +59,8 @@ public abstract class VersionVerifier implements ResultsVerifier {
 
         //version wasn't found ,deindex
         if ( version == null ) {
-            logger.warn( "Version for Entity {}:{} not found", entityId.getUuid(), entityId.getUuid() );
-
+            logger.warn( "Version for Entity {}:{} not found", 
+                    entityId.getUuid(), entityId.getUuid() );
 
             return false;
         }
@@ -88,16 +68,15 @@ public abstract class VersionVerifier implements ResultsVerifier {
         final UUID savedVersion = version.getVersion();
 
         if ( UUIDComparator.staticCompare( savedVersion, candidateResult.getVersion() ) > 0 ) {
-            logger.debug( "Stale version of Entity uuid:{} type:{}, stale v:{}, latest v:{}", new Object[] {
-                    entityId.getUuid(), entityId.getType(), savedVersion, candidateResult.getVersion()
+            logger.debug( "Stale version of Entity uuid:{} type:{}, stale v:{}, latest v:{}", 
+                new Object[] {
+                 entityId.getUuid(), entityId.getType(), savedVersion, candidateResult.getVersion()
             } );
 
             return false;
         }
 
-
         return true;
     }
 
-
 }