You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@usergrid.apache.org by mr...@apache.org on 2016/02/02 17:42:41 UTC

[4/7] usergrid git commit: USERGRID-1243: logging overhaul, pt. 1

USERGRID-1243: logging overhaul, pt. 1


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

Branch: refs/heads/master
Commit: 71fb6100c614e320441e3df07f5c7de680f90403
Parents: 0d4c35f
Author: Mike Dunker <md...@apigee.com>
Authored: Fri Jan 29 18:36:39 2016 -0800
Committer: Mike Dunker <md...@apigee.com>
Committed: Fri Jan 29 18:36:39 2016 -0800

----------------------------------------------------------------------
 .../batch/service/SchedulerServiceImpl.java     |  4 +-
 .../hazelcast/HazelcastLifecycleMonitor.java    |  8 +-
 .../corepersistence/CpEntityManager.java        | 89 +++++++++-----------
 .../corepersistence/CpEntityManagerFactory.java |  8 +-
 .../corepersistence/CpRelationManager.java      | 71 +++++++---------
 .../usergrid/corepersistence/CpSetup.java       |  2 +-
 .../usergrid/corepersistence/CpWalker.java      |  3 +-
 .../usergrid/corepersistence/GuiceFactory.java  |  4 +-
 .../asyncevents/AmazonAsyncEventService.java    |  7 +-
 .../asyncevents/EventBuilderImpl.java           | 31 +++----
 .../index/ReIndexServiceImpl.java               |  6 +-
 .../search/AbstractElasticSearchFilter.java     |  4 +-
 .../read/search/CandidateEntityFilter.java      |  9 +-
 .../pipeline/read/search/CandidateIdFilter.java |  6 +-
 .../read/search/SearchConnectionFilter.java     |  8 +-
 .../usergrid/count/CassandraCounterStore.java   |  6 +-
 .../usergrid/count/CassandraSubmitter.java      |  4 +-
 .../org/apache/usergrid/mq/CounterQuery.java    |  4 -
 .../main/java/org/apache/usergrid/mq/Query.java | 16 ++--
 .../usergrid/mq/cassandra/CassandraMQUtils.java |  8 +-
 .../usergrid/mq/cassandra/QueueManagerImpl.java | 18 ++--
 .../mq/cassandra/io/AbstractSearch.java         |  5 +-
 .../mq/cassandra/io/ConsumerTransaction.java    | 24 +++---
 .../mq/cassandra/io/NoTransactionSearch.java    |  2 +-
 .../org/apache/usergrid/persistence/Schema.java | 12 +--
 .../cassandra/CassandraPersistenceUtils.java    |  6 +-
 .../persistence/cassandra/CassandraService.java | 64 +++++++-------
 .../cassandra/ConnectionRefImpl.java            |  4 +-
 .../persistence/cassandra/CounterUtils.java     | 26 +++---
 .../usergrid/persistence/cassandra/Setup.java   |  4 -
 .../cassandra/util/Slf4jTraceTagReporter.java   |  4 +-
 .../cassandra/util/TraceTagAspect.java          |  8 +-
 .../cassandra/util/TraceTagManager.java         |  8 +-
 .../usergrid/system/UsergridSystemMonitor.java  |  2 +-
 .../org/apache/usergrid/utils/AESUtils.java     |  8 +-
 .../apache/usergrid/utils/ConversionUtils.java  |  6 +-
 .../org/apache/usergrid/utils/IndexUtils.java   |  4 +-
 .../org/apache/usergrid/utils/JsonUtils.java    | 22 ++---
 .../org/apache/usergrid/utils/ListUtils.java    | 10 +--
 .../org/apache/usergrid/utils/StringUtils.java  |  4 +-
 .../impl/ScopedCacheSerializationImpl.java      |  6 +-
 .../mvcc/stage/delete/MarkCommit.java           |  6 +-
 .../collection/mvcc/stage/delete/MarkStart.java |  4 +-
 .../mvcc/stage/delete/VersionCompact.java       |  2 +-
 .../mvcc/stage/write/RollbackAction.java        |  2 +-
 .../mvcc/stage/write/WriteCommit.java           |  6 +-
 .../mvcc/stage/write/WriteOptimisticVerify.java |  4 +-
 .../collection/mvcc/stage/write/WriteStart.java |  6 +-
 .../mvcc/stage/write/WriteUniqueVerify.java     |  2 +-
 .../MvccEntitySerializationStrategyImpl.java    |  8 +-
 .../MvccLogEntrySerializationStrategyImpl.java  |  6 +-
 .../UniqueValueSerializationStrategyImpl.java   |  7 +-
 .../migration/MvccEntityDataMigrationImpl.java  |  6 +-
 .../astyanax/MultiKeyColumnNameIterator.java    |  4 +-
 .../core/executor/TaskExecutorFactory.java      |  6 +-
 .../core/metrics/MetricsFactoryImpl.java        |  6 +-
 .../migration/schema/MigrationManagerImpl.java  |  5 +-
 .../persistence/core/rx/ObservableIterator.java |  4 +-
 .../persistence/core/rx/OrderedMerge.java       |  6 +-
 .../graph/impl/GraphManagerImpl.java            | 14 +--
 .../graph/impl/stage/EdgeMetaRepairImpl.java    | 46 ++++++----
 .../impl/stage/NodeDeleteListenerImpl.java      | 20 +++--
 .../serialization/impl/EdgesObservableImpl.java | 16 +++-
 .../impl/TargetIdObservableImpl.java            |  4 +-
 .../impl/migration/EdgeDataMigrationImpl.java   |  2 +-
 .../impl/shard/ShardEntryGroup.java             | 18 ++--
 .../shard/impl/NodeShardAllocationImpl.java     |  2 +-
 .../impl/shard/impl/NodeShardCacheImpl.java     |  2 +-
 .../shard/impl/ShardGroupCompactionImpl.java    | 22 +++--
 .../impl/shard/impl/ShardGroupDeletionImpl.java |  2 +-
 .../index/impl/EntityMappingParser.java         |  5 +-
 .../index/impl/EsEntityIndexBatchImpl.java      | 22 +++--
 .../index/impl/EsEntityIndexImpl.java           | 49 +++++++----
 .../index/impl/EsIndexProducerImpl.java         | 18 ++--
 .../persistence/index/impl/EsProvider.java      |  8 +-
 .../index/impl/FailureMonitorImpl.java          |  7 +-
 .../EsIndexMappingMigrationPlugin.java          |  2 +-
 .../index/query/ParsedQueryBuilder.java         |  4 +-
 .../index/utils/ConversionUtils.java            |  6 +-
 .../persistence/index/utils/ListUtils.java      | 10 +--
 .../persistence/index/impl/GeoPagingTest.java   |  1 -
 .../persistence/queue/impl/QueueScopeImpl.java  |  3 -
 .../queue/impl/SNSQueueManagerImpl.java         | 77 +++++++++--------
 .../queue/util/AmazonNotificationUtils.java     | 22 +++--
 stack/pom.xml                                   |  2 +-
 .../usergrid/rest/AbstractContextResource.java  | 10 +--
 .../org/apache/usergrid/rest/RootResource.java  |  8 +-
 .../apache/usergrid/rest/SwaggerServlet.java    | 16 +++-
 .../rest/applications/ApplicationResource.java  | 38 ++++-----
 .../rest/applications/AuthResource.java         | 20 +++--
 .../rest/applications/ServiceResource.java      | 60 ++++++-------
 .../applications/assets/AssetsResource.java     | 34 ++++++--
 .../notifiers/NotifierResource.java             |  4 +-
 .../notifiers/NotifiersResource.java            | 14 +--
 .../rest/applications/queues/QueueResource.java | 40 ++++++---
 .../queues/QueueSubscriberResource.java         | 20 +++--
 .../queues/QueueSubscriptionResource.java       | 20 +++--
 .../rest/applications/users/UserResource.java   | 52 +++++++++---
 .../rest/applications/users/UsersResource.java  | 18 ++--
 .../exceptions/AbstractExceptionMapper.java     |  8 +-
 .../exceptions/NotAllowedExceptionMapper.java   |  3 -
 .../rest/filters/ContentTypeFilter.java         | 18 ++--
 .../rest/filters/JSONPCallbackFilter.java       |  4 +-
 .../rest/management/ManagementResource.java     | 22 +++--
 .../organizations/OrganizationResource.java     | 30 ++++---
 .../organizations/OrganizationsResource.java    |  8 +-
 .../applications/ApplicationResource.java       |  8 +-
 .../applications/ApplicationsResource.java      |  4 +-
 .../applications/imports/ImportsResource.java   |  6 +-
 .../organizations/users/UsersResource.java      |  2 +-
 .../rest/management/users/UserResource.java     |  4 +-
 .../rest/management/users/UsersResource.java    |  4 +-
 .../organizations/OrganizationResource.java     |  4 +-
 .../security/SecuredResourceFilterFactory.java  | 56 ++++++------
 .../security/shiro/RestSecurityManager.java     |  2 +-
 .../shiro/filters/BasicAuthSecurityFilter.java  |  8 +-
 .../ClientCredentialsSecurityFilter.java        |  4 +-
 .../OAuth2AccessTokenSecurityFilter.java        |  4 +-
 .../rest/system/ApplicationsResource.java       |  6 +-
 .../usergrid/rest/system/DatabaseResource.java  |  4 +-
 .../usergrid/rest/system/IndexResource.java     |  4 +-
 .../usergrid/rest/system/MigrateResource.java   |  4 +-
 .../applications/queries/GeoPagingTest.java     |  1 -
 .../rest/applications/queries/OrderByTest.java  |  1 -
 .../rest/test/resource/model/ApiResponse.java   |  3 -
 .../rest/test/resource/model/Collection.java    |  3 -
 .../cassandra/AccountCreationPropsImpl.java     |  2 +-
 .../cassandra/ManagementServiceImpl.java        |  4 +-
 .../AwsPropertiesNotFoundException.java         |  3 -
 .../notifications/ApplicationQueueMessage.java  |  3 -
 .../notifications/NotificationServiceProxy.java |  3 -
 131 files changed, 857 insertions(+), 756 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/batch/service/SchedulerServiceImpl.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/batch/service/SchedulerServiceImpl.java b/stack/core/src/main/java/org/apache/usergrid/batch/service/SchedulerServiceImpl.java
index b0a5f08..af933f6 100644
--- a/stack/core/src/main/java/org/apache/usergrid/batch/service/SchedulerServiceImpl.java
+++ b/stack/core/src/main/java/org/apache/usergrid/batch/service/SchedulerServiceImpl.java
@@ -211,8 +211,8 @@ public class SchedulerServiceImpl implements SchedulerService, JobAccessor, JobR
                 // exception here. We don't want to cause job loss, so leave the job in
                 // the Q.
                 logger.error(
-                        "Unable to retrieve job data for jobname {}, job id {}, stats id {}.  Skipping to avoid job "
-                                + "loss", new Object[] { jobName, jobUuid, statsUuid, e } );
+                        "Unable to retrieve job data for jobname {}, job id {}, stats id {}.  Skipping to avoid job loss",
+                                jobName, jobUuid, statsUuid, e );
             }
         }
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/clustering/hazelcast/HazelcastLifecycleMonitor.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/clustering/hazelcast/HazelcastLifecycleMonitor.java b/stack/core/src/main/java/org/apache/usergrid/clustering/hazelcast/HazelcastLifecycleMonitor.java
index 7af19b3..0c436f6 100644
--- a/stack/core/src/main/java/org/apache/usergrid/clustering/hazelcast/HazelcastLifecycleMonitor.java
+++ b/stack/core/src/main/java/org/apache/usergrid/clustering/hazelcast/HazelcastLifecycleMonitor.java
@@ -55,25 +55,25 @@ public class HazelcastLifecycleMonitor implements InstanceListener, MembershipLi
     @Override
     public void instanceCreated( InstanceEvent event ) {
         Instance instance = event.getInstance();
-        logger.info( "Created instance ID: [" + instance.getId() + "] Type: [" + instance.getInstanceType() + "]" );
+        logger.info( "Created instance ID: [{}] Type: [{}]", instance.getId(), instance.getInstanceType() );
     }
 
 
     @Override
     public void instanceDestroyed( InstanceEvent event ) {
         Instance instance = event.getInstance();
-        logger.info( "Destroyed isntance ID: [" + instance.getId() + "] Type: [" + instance.getInstanceType() + "]" );
+        logger.info( "Destroyed instance ID: [{}] Type: [{}]", instance.getId(), instance.getInstanceType() );
     }
 
 
     @Override
     public void memberAdded( MembershipEvent membersipEvent ) {
-        logger.info( "MemberAdded " + membersipEvent );
+        logger.info( "MemberAdded {}", membersipEvent );
     }
 
 
     @Override
     public void memberRemoved( MembershipEvent membersipEvent ) {
-        logger.info( "MemberRemoved " + membersipEvent );
+        logger.info( "MemberRemoved {}", membersipEvent );
     }
 }

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManager.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManager.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManager.java
index d51131e..ed1d2de 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManager.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManager.java
@@ -443,9 +443,7 @@ public class CpEntityManager implements EntityManager {
         if ( cpEntity == null ) {
             if ( logger.isDebugEnabled() ) {
                 logger.debug( "FAILED to load entity {}:{} from app {}",
-                    new Object[] {
-                            id.getType(), id.getUuid(), applicationId
-                    } );
+                            id.getType(), id.getUuid(), applicationId );
             }
             return null;
         }
@@ -466,7 +464,7 @@ public class CpEntityManager implements EntityManager {
         }
         catch ( ClassCastException e1 ) {
             logger.error( "Unable to get typed entity: {} of class {}",
-                    new Object[] { entityId, entityClass.getCanonicalName(), e1 } );
+                    entityId, entityClass.getCanonicalName(), e1 );
         }
         return e;
     }
@@ -500,9 +498,8 @@ public class CpEntityManager implements EntityManager {
         if ( cpEntity == null ) {
             if ( logger.isDebugEnabled() ) {
                 logger.debug( "FAILED to load entity {}:{} from  app {}\n",
-                        new Object[] {
                                 id.getType(), id.getUuid(), applicationId
-                        } );
+                        );
             }
             return null;
         }
@@ -558,11 +555,9 @@ public class CpEntityManager implements EntityManager {
 
         if ( logger.isDebugEnabled() ) {
             logger.debug( "Updating entity {}:{}  app {}\n",
-                new Object[] {
                     entityId.getType(),
                     entityId.getUuid(),
-                    appId
-                } );
+                    appId );
         }
 
         //        if ( !UUIDUtils.isTimeBased( entityId.getUuid() ) ) {
@@ -588,9 +583,9 @@ public class CpEntityManager implements EntityManager {
 //            cpEntity = ecm.load( entityId ).toBlockingObservable().last();
 
             if (logger.isDebugEnabled()) {
-                logger.debug("Wrote {}:{} version {}", new Object[]{
+                logger.debug("Wrote {}:{} version {}",
                     cpEntity.getId().getType(), cpEntity.getId().getUuid(), cpEntity.getVersion()
-                });
+                );
             }
         }
         catch ( WriteUniqueVerifyException wuve ) {
@@ -686,14 +681,14 @@ public class CpEntityManager implements EntityManager {
         }
         catch ( Exception e ) {
             logger.error( "Unable to decrement counter application.collection: {}.",
-                    new Object[] { collection_name, e } );
+                    collection_name, e );
         }
         try {
             incrementAggregateCounters( null, null, null, APPLICATION_ENTITIES, -ONE_COUNT, cassandraTimestamp );
         }
         catch ( Exception e ) {
-            logger.error( "Unable to decrement counter application.entities for collection: {} " + "with timestamp: {}",
-                    new Object[] { collection_name, cassandraTimestamp, e } );
+            logger.error( "Unable to decrement counter application.entities for collection: {} with timestamp: {}",
+                    collection_name, cassandraTimestamp, e );
         }
     }
 
@@ -851,8 +846,8 @@ public class CpEntityManager implements EntityManager {
         Assert.notNull( collectionType, "collectionType is required" );
         Assert.notNull( aliasValue, "aliasValue is required" );
 
-        if (logger.isDebugEnabled()) {
-            logger.debug("getAlias() for collection type {} alias {}", collectionType, aliasValue);
+        if (logger.isTraceEnabled()) {
+            logger.trace("getAlias() for collection type {} alias {}", collectionType, aliasValue);
         }
 
         String collName = Schema.defaultCollectionName( collectionType );
@@ -866,9 +861,8 @@ public class CpEntityManager implements EntityManager {
         // add a warn statement so we can see if we have data migration issues.
         // TODO When we get an event system, trigger a repair if this is detected
         if ( results.size() > 1 ) {
-            logger.warn( "More than 1 entity with Owner id '{}' of type '{}' "
-                            + "and alias '{}' exists. This is a duplicate alias, and needs audited",
-                    new Object[] { ownerRef, collectionType, aliasValue } );
+            logger.warn( "More than 1 entity with Owner id '{}' of type '{}' and alias '{}' exists. This is a duplicate alias, and needs audited",
+                    ownerRef, collectionType, aliasValue );
         }
 
         return results.get(aliasValue);
@@ -888,8 +882,8 @@ public class CpEntityManager implements EntityManager {
     public Map<String, EntityRef> getAlias( EntityRef ownerRef, String collName, List<String> aliases )
             throws Exception {
 
-        if (logger.isDebugEnabled()) {
-            logger.debug("getAliases() for collection {} aliases {}", collName, aliases);
+        if (logger.isTraceEnabled()) {
+            logger.trace("getAliases() for collection {} aliases {}", collName, aliases);
         }
 
         Assert.notNull( ownerRef, "ownerRef is required" );
@@ -946,8 +940,8 @@ public class CpEntityManager implements EntityManager {
                 get( entityRef ).getType();
             }
             catch ( Exception e ) {
-                logger.error( "Unable to load entity " + entityRef.getType()
-                        + ":" + entityRef.getUuid(), e );
+                logger.error( "Unable to load entity {}:{}", entityRef.getType(),
+                        entityRef.getUuid(), e );
             }
             if ( entityRef == null ) {
                 throw new EntityNotFoundException(
@@ -1075,19 +1069,17 @@ public class CpEntityManager implements EntityManager {
 
         cpEntity.removeField( propertyName );
 
-        if(logger.isDebugEnabled()){
-            logger.debug( "About to Write {}:{} version {}", new Object[] {
-                cpEntity.getId().getType(), cpEntity.getId().getUuid(), cpEntity.getVersion()
-            } );
+        if(logger.isTraceEnabled()){
+            logger.trace( "About to Write {}:{} version {}",
+                cpEntity.getId().getType(), cpEntity.getId().getUuid(), cpEntity.getVersion() );
         }
 
         //TODO: does this call and others like it need a graphite reporter?
         cpEntity = ecm.write( cpEntity ).toBlocking().last();
 
-        if(logger.isDebugEnabled()){
-            logger.debug("Wrote {}:{} version {}", new Object[]{
-                cpEntity.getId().getType(), cpEntity.getId().getUuid(), cpEntity.getVersion()
-            });
+        if(logger.isTraceEnabled()){
+            logger.trace("Wrote {}:{} version {}",
+                cpEntity.getId().getType(), cpEntity.getId().getUuid(), cpEntity.getVersion() );
         }
 
         //Adding graphite metrics
@@ -1820,7 +1812,7 @@ public class CpEntityManager implements EntityManager {
                 .addToCollection( COLLECTION_ROLES, entity );
 
         logger.info( "Created role {} with id {} in group {}",
-            new String[] { roleName, entity.getUuid().toString(), groupId.toString() } );
+            roleName, entity.getUuid().toString(), groupId.toString() );
 
         return entity;
     }
@@ -2160,8 +2152,8 @@ public class CpEntityManager implements EntityManager {
             return null;
         }
 
-        if(logger.isDebugEnabled()){
-            logger.debug( "getUserByIdentifier {}:{}", identifier.getType(), identifier.toString() );
+        if(logger.isTraceEnabled()){
+            logger.trace( "getUserByIdentifier {}:{}", identifier.getType(), identifier.toString() );
         }
 
         if ( identifier.isUUID() ) {
@@ -2608,32 +2600,28 @@ public class CpEntityManager implements EntityManager {
 
         // prepare to write and index Core Persistence Entity into default scope
 
-        if ( logger.isDebugEnabled() ) {
-            logger.debug( "Writing entity {}:{} into app {}\n",
-                new Object[] {
+        if ( logger.isTraceEnabled() ) {
+            logger.trace( "Writing entity {}:{} into app {}\n",
                     entity.getType(),
                     entity.getUuid(),
                     applicationId,
-                    CpEntityMapUtils.toMap( cpEntity )
-                } );
+                    CpEntityMapUtils.toMap( cpEntity ));
 
         }
 
         try {
 
-            if(logger.isDebugEnabled()) {
-                logger.debug( "About to Write {}:{} version {}", new Object[] {
-                    cpEntity.getId().getType(), cpEntity.getId().getUuid(), cpEntity.getVersion()
-                } );
+            if(logger.isTraceEnabled()) {
+                logger.trace( "About to Write {}:{} version {}",
+                    cpEntity.getId().getType(), cpEntity.getId().getUuid(), cpEntity.getVersion() );
             }
 
             cpEntity = ecm.write( cpEntity ).toBlocking().last();
             entity.setSize(cpEntity.getSize());
 
-            if(logger.isDebugEnabled()) {
-                logger.debug( "Wrote {}:{} version {}", new Object[] {
-                    cpEntity.getId().getType(), cpEntity.getId().getUuid(), cpEntity.getVersion()
-                } );
+            if(logger.isTraceEnabled()) {
+                logger.trace( "Wrote {}:{} version {}",
+                    cpEntity.getId().getType(), cpEntity.getId().getUuid(), cpEntity.getVersion() );
             }
 
         }
@@ -2672,16 +2660,15 @@ public class CpEntityManager implements EntityManager {
         }
         catch ( Exception e ) {
             logger.error( "Unable to increment counter application.collection: {}.",
-                    new Object[] { collection_name, e } );
+                    collection_name, e );
         }
         try {
             incrementAggregateCounters( null, null, null,
                     APPLICATION_ENTITIES, ONE_COUNT, cassandraTimestamp );
         }
         catch ( Exception e ) {
-            logger.error( "Unable to increment counter application.entities for collection: "
-                    + "{} with timestamp: {}",
-                    new Object[] { collection_name, cassandraTimestamp, e } );
+            logger.error( "Unable to increment counter application.entities for collection: {} with timestamp: {}",
+                    collection_name, cassandraTimestamp, e );
         }
     }
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManagerFactory.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManagerFactory.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManagerFactory.java
index e3a0933..0462ac6 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManagerFactory.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpEntityManagerFactory.java
@@ -226,7 +226,7 @@ public class CpEntityManagerFactory implements EntityManagerFactory, Application
 
         if (logger.isDebugEnabled()) {
             logger.debug("New application orgName {} orgAppName {} id {} ",
-                new Object[]{orgName, name, applicationId.toString()});
+                orgName, name, applicationId.toString());
         }
 
         return initializeApplicationV2( orgName, applicationId, appName, properties, forMigration);
@@ -481,7 +481,7 @@ public class CpEntityManagerFactory implements EntityManagerFactory, Application
 
         if (logger.isDebugEnabled()) {
             logger.debug("getApplications(): Loading edges of edgeType {} from {}:{}",
-                new Object[]{edgeType, managementId.getType(), managementId.getUuid()});
+                edgeType, managementId.getType(), managementId.getUuid());
         }
 
         Observable<MarkedEdge> edges = gm.loadEdgesFromSource(
@@ -621,7 +621,7 @@ public class CpEntityManagerFactory implements EntityManagerFactory, Application
             results = em.searchCollection( em.getApplicationRef(), "propertymaps", q);
 
         } catch (Exception ex) {
-            logger.error("Error getting service property for delete of property: " + name, ex);
+            logger.error("Error getting service property for delete of property: {}", name, ex);
             return false;
         }
 
@@ -639,7 +639,7 @@ public class CpEntityManagerFactory implements EntityManagerFactory, Application
             em.update( propsEntity );
 
         } catch (Exception ex) {
-            logger.error("Error deleting service property orgAppName: " + name, ex);
+            logger.error("Error deleting service property orgAppName: {}", name, ex);
             return false;
         }
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpRelationManager.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpRelationManager.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpRelationManager.java
index fa15f8f..cfb8dfa 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpRelationManager.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpRelationManager.java
@@ -155,9 +155,9 @@ public class CpRelationManager implements RelationManager {
         this.connectionService = connectionService;
 
         if ( logger.isDebugEnabled() ) {
-            logger.debug( "Loading head entity {}:{} from app {}", new Object[] {
+            logger.debug( "Loading head entity {}:{} from app {}",
                 headEntity.getType(), headEntity.getUuid(), applicationScope
-            } );
+            );
         }
 
         Id entityId = new SimpleId( headEntity.getUuid(), headEntity.getType() );
@@ -178,10 +178,9 @@ public class CpRelationManager implements RelationManager {
 
         String edgeTypePrefix = CpNamingUtils.getEdgeTypeFromCollectionName( collectionName );
 
-        if (logger.isDebugEnabled()) {
-            logger.debug("getCollectionIndexes(): Searching for edge type prefix {} to target {}:{}", new Object[]{
-                edgeTypePrefix, cpHeadEntity.getId().getType(), cpHeadEntity.getId().getUuid()
-            });
+        if (logger.isTraceEnabled()) {
+            logger.trace("getCollectionIndexes(): Searching for edge type prefix {} to target {}:{}",
+                edgeTypePrefix, cpHeadEntity.getId().getType(), cpHeadEntity.getId().getUuid() );
         }
 
         Observable<Set<String>> types =
@@ -264,10 +263,9 @@ public class CpRelationManager implements RelationManager {
         Id entityId = new SimpleId( entity.getUuid(), entity.getType() );
 
 
-        if (logger.isDebugEnabled()) {
-            logger.debug("isConnectionMember(): Checking for edge type {} from {}:{} to {}:{}", new Object[]{
-                connectionType, headEntity.getType(), headEntity.getUuid(), entity.getType(), entity.getUuid()
-            });
+        if (logger.isTraceEnabled()) {
+            logger.trace("isConnectionMember(): Checking for edge type {} from {}:{} to {}:{}",
+                connectionType, headEntity.getType(), headEntity.getUuid(), entity.getType(), entity.getUuid() );
         }
 
         GraphManager gm = managerCache.getGraphManager( applicationScope );
@@ -285,10 +283,9 @@ public class CpRelationManager implements RelationManager {
 
         Id entityId = new SimpleId( entity.getUuid(), entity.getType() );
 
-        if (logger.isDebugEnabled()) {
-            logger.debug("isCollectionMember(): Checking for edge type {} from {}:{} to {}:{}", new Object[]{
-                collectionName, headEntity.getType(), headEntity.getUuid(), entity.getType(), entity.getUuid()
-            });
+        if (logger.isTraceEnabled()) {
+            logger.trace("isCollectionMember(): Checking for edge type {} from {}:{} to {}:{}",
+                collectionName, headEntity.getType(), headEntity.getUuid(), entity.getType(), entity.getUuid() );
         }
 
         GraphManager gm = managerCache.getGraphManager( applicationScope );
@@ -384,9 +381,8 @@ public class CpRelationManager implements RelationManager {
         }
 
         if ( logger.isDebugEnabled() ) {
-            logger.debug( "Loaded member entity {}:{} from   app {}\n   " + " data {}", new Object[] {
-                itemRef.getType(), itemRef.getUuid(), applicationScope, CpEntityMapUtils.toMap( memberEntity )
-            } );
+            logger.debug( "Loaded member entity {}:{} from   app {}\n    data {}",
+                itemRef.getType(), itemRef.getUuid(), applicationScope, CpEntityMapUtils.toMap( memberEntity ) );
         }
 
 
@@ -411,9 +407,8 @@ public class CpRelationManager implements RelationManager {
         } ).doOnCompleted( () -> {
             indexService.queueNewEdge( applicationScope, memberEntity, edge );
             if ( logger.isDebugEnabled() ) {
-                logger.debug( "Added entity {}:{} to collection {}", new Object[] {
-                    itemRef.getUuid().toString(), itemRef.getType(), collectionName
-                } );
+                logger.debug( "Added entity {}:{} to collection {}",
+                    itemRef.getUuid().toString(), itemRef.getType(), collectionName );
             }
         } ).toBlocking().lastOrDefault( null );
 
@@ -423,9 +418,8 @@ public class CpRelationManager implements RelationManager {
 
 
         if ( logger.isDebugEnabled() ) {
-            logger.debug( "Added entity {}:{} to collection {}", new Object[] {
-                itemRef.getUuid().toString(), itemRef.getType(), collectionName
-            } );
+            logger.debug( "Added entity {}:{} to collection {}",
+                itemRef.getUuid().toString(), itemRef.getType(), collectionName  );
         }
 
 
@@ -506,9 +500,8 @@ public class CpRelationManager implements RelationManager {
 
 
         if ( logger.isDebugEnabled() ) {
-            logger.debug( "Loading entity to remove from collection " + "{}:{} from app {}\n", new Object[] {
-                itemRef.getType(), itemRef.getUuid(), applicationScope
-            } );
+            logger.debug( "Loading entity to remove from collection {}:{} from app {}\n",
+                itemRef.getType(), itemRef.getUuid(), applicationScope );
         }
 
         Id entityId = new SimpleId( itemRef.getUuid(), itemRef.getType() );
@@ -650,11 +643,8 @@ public class CpRelationManager implements RelationManager {
             Thread.sleep( sleepTime );
         }
         while ( !found && length <= maxLength );
-        if ( logger.isInfoEnabled() ) {
-            logger.info( String
-                .format( "Consistent Search finished in %s,  results=%s, expected=%s...dumping stack", length,
-                    results.size(), expectedResults ) );
-        }
+        logger.info( "Consistent Search finished in {}, results={}, expected={}...dumping stack",
+            length, results.size(), expectedResults );
         return results;
     }
 
@@ -675,12 +665,10 @@ public class CpRelationManager implements RelationManager {
         ConnectionRefImpl connection = new ConnectionRefImpl( headEntity, connectionType, connectedEntityRef );
 
 
-        if ( logger.isDebugEnabled() ) {
-            logger.debug( "createConnection(): " + "Indexing connection type '{}'\n   from source {}:{}]\n"
-                + "   to target {}:{}\n   app {}", new Object[] {
+        if ( logger.isTraceEnabled() ) {
+            logger.trace( "createConnection(): Indexing connection type '{}'\n   from source {}:{}]\n   to target {}:{}\n   app {}",
                 connectionType, headEntity.getType(), headEntity.getUuid(), connectedEntityRef.getType(),
-                connectedEntityRef.getUuid(), applicationScope
-            } );
+                connectedEntityRef.getUuid(), applicationScope );
         }
 
         final Id entityId = new SimpleId( connectedEntityRef.getUuid(), connectedEntityRef.getType() );
@@ -758,11 +746,10 @@ public class CpRelationManager implements RelationManager {
         String connectionType = connectionRef.getTargetRefs().getConnectionType();
 
 
-        if ( logger.isDebugEnabled() ) {
-            logger.debug( "Deleting connection '{}' from source {}:{} \n   to target {}:{}", new Object[] {
+        if ( logger.isTraceEnabled() ) {
+            logger.trace( "Deleting connection '{}' from source {}:{} \n   to target {}:{}",
                 connectionType, connectingEntityRef.getType(), connectingEntityRef.getUuid(),
-                connectedEntityRef.getType(), connectedEntityRef.getUuid()
-            } );
+                connectedEntityRef.getType(), connectedEntityRef.getUuid() );
         }
 
         Id entityId = new SimpleId( connectedEntityRef.getUuid(), connectedEntityRef.getType() );
@@ -859,8 +846,8 @@ public class CpRelationManager implements RelationManager {
         for ( EntityRef ref : containers.keySet() ) {
             Entity entity = em.get( ref );
 
-            if (logger.isDebugEnabled()) {
-                logger.debug("   Found connecting entity: " + entity.getProperties());
+            if (logger.isTraceEnabled()) {
+                logger.trace("   Found connecting entity: " + entity.getProperties());
             }
 
             entities.add( entity );

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpSetup.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpSetup.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpSetup.java
index 035518e..e97be3f 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpSetup.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpSetup.java
@@ -171,7 +171,7 @@ public class CpSetup implements Setup {
 
         // Need this legacy stuff for queues
 
-        logger.info( "Creating static application keyspace " + getApplicationKeyspace() );
+        logger.info( "Creating static application keyspace {}", getApplicationKeyspace() );
 
         cass.createColumnFamily( getApplicationKeyspace(),
             createColumnFamilyDefinition( getApplicationKeyspace(), APPLICATIONS_CF,

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpWalker.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpWalker.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpWalker.java
index b5b27ac..25ff977 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpWalker.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/CpWalker.java
@@ -80,12 +80,11 @@ public class CpWalker {
 
         if (logger.isDebugEnabled()) {
             logger.debug("Loading edges types from {}:{}\n   scope {}:{}",
-                new Object[]{
                     applicationId.getType(),
                     applicationId.getUuid(),
                     applicationScope.getApplication().getType(),
                     applicationScope.getApplication().getUuid()
-                });
+                );
         }
 
         final SearchByEdgeType.Order order;

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/GuiceFactory.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/GuiceFactory.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/GuiceFactory.java
index 3d63ea4..b3ce43b 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/GuiceFactory.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/GuiceFactory.java
@@ -103,7 +103,7 @@ public class GuiceFactory implements FactoryBean<Injector> {
 
             hostsString = hostsString.substring( 0, hostsString.length() - 1 );
 
-            logger.info( "hostsString: " + hostsString );
+            logger.info( "hostsString: {}", hostsString );
 
             Properties cpProps = new Properties();
 
@@ -120,7 +120,7 @@ public class GuiceFactory implements FactoryBean<Injector> {
                 getAndValidateProperty( "cassandra.keyspace.replication" ) );
 
             if (logger.isDebugEnabled()) {
-                logger.debug("Set Cassandra properties for Core Persistence: " + cpProps.toString());
+                logger.debug("Set Cassandra properties for Core Persistence: {}", cpProps.toString());
             }
 
             // Make all Usergrid properties into Core Persistence config

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/AmazonAsyncEventService.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/AmazonAsyncEventService.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/AmazonAsyncEventService.java
index 542e54a..00dc69a 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/AmazonAsyncEventService.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/AmazonAsyncEventService.java
@@ -358,7 +358,7 @@ public class AmazonAsyncEventService implements AsyncEventService {
                 return new IndexEventResult(Optional.fromNullable(message),
                     Optional.fromNullable(indexOperationMessage), thisEvent.getCreationTime());
             } catch (Exception e) {
-                logger.error("Failed to index message: " + message.getMessageId(), message.getStringBody(), e);
+                logger.error("Failed to index message: {} {}", message.getMessageId(), message.getStringBody(), e);
                 return new IndexEventResult(Optional.absent(), Optional.<IndexOperationMessage>absent(),
                     event.getCreationTime());
             }
@@ -729,9 +729,8 @@ public class AmazonAsyncEventService implements AsyncEventService {
                                                          submitToIndex( indexEventResults );
                                                      if ( messagesToAck == null || messagesToAck.size() == 0 ) {
                                                          logger.error(
-                                                             "No messages came back from the queue operation should "
-                                                                 + "have seen "
-                                                                 + messages.size(), messages );
+                                                             "No messages came back from the queue operation, should have seen {} messages",
+                                                                 messages.size() );
                                                          return messagesToAck;
                                                      }
                                                      if ( messagesToAck.size() < messages.size() ) {

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/EventBuilderImpl.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/EventBuilderImpl.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/EventBuilderImpl.java
index 813436f..4e476db 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/EventBuilderImpl.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/asyncevents/EventBuilderImpl.java
@@ -54,7 +54,7 @@ import rx.Observable;
 @Singleton
 public class EventBuilderImpl implements EventBuilder {
 
-    private static final Logger log = LoggerFactory.getLogger( EventBuilderImpl.class );
+    private static final Logger logger = LoggerFactory.getLogger( EventBuilderImpl.class );
 
     private final IndexService indexService;
     private final EntityCollectionManagerFactory entityCollectionManagerFactory;
@@ -79,8 +79,8 @@ public class EventBuilderImpl implements EventBuilder {
         //process the entity immediately
         //only process the same version, otherwise ignore
 
-        if (log.isDebugEnabled()) {
-            log.debug("Indexing  in app scope {} entity {}", entity, applicationScope);
+        if (logger.isDebugEnabled()) {
+            logger.debug("Indexing  in app scope {} entity {}", entity, applicationScope);
         }
 
         return indexService.indexEntity( applicationScope, entity );
@@ -91,9 +91,9 @@ public class EventBuilderImpl implements EventBuilder {
     public Observable<IndexOperationMessage> buildNewEdge( final ApplicationScope applicationScope, final Entity entity,
                                                            final Edge newEdge ) {
 
-        if (log.isDebugEnabled()) {
-            log.debug("Indexing  in app scope {} with entity {} and new edge {}",
-                new Object[]{entity, applicationScope, newEdge});
+        if (logger.isDebugEnabled()) {
+            logger.debug("Indexing  in app scope {} with entity {} and new edge {}",
+                    applicationScope, entity, newEdge);
         }
 
         return indexService.indexEdge( applicationScope, entity, newEdge );
@@ -103,17 +103,14 @@ public class EventBuilderImpl implements EventBuilder {
     @Override
     public Observable<IndexOperationMessage> buildDeleteEdge( final ApplicationScope applicationScope, final Edge
         edge ) {
-        if (log.isDebugEnabled()) {
-            log.debug("Deleting in app scope {} with edge {} }", applicationScope, edge);
+        if (logger.isDebugEnabled()) {
+            logger.debug("Deleting in app scope {} with edge {}", applicationScope, edge);
         }
 
-        final Observable<IndexOperationMessage> edgeObservable =
-            indexService.deleteIndexEdge( applicationScope, edge ).flatMap( batch -> {
-                final GraphManager gm = graphManagerFactory.createEdgeManager( applicationScope );
-                return gm.deleteEdge( edge ).map( deletedEdge -> batch );
-            } );
-
-        return edgeObservable;
+        return indexService.deleteIndexEdge( applicationScope, edge ).flatMap( batch -> {
+            final GraphManager gm = graphManagerFactory.createEdgeManager( applicationScope );
+            return gm.deleteEdge( edge ).map( deletedEdge -> batch );
+        } );
     }
 
 
@@ -122,8 +119,8 @@ public class EventBuilderImpl implements EventBuilder {
 
     @Override
     public EntityDeleteResults buildEntityDelete( final ApplicationScope applicationScope, final Id entityId ) {
-        if (log.isDebugEnabled()) {
-            log.debug("Deleting entity id from index in app scope {} with entityId {} }", applicationScope, entityId);
+        if (logger.isDebugEnabled()) {
+            logger.debug("Deleting entity id from index in app scope {} with entityId {}", applicationScope, entityId);
         }
 
         final EntityCollectionManager ecm = entityCollectionManagerFactory.createCollectionManager( applicationScope );

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/index/ReIndexServiceImpl.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/index/ReIndexServiceImpl.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/index/ReIndexServiceImpl.java
index f108f37..da2ef1d 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/index/ReIndexServiceImpl.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/index/ReIndexServiceImpl.java
@@ -127,9 +127,7 @@ public class ReIndexServiceImpl implements ReIndexService {
             .buffer( indexProcessorFig.getReindexBufferSize())
             .doOnNext(edges -> {
 
-                if(logger.isInfoEnabled()) {
-                    logger.info("Sending batch of {} to be indexed.", edges.size());
-                }
+                logger.info("Sending batch of {} to be indexed.", edges.size());
                 indexService.indexBatch(edges, modifiedSince);
 
             });
@@ -285,7 +283,7 @@ public class ReIndexServiceImpl implements ReIndexService {
 
         if(logger.isDebugEnabled()) {
             logger.debug( "Flushing state for jobId {}, status {}, processedCount {}, lastUpdated {}",
-                new Object[] { jobId, status, processedCount, lastUpdated } );
+                    jobId, status, processedCount, lastUpdated);
         }
 
         mapManager.putString( jobId + MAP_STATUS_KEY, status.name() );

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/AbstractElasticSearchFilter.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/AbstractElasticSearchFilter.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/AbstractElasticSearchFilter.java
index b0a6a6b..deba16a 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/AbstractElasticSearchFilter.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/AbstractElasticSearchFilter.java
@@ -45,7 +45,7 @@ import java.util.Collection;
  */
 public abstract class AbstractElasticSearchFilter extends AbstractPathFilter<Id, Candidate, Integer> {
 
-    private static final Logger log = LoggerFactory.getLogger( AbstractElasticSearchFilter.class );
+    private static final Logger logger = LoggerFactory.getLogger( AbstractElasticSearchFilter.class );
 
     private final EntityIndexFactory entityIndexFactory;
     private final IndexLocationStrategyFactory indexLocationStrategyFactory;
@@ -139,7 +139,7 @@ public abstract class AbstractElasticSearchFilter extends AbstractPathFilter<Id,
                     }
                     catch ( Throwable t ) {
 
-                        log.error( "Unable to search candidates", t );
+                        logger.error( "Unable to search candidates", t );
                         subscriber.onError( t );
                     }
                 }

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateEntityFilter.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateEntityFilter.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateEntityFilter.java
index 449639c..bf444b5 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateEntityFilter.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateEntityFilter.java
@@ -211,8 +211,7 @@ public class CandidateEntityFilter extends AbstractFilter<FilterResult<Candidate
             //doesn't exist warn and drop
             if ( entity == null ) {
                 logger.warn(
-                    "Searched and received candidate with entityId {} and version {}, yet was not found in cassandra."
-                        + "  Ignoring since this could be a region sync issue",
+                    "Searched and received candidate with entityId {} and version {}, yet was not found in cassandra.  Ignoring since this could be a region sync issue",
                     candidateId, candidateVersion );
 
 
@@ -234,7 +233,7 @@ public class CandidateEntityFilter extends AbstractFilter<FilterResult<Candidate
             if ( UUIDComparator.staticCompare( entityVersion, candidateVersion ) > 0 || !entity.getEntity().isPresent()) {
 
                 logger.warn( "Deindexing stale entity on edge {} for entityId {} and version {}",
-                    new Object[] { searchEdge, entityId, entityVersion } );
+                        searchEdge, entityId, entityVersion);
                 batch.deindex( searchEdge, entityId, candidateVersion );
                 return;
             }
@@ -244,8 +243,8 @@ public class CandidateEntityFilter extends AbstractFilter<FilterResult<Candidate
             if ( UUIDComparator.staticCompare( candidateVersion, entityVersion ) > 0 ) {
 
                 logger.warn(
-                    "Found a newer version in ES over cassandra for edge {} for entityId {} and version {}.  Repair "
-                        + "should be run", new Object[] { searchEdge, entityId, entityVersion } );
+                    "Found a newer version in ES over cassandra for edge {} for entityId {} and version {}.  Repair should be run",
+                        searchEdge, entityId, entityVersion);
 
                   //TODO trigger an audit after a fail count where we explicitly try to repair from other regions
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateIdFilter.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateIdFilter.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateIdFilter.java
index 51cc0d0..96849f8 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateIdFilter.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/CandidateIdFilter.java
@@ -173,7 +173,7 @@ public class CandidateIdFilter extends AbstractFilter<FilterResult<Candidate>, F
             if ( UUIDComparator.staticCompare( entityVersion, candidateVersion ) > 0 ) {
 
                 logger.warn( "Deindexing stale entity on edge {} for entityId {} and version {}",
-                    new Object[] { searchEdge, entityId, entityVersion } );
+                        searchEdge, entityId, entityVersion );
                 batch.deindex( searchEdge, entityId, entityVersion );
                 return;
             }
@@ -183,8 +183,8 @@ public class CandidateIdFilter extends AbstractFilter<FilterResult<Candidate>, F
             if ( UUIDComparator.staticCompare( candidateVersion, entityVersion ) > 0 ) {
 
                 logger.warn(
-                    "Found a newer version in ES over cassandra for edge {} for entityId {} and version {}.  Repair "
-                        + "should be run", new Object[] { searchEdge, entityId, entityVersion } );
+                    "Found a newer version in ES over cassandra for edge {} for entityId {} and version {}.  Repair should be run",
+                        searchEdge, entityId, entityVersion );
             }
 
             //they're the same add it

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/SearchConnectionFilter.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/SearchConnectionFilter.java b/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/SearchConnectionFilter.java
index 27a12a8..d484ade 100644
--- a/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/SearchConnectionFilter.java
+++ b/stack/core/src/main/java/org/apache/usergrid/corepersistence/pipeline/read/search/SearchConnectionFilter.java
@@ -60,16 +60,12 @@ public class SearchConnectionFilter extends AbstractElasticSearchFilter {
 
     @Override
     protected SearchTypes getSearchTypes() {
-        final SearchTypes searchTypes = SearchTypes.fromNullableTypes( connectedEntityType.orNull() );
-
-        return searchTypes;
+        return SearchTypes.fromNullableTypes( connectedEntityType.orNull() );
     }
 
 
     @Override
     protected SearchEdge getSearchEdge( final Id id ) {
-        final SearchEdge searchEdge = createConnectionSearchEdge( id, connectionName );
-
-        return searchEdge;
+        return createConnectionSearchEdge( id, connectionName );
     }
 }

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/count/CassandraCounterStore.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/count/CassandraCounterStore.java b/stack/core/src/main/java/org/apache/usergrid/count/CassandraCounterStore.java
index ba32a01..fb4a7dc 100644
--- a/stack/core/src/main/java/org/apache/usergrid/count/CassandraCounterStore.java
+++ b/stack/core/src/main/java/org/apache/usergrid/count/CassandraCounterStore.java
@@ -41,7 +41,7 @@ import static org.apache.usergrid.persistence.cassandra.Serializers.*;
  * @author zznate
  */
 public class CassandraCounterStore implements CounterStore {
-    private static final Logger log = LoggerFactory.getLogger( CassandraCounterStore.class );
+    private static final Logger logger = LoggerFactory.getLogger( CassandraCounterStore.class );
 
     // keep track of exceptions thrown in scheduler so we can reduce noise in logs
     private Map<String, Integer> counterInsertFailures = new HashMap<String, Integer>();
@@ -84,14 +84,14 @@ public class CassandraCounterStore implements CounterStore {
             // errors here happen a lot on shutdown, don't fill the logs with them
             String error = e.getClass().getCanonicalName();
             if (counterInsertFailures.get( error ) == null) {
-                log.error( "CounterStore insert failed, first instance", e);
+                logger.error( "CounterStore insert failed, first instance", e);
                 counterInsertFailures.put( error, 1);
 
             } else {
                 int count = counterInsertFailures.get(error) + 1;
                 counterInsertFailures.put(error, count);
 
-                log.error(error + " caused CounterStore insert failure, count =  " + count, e);
+                logger.error("{} caused CounterStore insert failure, count = {}", error, count, e);
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/count/CassandraSubmitter.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/count/CassandraSubmitter.java b/stack/core/src/main/java/org/apache/usergrid/count/CassandraSubmitter.java
index 5323e1c..7fc7fa1 100644
--- a/stack/core/src/main/java/org/apache/usergrid/count/CassandraSubmitter.java
+++ b/stack/core/src/main/java/org/apache/usergrid/count/CassandraSubmitter.java
@@ -39,7 +39,7 @@ import com.yammer.metrics.core.TimerContext;
  * @author zznate
  */
 public class CassandraSubmitter implements BatchSubmitter {
-    private static final Logger log = LoggerFactory.getLogger( CassandraSubmitter.class );
+    private static final Logger logger = LoggerFactory.getLogger( CassandraSubmitter.class );
 
     private final int threadCount = 3;
     private final CassandraCounterStore cassandraCounterStore;
@@ -72,7 +72,7 @@ public class CassandraSubmitter implements BatchSubmitter {
 
     @Override
     public void shutdown() {
-        log.warn( "Shutting down CassandraSubmitter" );
+        logger.warn( "Shutting down CassandraSubmitter" );
         executor.shutdown();
     }
 }

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/mq/CounterQuery.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/mq/CounterQuery.java b/stack/core/src/main/java/org/apache/usergrid/mq/CounterQuery.java
index c29c08c..1ce06bc 100644
--- a/stack/core/src/main/java/org/apache/usergrid/mq/CounterQuery.java
+++ b/stack/core/src/main/java/org/apache/usergrid/mq/CounterQuery.java
@@ -21,8 +21,6 @@ import java.util.ArrayList;
 import java.util.List;
 import java.util.Map;
 
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
 import org.apache.usergrid.mq.Query.CounterFilterPredicate;
 import org.apache.usergrid.persistence.index.query.CounterResolution;
 import org.apache.usergrid.utils.JsonUtils;
@@ -36,8 +34,6 @@ import static org.apache.usergrid.utils.MapUtils.toMapList;
 
 public class CounterQuery {
 
-    public static final Logger logger = LoggerFactory.getLogger( CounterQuery.class );
-
     public static final int DEFAULT_MAX_RESULTS = 10;
 
     private int limit = 0;

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/mq/Query.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/mq/Query.java b/stack/core/src/main/java/org/apache/usergrid/mq/Query.java
index 674695c..bde0315 100644
--- a/stack/core/src/main/java/org/apache/usergrid/mq/Query.java
+++ b/stack/core/src/main/java/org/apache/usergrid/mq/Query.java
@@ -158,7 +158,7 @@ public class Query {
             return q;
         }
         catch ( Exception e ) {
-            logger.error( "Unable to parse \"" + ql + "\"", e );
+            logger.error( "Unable to parse \"{}\"", ql, e );
         }
         return null;
     }
@@ -584,7 +584,7 @@ public class Query {
         for ( SortPredicate s : sortPredicates ) {
             if ( s.getPropertyName().equals( propertyName ) ) {
                 logger.error(
-                        "Attempted to set sort order for " + s.getPropertyName() + " more than once, discardng..." );
+                        "Attempted to set sort order for {} more than once, discarding...", s.getPropertyName() );
                 return this;
             }
         }
@@ -600,7 +600,7 @@ public class Query {
         for ( SortPredicate s : sortPredicates ) {
             if ( s.getPropertyName().equals( sort.getPropertyName() ) ) {
                 logger.error(
-                        "Attempted to set sort order for " + s.getPropertyName() + " more than once, discardng..." );
+                        "Attempted to set sort order for {} more than once, discarding...", s.getPropertyName() );
                 return this;
             }
         }
@@ -642,8 +642,7 @@ public class Query {
             for ( FilterPredicate f : filterPredicates ) {
                 if ( f.getPropertyName().equals( propertyName ) && f.getValue().equals( value ) && "*"
                         .equals( value ) ) {
-                    logger.error( "Attempted to set wildcard wilder for " + f.getPropertyName()
-                            + " more than once, discardng..." );
+                    logger.error( "Attempted to set wildcard wilder for {} more than once, discarding...", f.getPropertyName());
                     return this;
                 }
             }
@@ -676,8 +675,7 @@ public class Query {
                     if ( f.getPropertyName().equals( filter.getPropertyName() ) && f.getValue()
                                                                                     .equals( filter.getValue() ) && "*"
                             .equals( filter.getValue() ) ) {
-                        logger.error( "Attempted to set wildcard wilder for " + f.getPropertyName()
-                                + " more than once, discardng..." );
+                        logger.error( "Attempted to set wildcard wilder for {} more than once, discarding...", f.getPropertyName());
                         return this;
                     }
                 }
@@ -685,7 +683,7 @@ public class Query {
             }
         }
         else {
-            logger.error( "Unable to add filter to query: " + filterStr );
+            logger.error( "Unable to add filter to query: {}", filterStr );
         }
         return this;
     }
@@ -1518,7 +1516,7 @@ public class Query {
                 return normalize( filter );
             }
             catch ( Exception e ) {
-                logger.error( "Unable to parse \"" + str + "\"", e );
+                logger.error( "Unable to parse \"{}\"", str, e );
             }
             return null;
         }

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/CassandraMQUtils.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/CassandraMQUtils.java b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/CassandraMQUtils.java
index 0c327df..d48b6d2 100644
--- a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/CassandraMQUtils.java
+++ b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/CassandraMQUtils.java
@@ -62,11 +62,9 @@ public class CassandraMQUtils {
     public static void logBatchOperation( String operation, Object columnFamily, Object key, Object columnName,
                                           Object columnValue, long timestamp ) {
 
-        if ( batch_logger.isInfoEnabled() ) {
-            batch_logger.info( "{} cf={} key={} name={} value={}", new Object[] {
-                    operation, columnFamily, key, columnName, columnValue
-            } );
-        }
+        batch_logger.info( "{} cf={} key={} name={} value={}",
+                operation, columnFamily, key, columnName, columnValue
+        );
     }
 
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/QueueManagerImpl.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/QueueManagerImpl.java b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/QueueManagerImpl.java
index 5ec4971..7a85eb6 100644
--- a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/QueueManagerImpl.java
+++ b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/QueueManagerImpl.java
@@ -212,7 +212,7 @@ public class QueueManagerImpl implements QueueManager {
                 createColumn( QUEUE_NEWEST, messageUuid, newest_ts, se, ue ) );
 
         if (logger.isDebugEnabled()) {
-            logger.debug("Writing UUID {} with oldest timestamp {} and newest with timestamp {}", new Object[]{messageUuid, oldest_ts, newest_ts});
+            logger.debug("Writing UUID {} with oldest timestamp {} and newest with timestamp {}", messageUuid, oldest_ts, newest_ts);
         }
 
         batch.addInsertion( bytebuffer( getQueueId( "/" ) ), QUEUE_SUBSCRIBERS.getColumnFamily(),
@@ -1042,7 +1042,9 @@ public class QueueManagerImpl implements QueueManager {
     public QueueIndexUpdate batchUpdateQueueIndex( QueueIndexUpdate indexUpdate, UUID subcriptionQueueId )
             throws Exception {
 
-        logger.info( "batchUpdateQueueIndex" );
+        if (logger.isTraceEnabled()) {
+            logger.trace("batchUpdateQueueIndex");
+        }
 
         Mutator<ByteBuffer> batch = indexUpdate.getBatch();
 
@@ -1104,11 +1106,9 @@ public class QueueManagerImpl implements QueueManager {
                         setGreaterThanEqualityFlag( new DynamicComposite( entryName ) ).serialize(), false,
                         INDEX_ENTRY_LIST_COUNT ).execute().get().getColumns();
 
-        if ( logger.isInfoEnabled() ) {
-            logger.info( "Found {} previous index entries for {} of entity {}", new Object[] {
-                    entries.size(), entryName, queueId
-            } );
-        }
+        logger.info( "Found {} previous index entries for {} of entity {}",
+                entries.size(), entryName, queueId
+        );
 
         // Delete all matching entries from entry list
         for ( HColumn<ByteBuffer, ByteBuffer> entry : entries ) {
@@ -1275,7 +1275,9 @@ public class QueueManagerImpl implements QueueManager {
                     composite_cursor = "";
                 }
                 int hashCode = slice.hashCode();
-                logger.info( "Cursor hash code: {} ", hashCode );
+                if (logger.isTraceEnabled()) {
+                    logger.trace("Cursor hash code: {} ", hashCode);
+                }
                 composite_cursor += hashCode + ":" + r.getCursor();
             }
 

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/AbstractSearch.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/AbstractSearch.java b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/AbstractSearch.java
index 7e5cbc0..a1d36a9 100644
--- a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/AbstractSearch.java
+++ b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/AbstractSearch.java
@@ -203,7 +203,7 @@ public abstract class AbstractSearch implements QueueSearch {
                 && comparator.compare( start, finish_uuid ) < 1 ) {
 
             logger.info( "Starting search with start UUID {}, finish UUID {}, and reversed {}",
-                    new Object[] { lastValue, finish_uuid, params.reversed } );
+                    lastValue, finish_uuid, params.reversed );
 
 
             SliceQuery<ByteBuffer, UUID, ByteBuffer> q = createSliceQuery( ko, be, ue, be );
@@ -299,9 +299,8 @@ public abstract class AbstractSearch implements QueueSearch {
 
         if ( logger.isDebugEnabled() ) {
             logger.debug( "Writing last client id pointer of '{}' for queue '{}' and consumer '{}' with timestamp '{}",
-                    new Object[] {
                             lastReturnedId, queueId, consumerId, colTimestamp
-                    } );
+                    );
         }
 
         mutator.addInsertion( consumerId, CONSUMERS.getColumnFamily(),

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/ConsumerTransaction.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/ConsumerTransaction.java b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/ConsumerTransaction.java
index 17d4934..ea8d3fa 100644
--- a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/ConsumerTransaction.java
+++ b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/ConsumerTransaction.java
@@ -127,8 +127,8 @@ public class ConsumerTransaction extends NoTransactionSearch
         // Generate a new expiration and insert it
         UUID expirationId = UUIDUtils.newTimeUUID( now + query.getTimeout() );
 
-        if (logger.isDebugEnabled()) {
-            logger.debug("Writing new timeout at '{}' for message '{}'", expirationId, messageId);
+        if (logger.isTraceEnabled()) {
+            logger.trace("Writing new timeout at '{}' for message '{}'", expirationId, messageId);
         }
 
 
@@ -350,13 +350,13 @@ public class ConsumerTransaction extends NoTransactionSearch
         for ( HColumn<UUID, UUID> column : cassResults )
         {
 
-            if ( logger.isDebugEnabled() )
+            if ( logger.isTraceEnabled() )
             {
-                logger.debug( "Adding uuid '{}' for original message '{}' to results for queue '{}' and consumer '{}'",
-                        new Object[] { column.getName(), column.getValue(), queueId, consumerId } );
-                logger.debug( "Max timeuuid : '{}', Current timeuuid : '{}', comparison '{}'", new Object[] {
+                logger.trace( "Adding uuid '{}' for original message '{}' to results for queue '{}' and consumer '{}'",
+                        column.getName(), column.getValue(), queueId, consumerId );
+                logger.trace( "Max timeuuid : '{}', Current timeuuid : '{}', comparison '{}'",
                         startTimeUUID, column.getName(), UUIDUtils.compare( startTimeUUID, column.getName() )
-                } );
+                );
             }
 
             results.add( new TransactionPointer( column.getName(), column.getValue() ) );
@@ -400,11 +400,11 @@ public class ConsumerTransaction extends NoTransactionSearch
         {
             UUID pointer = pointers.get( i ).expiration;
 
-            if ( logger.isDebugEnabled() )
+            if ( logger.isTraceEnabled() )
             {
-                logger.debug( "Removing transaction pointer '{}' for queue '{}' and consumer '{}'", new Object[] {
+                logger.trace( "Removing transaction pointer '{}' for queue '{}' and consumer '{}'",
                         pointer, queueId, consumerId
-                } );
+                );
             }
 
             mutator.addDeletion( key, CONSUMER_QUEUE_TIMEOUTS.getColumnFamily(), pointer, ue, cass.createTimestamp() );
@@ -445,8 +445,8 @@ public class ConsumerTransaction extends NoTransactionSearch
             UUID expirationId = UUIDUtils.newTimeUUID( futureTimeout, counter );
             UUID messageId = message.getUuid();
 
-            if (logger.isDebugEnabled()) {
-                logger.debug("Writing new timeout at '{}' for message '{}'", expirationId, messageId);
+            if (logger.isTraceEnabled()) {
+                logger.trace("Writing new timeout at '{}' for message '{}'", expirationId, messageId);
             }
 
             mutator.addInsertion( key, CONSUMER_QUEUE_TIMEOUTS.getColumnFamily(),

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/NoTransactionSearch.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/NoTransactionSearch.java b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/NoTransactionSearch.java
index aa535ef..4e8624f 100644
--- a/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/NoTransactionSearch.java
+++ b/stack/core/src/main/java/org/apache/usergrid/mq/cassandra/io/NoTransactionSearch.java
@@ -89,7 +89,7 @@ public class NoTransactionSearch extends AbstractSearch
         if ( logger.isDebugEnabled() )
         {
             logger.debug( "Last message id is '{}' for queueId '{}' and clientId '{}'",
-                    new Object[] { lastReadMessageId, queueId, consumerId } );
+                    lastReadMessageId, queueId, consumerId );
         }
 
         return new SearchParam( lastReadMessageId, false, lastReadMessageId != null, query.getLimit( DEFAULT_READ ) );

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/persistence/Schema.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/persistence/Schema.java b/stack/core/src/main/java/org/apache/usergrid/persistence/Schema.java
index 0da0334..6b8f139 100644
--- a/stack/core/src/main/java/org/apache/usergrid/persistence/Schema.java
+++ b/stack/core/src/main/java/org/apache/usergrid/persistence/Schema.java
@@ -559,7 +559,7 @@ public class Schema implements SchemaManager {
             return schemaNode;
         }
         catch ( Exception e ) {
-            logger.error( "Unable to get schema for entity type " + entityType, e );
+            logger.error( "Unable to get schema for entity type {}", entityType, e );
         }
         return null;
     }
@@ -1480,7 +1480,7 @@ public class Schema implements SchemaManager {
                         return;
                     }
                     catch ( Exception e ) {
-                        logger.error( "Unable to set entity property " + property, e );
+                        logger.error( "Unable to set entity property {}", property, e );
                     }
                 }
                 try {
@@ -1488,7 +1488,7 @@ public class Schema implements SchemaManager {
                     return;
                 }
                 catch ( Exception e ) {
-                    logger.error( "Unable to set entity property " + property, e );
+                    logger.error( "Unable to set entity property {}", property, e );
                 }
             }
         }
@@ -1503,7 +1503,7 @@ public class Schema implements SchemaManager {
                 return descriptor.getReadMethod().invoke( entity );
             }
             catch ( Exception e ) {
-                logger.error( "Unable to get entity property " + property, e );
+                logger.error( "Unable to get entity property {}", property, e );
             }
             return null;
         }
@@ -1535,7 +1535,7 @@ public class Schema implements SchemaManager {
                     }
                 }
                 catch ( Exception e ) {
-                    logger.error( "Unable to get entity property " + property, e );
+                    logger.error( "Unable to get entity property {}", property, e );
                 }
             }
         }
@@ -1607,7 +1607,7 @@ public class Schema implements SchemaManager {
                 for ( String property_name : required_properties ) {
 
                     if ( !columns.containsKey( property_name ) ) {
-                        logger.error( "Entity (" + entityType + ") missing required property: " + property_name,
+                        logger.error( "Entity ({}) missing required property: {}", entityType, property_name,
                                 new Throwable() );
                         return null;
                     }

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraPersistenceUtils.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraPersistenceUtils.java b/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraPersistenceUtils.java
index c94bf59..813fbe8 100644
--- a/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraPersistenceUtils.java
+++ b/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraPersistenceUtils.java
@@ -103,7 +103,7 @@ public class CassandraPersistenceUtils {
 
         if ( batch_logger.isDebugEnabled() ) {
             batch_logger.debug( "{} cf={} key={} name={} value={}",
-                    new Object[] { operation, columnFamily, key, columnName, columnValue } );
+                    operation, columnFamily, key, columnName, columnValue );
         }
     }
 
@@ -225,8 +225,8 @@ public class CassandraPersistenceUtils {
         }
         UUID uuid = UUID.nameUUIDFromBytes( keyStr.getBytes() ); //UUIDUtils.newTimeUUID(); //UUID.nameUUIDFromBytes( keyStr.getBytes() );
 
-        if (logger.isDebugEnabled()) {
-            logger.debug("Key {} equals UUID {}", keyStr, uuid);
+        if (logger.isTraceEnabled()) {
+            logger.trace("Key {} equals UUID {}", keyStr, uuid);
         }
 
         return uuid;

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraService.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraService.java b/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraService.java
index b0226b7..2431533 100644
--- a/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraService.java
+++ b/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/CassandraService.java
@@ -117,7 +117,7 @@ public class CassandraService {
         this.cluster = cluster;
         chc = cassandraHostConfigurator;
         lockManager = injector.getInstance( LockManager.class );
-        db_logger.info( "" + cluster.getKnownPoolHosts( false ) );
+        db_logger.info( "{}", cluster.getKnownPoolHosts( false ) );
         //getInjector
         applicationKeyspace  = injector.getInstance( CassandraFig.class ).getApplicationKeyspace();
     }
@@ -385,8 +385,8 @@ public class CassandraService {
                                                      Serializer<N> nameSerializer, Serializer<V> valueSerializer )
             throws Exception {
 
-        if ( db_logger.isInfoEnabled() ) {
-            db_logger.info( "getColumns cf={} key={}", columnFamily, key );
+        if ( db_logger.isTraceEnabled() ) {
+            db_logger.trace( "getColumns cf={} key={}", columnFamily, key );
         }
 
         SliceQuery<ByteBuffer, N, V> q = createSliceQuery( ko, be, nameSerializer, valueSerializer );
@@ -397,12 +397,12 @@ public class CassandraService {
         ColumnSlice<N, V> slice = r.get();
         List<HColumn<N, V>> results = slice.getColumns();
 
-        if ( db_logger.isInfoEnabled() ) {
+        if ( db_logger.isTraceEnabled() ) {
             if ( results == null ) {
-                db_logger.info( "getColumns returned null" );
+                db_logger.trace( "getColumns returned null" );
             }
             else {
-                db_logger.info( "getColumns returned {} columns", results.size() );
+                db_logger.trace( "getColumns returned {} columns", results.size() );
             }
         }
 
@@ -445,7 +445,7 @@ public class CassandraService {
                                                              Object finish, int count, boolean reversed )
             throws Exception {
 
-        if ( db_logger.isDebugEnabled() ) {
+        if ( db_logger.isTraceEnabled() ) {
             db_logger.debug( "getColumns cf=" + columnFamily + " key=" + key + " start=" + start + " finish=" + finish
                     + " count=" + count + " reversed=" + reversed );
         }
@@ -485,16 +485,12 @@ public class CassandraService {
         ColumnSlice<ByteBuffer, ByteBuffer> slice = r.get();
         List<HColumn<ByteBuffer, ByteBuffer>> results = slice.getColumns();
 
-        if ( db_logger.isDebugEnabled() ) {
+        if ( db_logger.isTraceEnabled() ) {
             if ( results == null ) {
-                if (logger.isDebugEnabled()) {
-                    db_logger.debug("getColumns returned null");
-                }
+                db_logger.trace("getColumns returned null");
             }
             else {
-                if (logger.isDebugEnabled()) {
-                    db_logger.debug("getColumns returned " + results.size() + " columns");
-                }
+                db_logger.trace("getColumns returned {} columns", results.size());
             }
         }
 
@@ -518,8 +514,8 @@ public class CassandraService {
                                                   Serializer<N> nameSerializer, Serializer<V> valueSerializer )
             throws Exception {
 
-        if ( db_logger.isDebugEnabled() ) {
-            db_logger.debug( "getColumns cf=" + columnFamily + " key=" + key + " names=" + columnNames );
+        if ( db_logger.isTraceEnabled() ) {
+            db_logger.trace( "getColumns cf={} key={} names={}", columnFamily, key, columnNames );
         }
 
         SliceQuery<ByteBuffer, N, V> q = createSliceQuery( ko, be, nameSerializer, valueSerializer );
@@ -533,12 +529,12 @@ public class CassandraService {
         ColumnSlice<N, V> slice = r.get();
         List<HColumn<N, V>> results = slice.getColumns();
 
-        if ( db_logger.isInfoEnabled() ) {
+        if ( db_logger.isTraceEnabled() ) {
             if ( results == null ) {
-                db_logger.info( "getColumns returned null" );
+                db_logger.trace( "getColumns returned null" );
             }
             else {
-                db_logger.info( "getColumns returned " + results.size() + " columns" );
+                db_logger.trace( "getColumns returned {} columns", results.size());
             }
         }
 
@@ -562,8 +558,8 @@ public class CassandraService {
                                            Serializer<N> nameSerializer, Serializer<V> valueSerializer )
             throws Exception {
 
-        if ( db_logger.isDebugEnabled() ) {
-            db_logger.debug( "getColumn cf=" + columnFamily + " key=" + key + " column=" + column );
+        if ( db_logger.isTraceEnabled() ) {
+            db_logger.trace( "getColumn cf={} key={} column={}", columnFamily, key, column );
         }
 
     /*
@@ -577,9 +573,9 @@ public class CassandraService {
                 q.setKey( bytebuffer( key ) ).setName( column ).setColumnFamily( columnFamily.toString() ).execute();
         HColumn<N, V> result = r.get();
 
-        if ( db_logger.isInfoEnabled() ) {
+        if ( db_logger.isTraceEnabled() ) {
             if ( result == null ) {
-                db_logger.info( "getColumn returned null" );
+                db_logger.trace( "getColumn returned null" );
             }
         }
 
@@ -591,8 +587,8 @@ public class CassandraService {
                                                 Serializer<N> nameSerializer, Serializer<V> valueSerializer )
             throws Exception {
 
-        if ( db_logger.isDebugEnabled() ) {
-            db_logger.debug( "getColumn cf=" + columnFamily + " key=" + key + " column=" + columns );
+        if ( db_logger.isTraceEnabled() ) {
+            db_logger.trace( "getColumn cf={} key={} column={}", columnFamily, key, columns );
         }
 
     /*
@@ -607,9 +603,9 @@ public class CassandraService {
                  .execute();
         ColumnSlice<N, V> result = r.get();
 
-        if ( db_logger.isDebugEnabled() ) {
+        if ( db_logger.isTraceEnabled() ) {
             if ( result == null ) {
-                db_logger.debug( "getColumn returned null" );
+                db_logger.trace( "getColumn returned null" );
             }
         }
 
@@ -620,9 +616,8 @@ public class CassandraService {
     public void setColumn( Keyspace ko, Object columnFamily, Object key, Object columnName, Object columnValue,
                            int ttl ) throws Exception {
 
-        if ( db_logger.isDebugEnabled() ) {
-            db_logger.debug( "setColumn cf=" + columnFamily + " key=" + key + " name=" + columnName + " value="
-                    + columnValue );
+        if ( db_logger.isTraceEnabled() ) {
+            db_logger.trace( "setColumn cf={} key={} name={} value={}", columnFamily, key, columnName, columnValue );
         }
 
         ByteBuffer name_bytes = null;
@@ -655,9 +650,8 @@ public class CassandraService {
 
     public void setColumns( Keyspace ko, Object columnFamily, byte[] key, Map<?, ?> map, int ttl ) throws Exception {
 
-        if ( db_logger.isDebugEnabled() ) {
-            db_logger.debug( "setColumns cf=" + columnFamily + " key=" + key + " map=" + map + ( ttl != 0 ?
-                                                                                                 " ttl=" + ttl : "" ) );
+        if ( db_logger.isTraceEnabled() ) {
+            db_logger.trace( "setColumns cf={} key={} map={} ttl={}", columnFamily, key, map, ttl);
         }
 
         Mutator<ByteBuffer> m = CountingMutator.createFlushingMutator( ko, be );
@@ -718,8 +712,8 @@ public class CassandraService {
      */
     public void deleteRow( Keyspace ko, final Object columnFamily, final Object key ) throws Exception {
 
-        if ( db_logger.isDebugEnabled() ) {
-            db_logger.debug( "deleteRow cf=" + columnFamily + " key=" + key );
+        if ( db_logger.isTraceEnabled() ) {
+            db_logger.trace( "deleteRow cf={} key={}", columnFamily, key );
         }
 
         CountingMutator.createFlushingMutator( ko, be ).addDeletion( bytebuffer( key ), columnFamily.toString() ).execute();

http://git-wip-us.apache.org/repos/asf/usergrid/blob/71fb6100/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/ConnectionRefImpl.java
----------------------------------------------------------------------
diff --git a/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/ConnectionRefImpl.java b/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/ConnectionRefImpl.java
index 1ad9413..f6d2e87 100644
--- a/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/ConnectionRefImpl.java
+++ b/stack/core/src/main/java/org/apache/usergrid/persistence/cassandra/ConnectionRefImpl.java
@@ -549,11 +549,11 @@ public class ConnectionRefImpl implements ConnectionRef {
 
             byte[] raw_id = byteStream.toByteArray();
 
-            logger.info( "raw connection index id: " + Hex.encodeHexString( raw_id ) );
+            logger.info( "raw connection index id: {}", Hex.encodeHexString( raw_id ) );
 
             uuid = UUID.nameUUIDFromBytes( raw_id );
 
-            logger.info( "connection index uuid: " + uuid );
+            logger.info( "connection index uuid: {}", uuid );
         }
         catch ( IOException e ) {
             logger.error( "Unable to create connection index UUID", e );