You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by nn...@apache.org on 2021/06/03 21:46:02 UTC

[geode] branch support/1.12 updated: GEODE-7864: Always use curly braces for control flow statements

This is an automated email from the ASF dual-hosted git repository.

nnag pushed a commit to branch support/1.12
in repository https://gitbox.apache.org/repos/asf/geode.git


The following commit(s) were added to refs/heads/support/1.12 by this push:
     new ccc63f9  GEODE-7864: Always use curly braces for control flow statements
ccc63f9 is described below

commit ccc63f9a5e5a8c61643afa0028f3af2723361288
Author: Donal Evans <do...@vmware.com>
AuthorDate: Wed Jun 2 15:06:57 2021 -0700

    GEODE-7864: Always use curly braces for control flow statements
    
    (cherry picked from commit 2879573)
    
    Authored-by: Donal Evans <do...@vmware.com>
---
 .../geode/modules/session/installer/Installer.java |   6 +-
 .../LocalSessionCacheWriterIntegrationTest.java    |   9 +-
 .../web/controllers/AddFreeItemToOrders.java       |  15 +-
 .../web/controllers/GetDeliveredOrders.java        |  15 +-
 .../geode/rest/internal/web/controllers/Order.java |   9 +-
 .../web/controllers/RedactingPostProcessor.java    |   9 +-
 .../geode/session/tests/ContainerInstall.java      |   3 +-
 .../geode/session/tests/ContainerManager.java      |  18 +-
 .../geode/session/tests/ServerContainer.java       |   6 +-
 .../geode/tools/pulse/PulseConnectivityTest.java   |   3 +-
 .../tools/pulse/ui/PulseAcceptanceTestBase.java    |  15 +-
 .../apache/geode/util/internal/GeodeConverter.java |   9 +-
 .../geode/test/concurrency/loop/LoopRunner.java    |   4 +-
 .../internal/cli/ListMappingCommandDUnitTest.java  |   3 +-
 .../connectors/jdbc/internal/xml/ElementType.java  |   3 +-
 .../management/MemoryThresholdsDUnitTest.java      |   9 +-
 .../MemoryThresholdsOffHeapDUnitTest.java          |  12 +-
 .../cache/management/ResourceManagerDUnitTest.java |   3 +-
 .../partition/PartitionRegionHelperDUnitTest.java  |  18 +-
 .../dunit/QueryUsingFunctionContextDUnitTest.java  |  30 +-
 ...igurationServiceConstraintsDistributedTest.java |   9 +-
 ...ncurrentIndexInitOnOverflowRegionDUnitTest.java |   6 +-
 ...exUpdateWithInplaceObjectModFalseDUnitTest.java |   3 +-
 .../ConcurrentIndexUpdateWithoutWLDUnitTest.java   |   3 +-
 .../index/PutAllWithIndexPerfDUnitTest.java        |   6 +-
 .../query/partitioned/PRBasicQueryDUnitTest.java   |   3 +-
 .../query/partitioned/PRQueryDUnitHelper.java      |  12 +-
 .../cache30/ClientRegisterInterestDUnitTest.java   |   9 +-
 .../geode/cache30/DistAckMapMethodsDUnitTest.java  |   3 +-
 .../cache30/PutAllCallBkRemoteVMDUnitTest.java     |  12 +-
 .../geode/cache30/RegionReliabilityTestCase.java   |   9 +-
 .../org/apache/geode/cache30/SlowRecDUnitTest.java |   3 +-
 .../geode/cache30/TXDistributedDUnitTest.java      |   3 +-
 .../distributed/DistributedLockBlackboardImpl.java |   9 +-
 .../DistributedLockServiceDUnitTest.java           |  12 +-
 .../apache/geode/disttx/DistTXDebugDUnitTest.java  |   6 +-
 .../cache/ClientServerGetAllDUnitTest.java         |  20 +-
 .../cache/ClientServerTransactionDUnitTest.java    |  15 +-
 .../internal/cache/ConcurrentMapOpsDUnitTest.java  |   3 +-
 .../PartitionedRegionCacheLoaderForRootRegion.java |   3 +-
 .../PartitionedRegionCacheLoaderForSubRegion.java  |   3 +-
 .../internal/cache/RemoteTransactionDUnitTest.java |   3 +-
 .../internal/cache/RemoveGlobalDUnitTest.java      |   6 +-
 .../geode/internal/cache/SizingFlagDUnitTest.java  |  30 +-
 .../cache/TransactionsWithDeltaDUnitTest.java      |   3 +-
 .../cache/execute/ColocationFailoverDUnitTest.java |   6 +-
 .../cache/execute/LocalDataSetDUnitTest.java       |   6 +-
 ...lientServerFunctionExecutionNoAckDUnitTest.java |   6 +-
 .../cache/execute/PRColocationDUnitTest.java       |  20 +-
 .../geode/internal/cache/execute/TimeKeeper.java   |   3 +-
 .../geode/internal/cache/ha/HAClearDUnitTest.java  |  24 +-
 .../internal/cache/ha/HADuplicateDUnitTest.java    |   9 +-
 .../geode/internal/cache/ha/HAGIIBugDUnitTest.java |  12 +-
 .../internal/cache/ha/HARegionQueueDUnitTest.java  |   3 +-
 .../partitioned/PartitionResolverDUnitTest.java    |  42 +-
 .../sockets/EventIDVerificationInP2PDUnitTest.java |   8 +-
 .../cache/tier/sockets/HAInterestTestCase.java     |   6 +-
 .../sockets/InterestListEndpointDUnitTest.java     |  18 +-
 .../sockets/InterestRegrListenerDUnitTest.java     |  11 +-
 .../tier/sockets/NewRegionAttributesDUnitTest.java |  33 +-
 .../jta/dunit/TransactionTimeOutDUnitTest.java     |  18 +-
 .../internal/jta/dunit/TxnTimeOutDUnitTest.java    |  12 +-
 .../geode/pdx/JSONPdxClientServerDUnitTest.java    |  18 +-
 .../java/org/apache/geode/CopyJUnitTest.java       |  54 ++-
 .../java/org/apache/geode/TXJUnitTest.java         |  24 +-
 .../org/apache/geode/cache/ProxyJUnitTest.java     |   4 +-
 .../operations/PutOperationContextJUnitTest.java   |  15 +-
 .../apache/geode/cache/query/QueryJUnitTest.java   |   3 +-
 .../cache/query/QueryServiceRegressionTest.java    |   9 +-
 .../functional/ComparisonOperatorsJUnitTest.java   |  12 +-
 .../cache/query/functional/ConstantsJUnitTest.java |  18 +-
 ...tinctResultsWithDupValuesInRegionJUnitTest.java |   6 +-
 .../cache/query/functional/FunctionJUnitTest.java  |  24 +-
 .../query/functional/IUM6Bug32345ReJUnitTest.java  |  15 +-
 .../geode/cache/query/functional/IUMJUnitTest.java |   6 +-
 .../query/functional/IndexOperatorJUnitTest.java   |  33 +-
 .../functional/IndexPrimaryKeyUsageJUnitTest.java  |   3 +-
 .../IndexUsageInNestedQueryJUnitTest.java          |   3 +-
 .../IndexUseMultFrmSnglCondJUnitTest.java          |   6 +-
 .../IndexWithSngleFrmAndMultCondQryJUnitTest.java  |  66 ++--
 .../query/functional/IteratorTypeDefJUnitTest.java |   6 +-
 .../IteratorTypeDefaultTypesJUnitTest.java         |  36 +-
 .../functional/IumMultConditionJUnitTest.java      |  15 +-
 .../query/functional/LimitClauseJUnitTest.java     |  21 +-
 .../functional/LogicalOperatorsJUnitTest.java      |  39 +-
 .../query/functional/MultipleRegionsJUnitTest.java |   3 +-
 .../query/functional/NestedQueryJUnitTest.java     |  12 +-
 .../functional/QRegionInterfaceJUnitTest.java      |  21 +-
 .../functional/StructMemberAccessJUnitTest.java    |   6 +-
 .../CompiledJunctionInternalsJUnitTest.java        |   3 +-
 .../internal/ProjectionAttributeJUnitTest.java     |  25 +-
 .../QueryFromClauseCanonicalizationJUnitTest.java  |   3 +-
 .../query/internal/QueryObserverCallbacksTest.java |   3 +-
 .../cache/query/internal/QueryUtilsJUnitTest.java  |   6 +-
 .../index/DeclarativeIndexCreationJUnitTest.java   |  12 +-
 .../index/IndexManagerIntegrationTest.java         |   6 +-
 ...ProgRegionCreationIndexUpdateTypeJUnitTest.java |  12 +-
 .../gms/messenger/JGroupsMessengerJUnitTest.java   |   3 +-
 ...qualityShouldUseArrayEqualsIntegrationTest.java |  54 ++-
 ...urrentFlushingAndRegionOperationsJUnitTest.java |   3 +-
 .../cache/ConcurrentRegionOperationsJUnitTest.java |   3 +-
 .../internal/cache/DiskRegRecoveryJUnitTest.java   |  24 +-
 .../internal/cache/DiskRegionClearJUnitTest.java   |   3 +-
 .../cache/PartitionedRegionCreationJUnitTest.java  |  24 +-
 ...itionedRegionQueryEvaluatorIntegrationTest.java |   3 +-
 ...itionedRegionSingleNodeOperationsJUnitTest.java |  15 +-
 ...skRegionOverflowAsyncRollingOpLogJUnitTest.java |  18 +-
 .../ha/BlockingHARQAddOperationJUnitTest.java      |   6 +-
 .../cache/ha/HARQAddOperationJUnitTest.java        |  27 +-
 .../tier/sockets/ConnectionProxyJUnitTest.java     |   3 +-
 .../datasource/AbstractPoolCacheJUnitTest.java     |   3 +-
 .../internal/datasource/CleanUpJUnitTest.java      |   3 +-
 .../ConnectionPoolCacheImplJUnitTest.java          |   3 +-
 .../datasource/ConnectionPoolingJUnitTest.java     |   9 +-
 .../datasource/DataSourceFactoryJUnitTest.java     |   9 +-
 .../internal/jta/GlobalTransactionJUnitTest.java   |  21 +-
 .../internal/jta/functional/CacheJUnitTest.java    |  94 +++--
 .../StatTypesAreRolledOverRegressionTest.java      |   3 +-
 .../concurrent/cm/ConcurrentHashMapJUnitTest.java  |   3 +-
 .../concurrent/cm/CountedMapLoopsJUnitTest.java    |  45 ++-
 .../util/concurrent/cm/IntMapCheckJUnitTest.java   | 132 ++++---
 .../util/concurrent/cm/MapCheckJUnitTest.java      | 132 ++++---
 .../util/concurrent/cm/MapLoopsJUnitTest.java      |  43 +-
 .../util/concurrent/cm/RLJBarJUnitTest.java        |  12 +-
 .../concurrent/cm/StringMapLoopsJUnitTest.java     |  37 +-
 .../internal/security/CliCommandsSecurityTest.java |   3 +-
 .../geode/pdx/AutoSerializableJUnitTest.java       | 105 +++--
 .../geode/pdx/PdxInstanceFactoryJUnitTest.java     |  12 +-
 .../apache/geode/pdx/PdxSerializableJUnitTest.java |  18 +-
 .../src/main/java/org/apache/geode/CopyHelper.java |  33 +-
 .../org/apache/geode/GemFireCheckedException.java  |   3 +-
 .../org/apache/geode/InternalGemFireError.java     |   3 +-
 .../main/java/org/apache/geode/SystemFailure.java  |   3 +-
 .../java/org/apache/geode/admin/AlertLevel.java    |  15 +-
 .../org/apache/geode/admin/SystemMemberType.java   |  12 +-
 .../admin/internal/AdminDistributedSystemImpl.java |  24 +-
 .../internal/DistributedSystemConfigImpl.java      |   6 +-
 .../internal/DistributedSystemHealthEvaluator.java |   3 +-
 .../admin/internal/DistributionLocatorImpl.java    |   6 +-
 .../internal/EnabledManagedEntityController.java   |  15 +-
 .../admin/internal/ManagedSystemMemberImpl.java    |   6 +-
 .../geode/admin/internal/SystemMemberImpl.java     |  18 +-
 .../internal/AdminDistributedSystemJmxImpl.java    |  15 +-
 .../apache/geode/admin/jmx/internal/AgentImpl.java |  18 +-
 .../admin/jmx/internal/CacheServerJmxImpl.java     |   6 +-
 .../apache/geode/admin/jmx/internal/MBeanUtil.java |   3 +-
 .../geode/admin/jmx/internal/MX4JModelMBean.java   | 426 +++++++++++++-------
 .../admin/jmx/internal/ManagedResourceType.java    |  15 +-
 .../jmx/internal/RefreshNotificationType.java      |  15 +-
 .../jmx/internal/StatisticResourceJmxImpl.java     |   6 +-
 .../geode/admin/jmx/internal/SystemMemberJmx.java  |   4 +-
 .../admin/jmx/internal/SystemMemberJmxImpl.java    |   6 +-
 .../org/apache/geode/cache/AttributesFactory.java  |  15 +-
 .../java/org/apache/geode/cache/DataPolicy.java    |   3 +-
 .../apache/geode/cache/DynamicRegionFactory.java   |  44 ++-
 .../org/apache/geode/cache/EvictionAction.java     |   6 +-
 .../org/apache/geode/cache/EvictionAlgorithm.java  |   6 +-
 .../apache/geode/cache/MembershipAttributes.java   |  22 +-
 .../apache/geode/cache/SubscriptionAttributes.java |  12 +-
 .../client/internal/AutoConnectionSourceImpl.java  |   3 +-
 .../client/internal/ClientPartitionAdvisor.java    |   3 +-
 .../client/internal/ExecuteFunctionNoAckOp.java    |  10 +-
 .../internal/ExecuteRegionFunctionNoAckOp.java     |  10 +-
 .../internal/ExecuteRegionFunctionSingleHopOp.java |   3 +-
 .../apache/geode/cache/client/internal/GetOp.java  |   3 +-
 .../geode/cache/client/internal/PoolImpl.java      |  12 +-
 .../apache/geode/cache/client/internal/PutOp.java  |   6 +-
 .../cache/client/internal/QueueManagerImpl.java    |   6 +-
 .../cache/client/internal/QueueStateImpl.java      |   3 +-
 .../client/internal/SingleHopClientExecutor.java   |   7 +-
 .../client/internal/pooling/PooledConnection.java  |   9 +-
 .../query/internal/AbstractCompiledValue.java      |   9 +-
 .../internal/AbstractGroupOrRangeJunction.java     |  18 +-
 .../cache/query/internal/AttributeDescriptor.java  |   9 +-
 .../org/apache/geode/cache/query/internal/Bag.java |   3 +-
 .../cache/query/internal/CompiledArithmetic.java   |  44 ++-
 .../cache/query/internal/CompiledComparison.java   |  18 +-
 .../geode/cache/query/internal/CompiledID.java     |   3 +-
 .../geode/cache/query/internal/CompiledIn.java     |   9 +-
 .../cache/query/internal/CompiledJunction.java     |  63 +--
 .../cache/query/internal/CompiledNegation.java     |   6 +-
 .../cache/query/internal/CompiledOperation.java    |  12 +-
 .../geode/cache/query/internal/CompiledPath.java   |   6 +-
 .../cache/query/internal/CompiledUnaryMinus.java   |  21 +-
 .../cache/query/internal/CompiledUndefined.java    |  11 +-
 .../cache/query/internal/CqQueryVsdStats.java      |   3 +-
 .../cache/query/internal/DefaultQueryService.java  |  15 +-
 .../cache/query/internal/ExecutionContext.java     |  19 +-
 .../geode/cache/query/internal/Functions.java      |   9 +-
 .../query/internal/IndexConditioningHelper.java    |   3 +-
 .../cache/query/internal/LinkedResultSet.java      |   3 +-
 .../cache/query/internal/LinkedStructSet.java      |   3 +-
 .../geode/cache/query/internal/MethodDispatch.java |  30 +-
 .../cache/query/internal/ObjectIntHashMap.java     | 121 ++++--
 .../geode/cache/query/internal/PathUtils.java      |   8 +-
 .../geode/cache/query/internal/QCompiler.java      |  17 +-
 .../apache/geode/cache/query/internal/QRegion.java |  12 +-
 .../geode/cache/query/internal/QueryUtils.java     |  24 +-
 .../geode/cache/query/internal/RangeJunction.java  |  15 +-
 .../query/internal/ResultsCollectionWrapper.java   |  12 +-
 .../geode/cache/query/internal/ResultsSet.java     |   3 +-
 .../cache/query/internal/RuntimeIterator.java      |   3 +-
 .../cache/query/internal/SortedResultSet.java      |   3 +-
 .../cache/query/internal/SortedStructSet.java      |   3 +-
 .../geode/cache/query/internal/StructBag.java      |   9 +-
 .../geode/cache/query/internal/StructImpl.java     |  15 +-
 .../geode/cache/query/internal/StructSet.java      |   9 +-
 .../apache/geode/cache/query/internal/Support.java |  15 +-
 .../cache/query/internal/index/AbstractIndex.java  |   6 +-
 .../query/internal/index/CompactRangeIndex.java    |   9 +-
 .../cache/query/internal/index/DummyQRegion.java   |   6 +-
 .../index/FunctionalIndexCreationHelper.java       |   3 +-
 .../cache/query/internal/index/HashIndex.java      |   6 +-
 .../cache/query/internal/index/HashIndexSet.java   |   9 +-
 .../cache/query/internal/index/IndexElemArray.java |  18 +-
 .../cache/query/internal/index/IndexManager.java   |   6 +-
 .../query/internal/index/PrimaryKeyIndex.java      |   6 +-
 .../index/PrimaryKeyIndexCreationHelper.java       |   3 +-
 .../cache/query/internal/index/RangeIndex.java     |  15 +-
 .../cache/query/internal/parse/ASTLiteral.java     |  56 ++-
 .../cache/query/internal/parse/UtilParser.java     |   3 +-
 .../query/internal/types/NumericComparator.java    |  31 +-
 .../cache/query/internal/types/ObjectTypeImpl.java |   3 +-
 .../cache/query/internal/types/StructTypeImpl.java |   6 +-
 .../query/internal/types/TemporalComparator.java   |   3 +-
 .../cache/query/internal/xml/ElementType.java      |   3 +-
 .../org/apache/geode/cache/server/ServerLoad.java  |  21 +-
 .../apache/geode/cache/wan/EventSequenceID.java    |   3 +-
 .../geode/distributed/DurableClientAttributes.java |  15 +-
 .../internal/ClusterDistributionManager.java       |  37 +-
 .../internal/ClusterOperationExecutors.java        |   9 +-
 .../distributed/internal/DistributionAdvisor.java  |   6 +-
 .../distributed/internal/DistributionImpl.java     |  22 +-
 .../internal/HighPriorityAckedMessage.java         |   3 +-
 .../distributed/internal/LocatorLoadSnapshot.java  |   3 +-
 .../internal/OverflowQueueWithDMStats.java         |  12 +-
 .../geode/distributed/internal/ReplyMessage.java   |   3 +-
 .../distributed/internal/ReplyProcessor21.java     |   9 +-
 .../distributed/internal/SerialAckedMessage.java   |   3 +-
 .../geode/distributed/internal/ServerLocation.java |  15 +-
 .../geode/distributed/internal/StartupMessage.java |   6 +-
 .../distributed/internal/StartupOperation.java     |   3 +-
 .../ThrottlingMemLinkedQueueWithDMStats.java       |   3 +-
 .../internal/deadlock/DLockDependencyMonitor.java  |  21 +-
 .../distributed/internal/deadlock/Dependency.java  |  21 +-
 .../internal/deadlock/LocalLockInfo.java           |  18 +-
 .../distributed/internal/deadlock/LocalThread.java |  18 +-
 .../deadlock/MessageDependencyMonitor.java         |  18 +-
 .../internal/deadlock/UnsafeThreadLocal.java       |   3 +-
 .../distributed/internal/direct/DirectChannel.java |   9 +-
 .../distributed/internal/locks/DLockGrantor.java   |  81 ++--
 .../internal/locks/DLockQueryProcessor.java        |   3 +-
 .../locks/DLockRecoverGrantorProcessor.java        |   3 +-
 .../internal/locks/DLockReleaseProcessor.java      |   6 +-
 .../internal/locks/DLockRequestProcessor.java      |  24 +-
 .../distributed/internal/locks/DLockService.java   |  42 +-
 .../distributed/internal/locks/DLockToken.java     |   6 +-
 .../distributed/internal/locks/ElderState.java     |   6 +-
 .../internal/locks/GrantorRequestProcessor.java    |   3 +-
 .../distributed/internal/locks/LockGrantorId.java  |  18 +-
 .../distributed/internal/locks/RemoteThread.java   |  15 +-
 .../membership/InternalDistributedMember.java      |   3 +-
 .../internal/membership/InternalRole.java          |  12 +-
 .../membership/adapter/auth/GMSAuthenticator.java  |   3 +-
 .../geode/examples/SimpleSecurityManager.java      |   3 +-
 .../examples/security/ExampleSecurityManager.java  |   9 +-
 .../org/apache/geode/internal/AvailablePort.java   |   8 +-
 .../org/apache/geode/internal/ClassPathLoader.java |   6 +-
 .../org/apache/geode/internal/ConfigSource.java    |   9 +-
 .../geode/internal/HeapDataOutputStream.java       |   6 +-
 .../apache/geode/internal/ObjIdConcurrentMap.java  | 118 ++++--
 .../java/org/apache/geode/internal/ObjIdMap.java   |   5 +-
 .../org/apache/geode/internal/SystemAdmin.java     |  15 +-
 .../apache/geode/internal/admin/ListenerIdMap.java |   5 +-
 .../geode/internal/admin/StatAlertsManager.java    |   6 +-
 .../internal/admin/remote/AdminReplyProcessor.java |   3 +-
 .../geode/internal/admin/remote/CacheDisplay.java  |   3 +-
 .../admin/remote/CancellationRegistry.java         |   3 +-
 .../admin/remote/DistributionLocatorId.java        |  21 +-
 .../internal/admin/remote/EntryValueNodeImpl.java  |  12 +-
 .../admin/remote/ObjectDetailsResponse.java        |  15 +-
 .../internal/admin/remote/RemoteEntrySnapshot.java |   3 +-
 .../admin/remote/RemoteGfManagerAgent.java         |   3 +-
 .../admin/remote/RemoteRegionSnapshot.java         |   3 +-
 .../internal/admin/remote/TailLogResponse.java     |   3 +-
 .../internal/admin/statalerts/FunctionHelper.java  |  15 +-
 .../admin/statalerts/MultiAttrDefinitionImpl.java  |   6 +-
 .../statalerts/NumberThresholdDecoratorImpl.java   |   5 +-
 .../admin/statalerts/SingleAttrDefinitionImpl.java |   9 +-
 .../admin/statalerts/StatisticInfoImpl.java        |  12 +-
 .../internal/cache/AbstractBucketRegionQueue.java  |   3 +-
 .../geode/internal/cache/AbstractDiskRegion.java   |  15 +-
 .../geode/internal/cache/AbstractRegion.java       |   6 +-
 .../geode/internal/cache/AbstractRegionMap.java    |  42 +-
 .../apache/geode/internal/cache/BucketAdvisor.java |  12 +-
 .../apache/geode/internal/cache/BucketDump.java    |  21 +-
 .../apache/geode/internal/cache/BucketRegion.java  |  12 +-
 .../geode/internal/cache/BucketRegionQueue.java    |   3 +-
 .../geode/internal/cache/CacheClientStatus.java    |   3 +-
 .../internal/cache/CacheDistributionAdvisor.java   |  63 ++-
 .../geode/internal/cache/CacheObserverHolder.java  |   3 +-
 .../geode/internal/cache/CachePerfStats.java       |   6 +-
 .../geode/internal/cache/ColocationHelper.java     |   8 +-
 .../internal/cache/CreateRegionProcessor.java      |   3 +-
 .../internal/cache/DestroyRegionOperation.java     |  12 +-
 .../apache/geode/internal/cache/DiskInitFile.java  |  21 +-
 .../apache/geode/internal/cache/DiskRegion.java    |   6 +-
 .../apache/geode/internal/cache/DiskStoreImpl.java |  30 +-
 .../internal/cache/DistributedCacheOperation.java  |   3 +-
 .../internal/cache/DistributedClearOperation.java  |  21 +-
 .../internal/cache/DistributedPutAllOperation.java |   9 +-
 .../geode/internal/cache/DistributedRegion.java    |  46 ++-
 .../DistributedRegionFunctionStreamingMessage.java |  24 +-
 .../cache/DistributedRemoveAllOperation.java       |   9 +-
 .../geode/internal/cache/EntryEventImpl.java       |  21 +-
 .../org/apache/geode/internal/cache/EventID.java   |  15 +-
 .../geode/internal/cache/EventStateHelper.java     |  12 +-
 .../apache/geode/internal/cache/ExpiryTask.java    |  23 +-
 .../apache/geode/internal/cache/FilterProfile.java |  18 +-
 .../cache/ForceableLinkedBlockingQueue.java        | 129 ++++--
 .../apache/geode/internal/cache/GridAdvisor.java   |   3 +-
 .../geode/internal/cache/IdentityArrayList.java    | 127 +++---
 .../internal/cache/InitialImageOperation.java      |   6 +-
 .../cache/MemberFunctionStreamingMessage.java      |  27 +-
 .../org/apache/geode/internal/cache/Oplog.java     |  54 ++-
 .../apache/geode/internal/cache/OverflowOplog.java |  21 +-
 .../geode/internal/cache/PRQueryProcessor.java     |   6 +-
 .../geode/internal/cache/PartitionedRegion.java    |  25 +-
 .../internal/cache/PartitionedRegionDataStore.java |   6 +-
 .../internal/cache/PartitionedRegionHelper.java    |  12 +-
 .../cache/PreferBytesCachedDeserializable.java     |   3 +-
 .../geode/internal/cache/RegionIdleExpiryTask.java |   3 +-
 .../geode/internal/cache/RegionTTLExpiryTask.java  |   3 +-
 .../cache/SearchLoadAndWriteProcessor.java         |  60 ++-
 .../geode/internal/cache/ServerPingMessage.java    |   9 +-
 .../apache/geode/internal/cache/TXEntryState.java  |  12 +-
 .../geode/internal/cache/TXFarSideCMTracker.java   |   3 +-
 .../java/org/apache/geode/internal/cache/TXId.java |   3 +-
 .../apache/geode/internal/cache/TXManagerImpl.java |   9 +-
 .../apache/geode/internal/cache/TXRegionState.java |   3 +-
 .../org/apache/geode/internal/cache/TXState.java   |   9 +-
 .../geode/internal/cache/UpdateOperation.java      |   3 +-
 .../internal/cache/VMCachedDeserializable.java     |  12 +-
 .../geode/internal/cache/VMLRURegionMap.java       |   9 +-
 .../CompressedCachedDeserializable.java            |   3 +-
 .../cache/control/RebalanceOperationImpl.java      |   3 +-
 .../cache/control/RebalanceResultsImpl.java        |   3 +-
 .../cache/entries/AbstractRegionEntry.java         |  23 +-
 .../geode/internal/cache/entries/DiskEntry.java    |  12 +-
 .../execute/FunctionStreamingResultCollector.java  |   3 +-
 .../cache/execute/StreamingFunctionOperation.java  |   3 +-
 .../geode/internal/cache/ha/HARegionQueue.java     |  15 +-
 .../cache/locks/TXLessorDepartureHandler.java      |   3 +-
 .../geode/internal/cache/locks/TXLockIdImpl.java   |  12 +-
 .../geode/internal/cache/locks/TXLockService.java  |   3 +-
 .../cache/locks/TXOriginatorRecoveryProcessor.java |   3 +-
 .../AllBucketProfilesUpdateMessage.java            |   9 +-
 .../partitioned/BucketProfileUpdateMessage.java    |   9 +-
 .../cache/partitioned/ColocatedRegionDetails.java  |   9 +-
 .../internal/cache/partitioned/DestroyMessage.java |   3 +-
 .../internal/cache/partitioned/DumpB2NRegion.java  |   3 +-
 .../cache/partitioned/FetchEntryMessage.java       |   3 +-
 .../cache/partitioned/IndexCreationMsg.java        |   6 +-
 .../cache/partitioned/PartitionMessage.java        |  21 +-
 .../PartitionedRegionFunctionStreamingMessage.java |   3 +-
 .../cache/partitioned/PutAllPRMessage.java         |  12 +-
 .../internal/cache/partitioned/PutMessage.java     |  21 +-
 .../internal/cache/partitioned/RegionAdvisor.java  |  14 +-
 .../cache/partitioned/RemoveAllPRMessage.java      |  12 +-
 .../cache/partitioned/RemoveIndexesMessage.java    |   6 +-
 .../internal/cache/partitioned/SizeMessage.java    |   3 +-
 .../partitioned/StreamingPartitionOperation.java   |   9 +-
 .../internal/cache/persistence/DiskStoreID.java    |  15 +-
 .../cache/persistence/PRPersistentConfig.java      |  18 +-
 .../cache/persistence/PersistentMemberID.java      |  39 +-
 .../cache/persistence/PersistentMemberPattern.java |  30 +-
 .../cache/persistence/query/mock/Pair.java         |  21 +-
 .../internal/cache/snapshot/FlowController.java    |  15 +-
 .../cache/snapshot/RegionSnapshotServiceImpl.java  |   6 +-
 .../internal/cache/snapshot/WindowedExporter.java  |   9 +-
 .../cache/tier/InternalClientMembership.java       |   6 +-
 .../internal/cache/tier/sockets/BaseCommand.java   |   3 +-
 .../cache/tier/sockets/CacheClientProxy.java       |  15 +-
 .../cache/tier/sockets/CacheClientUpdater.java     |   3 +-
 .../cache/tier/sockets/CacheServerHelper.java      |   6 +-
 .../cache/tier/sockets/ChunkedMessage.java         |  11 +-
 .../cache/tier/sockets/ClientHealthMonitor.java    |   6 +-
 .../ClientRegistrationEventQueueManager.java       |   3 +-
 .../cache/tier/sockets/ClientUserAuths.java        |  10 +-
 .../internal/cache/tier/sockets/Handshake.java     |   6 +-
 .../geode/internal/cache/tier/sockets/Message.java |   3 +-
 .../cache/tier/sockets/ServerConnection.java       |   6 +-
 .../cache/tier/sockets/command/PeriodicAck.java    |   3 +-
 .../internal/cache/tier/sockets/command/Ping.java  |   3 +-
 .../cache/tx/RemoteContainsKeyValueMessage.java    |   3 +-
 .../internal/cache/tx/RemoteDestroyMessage.java    |  18 +-
 .../internal/cache/tx/RemoteOperationMessage.java  |  12 +-
 .../internal/cache/tx/RemotePutAllMessage.java     |   9 +-
 .../geode/internal/cache/tx/RemotePutMessage.java  |  42 +-
 .../internal/cache/tx/RemoteRemoveAllMessage.java  |   6 +-
 .../internal/cache/versions/RVVExceptionB.java     |   3 +-
 .../cache/versions/RegionVersionVector.java        |   9 +-
 .../geode/internal/cache/versions/VersionTag.java  |  24 +-
 .../wan/AbstractGatewaySenderEventProcessor.java   |   4 +-
 .../internal/cache/wan/GatewaySenderAdvisor.java   |  12 +-
 .../ConcurrentParallelGatewaySenderQueue.java      |   6 +-
 .../wan/parallel/ParallelGatewaySenderQueue.java   |  39 +-
 .../cache/wan/serial/BatchDestroyOperation.java    |   3 +-
 .../serial/SerialGatewaySenderEventProcessor.java  |   9 +-
 .../cache/wan/serial/SerialGatewaySenderQueue.java |   6 +-
 .../internal/cache/xmlcache/CacheXmlGenerator.java | 363 +++++++++++------
 .../internal/cache/xmlcache/CacheXmlParser.java    |  13 +-
 .../geode/internal/concurrent/AtomicLong5.java     |   6 +-
 .../apache/geode/internal/concurrent/Atomics.java  |   6 +-
 .../concurrent/CompactConcurrentHashSet2.java      | 434 +++++++++++++--------
 .../org/apache/geode/internal/concurrent/LI.java   |  18 +-
 .../internal/datasource/AbstractPoolCache.java     |  11 +-
 .../datasource/ConfiguredDataSourceProperties.java |  15 +-
 .../internal/datasource/DataSourceFactory.java     |  27 +-
 .../datasource/GemFireConnPooledDataSource.java    |   7 +-
 .../datasource/GemFireTransactionDataSource.java   |   3 +-
 .../datasource/JCAConnectionManagerImpl.java       |   6 +-
 .../internal/datasource/TranxPoolCacheImpl.java    |   3 +-
 .../i18n/AbstractStringIdResourceBundle.java       |   3 +-
 .../apache/geode/internal/jndi/ContextImpl.java    |   9 +-
 .../internal/jndi/InitialContextFactoryImpl.java   |   5 +-
 .../apache/geode/internal/jndi/JNDIInvoker.java    |  57 ++-
 .../geode/internal/jta/GlobalTransaction.java      |  86 ++--
 .../apache/geode/internal/jta/TransactionImpl.java |  21 +-
 .../geode/internal/jta/TransactionManagerImpl.java | 111 ++++--
 .../geode/internal/jta/UserTransactionImpl.java    |   3 +-
 .../geode/internal/logging/LogFileParser.java      |   8 +
 .../internal/monitoring/ThreadsMonitoringImpl.java |   3 +-
 .../monitoring/ThreadsMonitoringProcess.java       |  13 +-
 .../monitoring/executor/AbstractExecutor.java      |   6 +-
 .../geode/internal/offheap/FreeListManager.java    |  12 +-
 .../internal/offheap/OffHeapRegionEntryHelper.java |  36 +-
 .../offheap/OffHeapStoredObjectAddressStack.java   |   3 +-
 .../geode/internal/offheap/RefCountChangeInfo.java |   6 +-
 .../internal/offheap/ReferenceCountHelperImpl.java |  24 +-
 .../geode/internal/sequencelog/model/Edge.java     |  30 +-
 .../geode/internal/sequencelog/model/GraphID.java  |  21 +-
 .../geode/internal/sequencelog/model/Vertex.java   |  24 +-
 .../internal/size/ReflectionSingleObjectSizer.java |  21 +-
 .../geode/internal/statistics/HostStatSampler.java |  15 +-
 .../internal/statistics/StatArchiveReader.java     |  39 +-
 .../statistics/platform/LinuxProcFsStatistics.java |  28 +-
 .../geode/internal/tcp/ByteBufferInputStream.java  |   3 +-
 .../org/apache/geode/internal/tcp/Connection.java  |   6 +-
 .../apache/geode/internal/tcp/ConnectionTable.java |   9 +-
 .../apache/geode/internal/tcp/MsgDestreamer.java   |  24 +-
 .../org/apache/geode/internal/tcp/MsgStreamer.java |   6 +-
 .../apache/geode/internal/util/PasswordUtil.java   |   6 +-
 .../apache/geode/internal/util/PluckStacks.java    |  39 +-
 .../concurrent/CustomEntryConcurrentHashMap.java   |   3 +-
 .../internal/util/concurrent/FutureResult.java     |  18 +-
 .../util/concurrent/SemaphoreReadWriteLock.java    |  12 +-
 .../util/concurrent/StoppableReentrantLock.java    |   6 +-
 .../StoppableReentrantReadWriteLock.java           |  12 +-
 .../management/internal/CollectionConverter.java   |  11 +-
 .../management/internal/CompositeConverter.java    |  21 +-
 .../management/internal/FederationComponent.java   |   3 +-
 .../internal/JmxManagerLocatorRequest.java         |   4 +-
 .../geode/management/internal/NotificationKey.java |   3 +-
 .../geode/management/internal/OpenMethod.java      |  24 +-
 .../management/internal/OpenTypeConverter.java     | 103 +++--
 .../geode/management/internal/RestAgent.java       |   9 +-
 .../configuration/domain/Configuration.java        |   3 +-
 .../domain/ConfigurationChangeResult.java          |  24 +-
 .../internal/configuration/domain/XmlEntity.java   |  24 +-
 .../internal/functions/CliFunctionResult.java      |  15 +-
 .../operation/OperationHistoryManager.java         |   3 +-
 .../internal/security/MBeanServerWrapper.java      |  13 +-
 .../internal/util/ClasspathScanLoadHelper.java     |   3 +-
 .../UniversalMembershipListenerAdapter.java        |  12 +-
 .../pdx/internal/AutoSerializableManager.java      |  36 +-
 .../java/org/apache/geode/pdx/internal/EnumId.java |  12 +-
 .../org/apache/geode/pdx/internal/EnumInfo.java    |  42 +-
 .../apache/geode/pdx/internal/PdxInstanceEnum.java |  21 +-
 .../apache/geode/pdx/internal/PdxInstanceImpl.java |   3 +-
 .../apache/geode/pdx/internal/PdxReaderImpl.java   |   3 +-
 .../org/apache/geode/pdx/internal/PdxString.java   |   3 +-
 .../org/apache/geode/pdx/internal/PdxType.java     |   3 +-
 .../apache/geode/pdx/internal/PdxUnreadData.java   |   6 +-
 .../internal/WeakConcurrentIdentityHashMap.java    |  12 +-
 .../geode/pdx/internal/json/PdxInstanceHelper.java |   3 +-
 .../geode/pdx/internal/json/PdxListHelper.java     |   3 +-
 .../apache/geode/pdx/internal/json/PdxToJSON.java  |   3 +-
 .../geode/cache/query/facets/lang/Address.java     |  12 +-
 .../geode/cache/query/facets/lang/Employee.java    |  10 +-
 .../geode/cache/query/facets/lang/Faculty.java     |  18 +-
 .../geode/cache/query/facets/lang/Person.java      |   3 +-
 .../geode/cache/query/facets/lang/Student.java     |  12 +-
 .../geode/cache/query/facets/lang/Utils.java       |   3 +-
 .../internal/SelectResultsComparatorJUnitTest.java |   9 +-
 .../geode/internal/DataSerializableJUnitTest.java  |  12 +-
 .../apache/geode/internal/ObjIdMapJUnitTest.java   |  15 +-
 .../rebalance/BucketOperatorWrapperTest.java       |  32 +-
 .../PartitionedRegionLoadModelJUnitTest.java       |  57 ++-
 .../offheap/OffHeapStoredObjectJUnitTest.java      |   3 +-
 .../offheap/RefCountChangeInfoJUnitTest.java       |   3 +-
 .../security/GemFireSecurityExceptionTest.java     |   6 +-
 .../geode/security/NotAuthorizedExceptionTest.java |  12 +-
 .../java/org/apache/geode/sequence/TimeAxis.java   |   6 +-
 .../query/cq/dunit/CqQueryUsingPoolDUnitTest.java  |   6 +-
 ...igurationServiceConstraintsDistributedTest.java |   9 +-
 .../cache/PRDeltaPropagationDUnitTest.java         |   6 +-
 .../internal/cache/ha/HADispatcherDUnitTest.java   |   3 +-
 .../tier/sockets/ClientToServerDeltaDUnitTest.java |   7 +-
 ...ltaToRegionRelationCQRegistrationDUnitTest.java |  10 +-
 .../management/CacheServerManagementDUnitTest.java |   6 +-
 .../geode/security/FilterPreAuthorization.java     |   6 +-
 .../cache/query/cq/internal/ClientCQImpl.java      |   3 +-
 .../cache/query/cq/internal/CqServiceImpl.java     |   6 +-
 .../cache/query/cq/internal/ServerCQImpl.java      |   3 +-
 .../cache/query/cq/internal/command/CloseCQ.java   |   3 +-
 .../cache/query/cq/internal/command/StopCQ.java    |   3 +-
 .../dunit/rules/tests/MemberStarterRuleTest.java   |   3 +-
 .../apache/geode/cache/query/QueryTestUtils.java   |   6 +-
 .../apache/geode/cache30/ClientServerTestCase.java |   3 +-
 .../org/apache/geode/cache30/RegionTestCase.java   |  57 ++-
 .../apache/geode/cache30/TestCacheListener.java    |   3 +-
 .../org/apache/geode/cache30/TestCacheWriter.java  |   3 +-
 .../cache/CustomerIDPartitionResolver.java         |   6 +-
 .../cache/execute/CustomerIDPartitionResolver.java |   6 +-
 .../internal/cache/execute/data/Customer.java      |   6 +-
 .../geode/internal/cache/execute/data/Order.java   |   3 +-
 .../internal/cache/execute/data/Shipment.java      |   3 +-
 .../internal/cache/functions/TestFunction.java     |  23 +-
 .../sockets/ClientServerMiscDUnitTestBase.java     |  12 +-
 .../cache/wan/AsyncEventQueueTestBase.java         |   6 +-
 .../management/internal/cli/HeadlessGfsh.java      |   3 +-
 .../commands/GemfireDataCommandsDUnitTestBase.java |  12 +-
 .../internal/configuration/ClusterConfig.java      |   5 +-
 .../security/templates/SimpleAccessController.java |   3 +-
 .../java/org/apache/geode/test/dunit/Invoke.java   |  10 +-
 .../junit/rules/MBeanServerConnectionRule.java     |   6 +-
 .../geode/test/junit/rules/MemberStarterRule.java  |   3 +-
 .../cli/commands/VersionCommandJUnitTest.java      |   3 +-
 .../geode/management/internal/cli/CliUtil.java     |   3 +-
 .../geode/management/internal/cli/Launcher.java    |   3 +-
 .../cli/commands/AlterQueryServiceCommand.java     |   3 +-
 .../cli/commands/CreateJndiBindingCommand.java     |   3 +-
 .../GetMemberConfigInformationFunction.java        |   9 +-
 .../geode/management/internal/cli/help/Helper.java |   9 +-
 .../internal/cli/result/TableBuilder.java          |   9 +-
 .../internal/cli/result/TableBuilderHelper.java    |  20 +-
 .../geode/management/internal/cli/shell/Gfsh.java  |   9 +-
 .../management/internal/cli/shell/GfshConfig.java  |   6 +-
 .../internal/cli/shell/MultiCommandHelper.java     |   7 +-
 .../internal/cli/util/ExportLogsCacheWriter.java   |   3 +-
 .../org/apache/geode/cache/query/CacheUtils.java   |   6 +-
 .../java/org/apache/geode/cache/query/Utils.java   |   3 +-
 .../geode/cache/query/data/ComparableWrapper.java  |   3 +-
 .../geode/cache/query/data/PortfolioPdx.java       |   6 +-
 .../apache/geode/cache/query/data/Position.java    |   8 +-
 .../geode/cache/query/data/PositionNoDS.java       |   8 +-
 .../apache/geode/cache/query/data/PositionPdx.java |   3 +-
 .../org/apache/geode/cache/query/data/Student.java |   3 +-
 .../geode/codeAnalysis/decode/CompiledClass.java   |  39 +-
 .../geode/codeAnalysis/decode/CompiledField.java   |  27 +-
 .../geode/codeAnalysis/decode/CompiledMethod.java  |  38 +-
 .../geode/codeAnalysis/decode/cp/CpClass.java      |   3 +-
 .../geode/codeAnalysis/decode/cp/CpUtf8.java       |  20 +-
 .../apache/geode/internal/AvailablePortHelper.java |   5 +-
 .../cache/PartitionedRegionTestHelper.java         |   6 +-
 .../geode/internal/cache/execute/data/CustId.java  |   6 +-
 .../geode/internal/cache/execute/data/OrderId.java |   6 +-
 .../internal/cache/execute/data/ShipmentId.java    |   3 +-
 .../apache/geode/internal/cache/wan/Filter70.java  |   3 +-
 .../cache/wan/MyGatewaySenderEventListener.java    |   3 +-
 .../cache/wan/MyGatewaySenderEventListener2.java   |   3 +-
 .../cache/wan/MyGatewayTransportFilter1.java       |   3 +-
 .../cache/wan/MyGatewayTransportFilter2.java       |   3 +-
 .../cache/wan/MyGatewayTransportFilter3.java       |   3 +-
 .../cache/wan/MyGatewayTransportFilter4.java       |   3 +-
 .../org/apache/geode/internal/jta/CacheUtils.java  |   3 +-
 .../internal/util/concurrent/cm/LoopHelpers.java   |   6 +-
 .../geode/management/internal/cli/dto/Key1.java    |   3 +-
 .../geode/management/internal/cli/dto/Key2.java    |   3 +-
 .../internal/cli/dto/ObjectWithCharAttr.java       |   3 +-
 .../geode/management/internal/cli/dto/Value1.java  |   3 +-
 .../geode/management/internal/cli/dto/Value2.java  |   3 +-
 .../java/org/apache/geode/pdx/DSInsidePdx.java     |  33 +-
 .../java/org/apache/geode/pdx/DomainObject.java    |  27 +-
 .../org/apache/geode/pdx/DomainObjectPdxAuto.java  | 111 ++++--
 .../main/java/org/apache/geode/pdx/Employee.java   |  27 +-
 .../main/java/org/apache/geode/pdx/NestedPdx.java  |  33 +-
 .../java/org/apache/geode/pdx/PdxInsideDS.java     |  30 +-
 .../java/org/apache/geode/pdx/SimpleClass.java     |  18 +-
 .../java/org/apache/geode/pdx/SimpleClass1.java    |  42 +-
 .../geode/pdx/TestObjectForJSONFormatter.java      | 138 ++++---
 .../apache/geode/security/TestSecurityManager.java |   6 +-
 .../geode/security/query/UserPermissions.java      |   3 +-
 .../geode/test/junit/rules/RestoreLocaleRule.java  |   6 +-
 .../java/parReg/query/unittest/NewPortfolio.java   |   6 +-
 geode-junit/src/main/java/perffmwk/Formatter.java  |   5 +-
 .../test/junit/rules/RestoreLocaleRuleTest.java    |   3 +-
 .../serializable/SerializableRuleListTest.java     |   6 +-
 .../apache/geode/logging/internal/OSProcess.java   |   9 +-
 .../cache/lucene/LuceneQueriesAccessorBase.java    |  15 +-
 .../cache/lucene/MixedObjectIndexDUnitTest.java    |  75 ++--
 .../IndexRepositoryFactoryDistributedTest.java     |   9 +-
 .../NestedObjectSeralizerIntegrationTest.java      |   3 +-
 .../repository/IndexRepositoryImplJUnitTest.java   |  12 +-
 .../lucene/internal/LuceneResultStructImpl.java    |  24 +-
 .../cache/lucene/internal/LuceneServiceImpl.java   |   3 +-
 .../internal/PageableLuceneQueryResultsImpl.java   |   3 +-
 .../lucene/internal/cli/LuceneIndexDetails.java    |   3 +-
 .../cache/lucene/internal/cli/LuceneQueryInfo.java |   5 +-
 .../cli/functions/LuceneCreateIndexFunction.java   |  12 +-
 .../repository/LuceneIndexMemoryOverheadTest.java  |   3 +-
 .../api/ClusterManagementOperationResult.java      |   3 +-
 .../management/runtime/MemberInformation.java      |   3 +-
 .../internal/membership/api/MembershipView.java    |   9 +-
 .../internal/membership/gms/GMSMemberData.java     |  12 +-
 .../internal/membership/gms/GMSMembership.java     |  12 +-
 .../internal/membership/gms/GMSMembershipView.java |   9 +-
 .../membership/gms/MemberIdentifierImpl.java       |  69 ++--
 .../internal/membership/gms/Services.java          |   3 +-
 .../gms/locator/FindCoordinatorRequest.java        |  24 +-
 .../gms/locator/FindCoordinatorResponse.java       |  48 ++-
 .../membership/gms/membership/GMSJoinLeave.java    |   3 +-
 .../gms/messages/InstallViewMessage.java           |  27 +-
 .../gms/messages/JoinRequestMessage.java           |  27 +-
 .../gms/messages/JoinResponseMessage.java          |  33 +-
 .../membership/gms/messenger/JGAddress.java        |  10 +-
 .../membership/gms/messenger/Transport.java        |   3 +-
 .../org/apache/geode/tools/pulse/tests/Server.java |   3 +-
 .../geode/tools/pulse/internal/data/Cluster.java   |   8 +-
 .../tools/pulse/internal/data/Repository.java      |   3 +-
 .../security/GemFireAuthenticationProvider.java    |   3 +-
 .../service/ClusterMembersRGraphService.java       |   3 +-
 .../tools/pulse/tests/junit/BaseServiceTest.java   |   6 +-
 .../geode/cache/util/AutoBalancerJUnitTest.java    |   3 +-
 .../java/org/apache/geode/redis/AuthJUnitTest.java |   6 +-
 .../apache/geode/redis/ConcurrentStartTest.java    |   3 +-
 .../org/apache/geode/redis/HashesJUnitTest.java    |   3 +-
 .../org/apache/geode/redis/ListsJUnitTest.java     |   3 +-
 .../java/org/apache/geode/redis/SetsJUnitTest.java |  18 +-
 .../apache/geode/redis/SortedSetsJUnitTest.java    |  58 ++-
 .../org/apache/geode/redis/StringsJunitTest.java   |   9 +-
 .../org/apache/geode/redis/GeodeRedisServer.java   |  33 +-
 .../geode/redis/internal/ByteArrayWrapper.java     |  20 +-
 .../geode/redis/internal/ByteToCommandDecoder.java |  54 ++-
 .../org/apache/geode/redis/internal/Coder.java     |  24 +-
 .../org/apache/geode/redis/internal/Command.java   |  21 +-
 .../apache/geode/redis/internal/DoubleWrapper.java |  13 +-
 .../redis/internal/ExecutionHandlerContext.java    |  35 +-
 .../org/apache/geode/redis/internal/GeoCoder.java  |   3 +-
 .../geode/redis/internal/GeodeRedisService.java    |   3 +-
 .../apache/geode/redis/internal/KeyRegistrar.java  |   5 +-
 .../geode/redis/internal/RegionProvider.java       |  41 +-
 .../redis/internal/executor/AbstractExecutor.java  |  35 +-
 .../geode/redis/internal/executor/DelExecutor.java |   6 +-
 .../redis/internal/executor/ExistsExecutor.java    |   5 +-
 .../redis/internal/executor/ExpireAtExecutor.java  |  13 +-
 .../redis/internal/executor/ExpireExecutor.java    |  13 +-
 .../redis/internal/executor/FlushAllExecutor.java  |   3 +-
 .../redis/internal/executor/KeysExecutor.java      |   8 +-
 .../redis/internal/executor/PersistExecutor.java   |   5 +-
 .../redis/internal/executor/ScanExecutor.java      |  12 +-
 .../geode/redis/internal/executor/TTLExecutor.java |   6 +-
 .../redis/internal/executor/TypeExecutor.java      |   5 +-
 .../redis/internal/executor/hash/HDelExecutor.java |   3 +-
 .../internal/executor/hash/HExistsExecutor.java    |   5 +-
 .../internal/executor/hash/HMGetExecutor.java      |   3 +-
 .../internal/executor/hash/HScanExecutor.java      |   8 +-
 .../redis/internal/executor/hash/HSetExecutor.java |  10 +-
 .../redis/internal/executor/hll/PFAddExecutor.java |  11 +-
 .../internal/executor/hll/PFCountExecutor.java     |   3 +-
 .../internal/executor/hll/PFMergeExecutor.java     |   6 +-
 .../internal/executor/list/LIndexExecutor.java     |   9 +-
 .../internal/executor/list/LRangeExecutor.java     |   5 +-
 .../redis/internal/executor/list/LRemExecutor.java |   3 +-
 .../redis/internal/executor/list/LSetExecutor.java |   6 +-
 .../internal/executor/list/LTrimExecutor.java      |   3 +-
 .../redis/internal/executor/list/ListExecutor.java |  10 +-
 .../redis/internal/executor/list/PopExecutor.java  |  12 +-
 .../redis/internal/executor/set/SAddExecutor.java  |   3 +-
 .../redis/internal/executor/set/SDiffExecutor.java |   6 +-
 .../internal/executor/set/SInterExecutor.java      |   6 +-
 .../internal/executor/set/SIsMemberExecutor.java   |   5 +-
 .../redis/internal/executor/set/SRemExecutor.java  |   3 +-
 .../redis/internal/executor/set/SScanExecutor.java |   8 +-
 .../redis/internal/executor/set/SetOpExecutor.java |  19 +-
 .../executor/sortedset/GeoAddExecutor.java         |   3 +-
 .../executor/sortedset/GeoRadiusExecutor.java      |   3 +-
 .../executor/sortedset/GeoRadiusParameters.java    |  16 +-
 .../internal/executor/sortedset/ZAddExecutor.java  |   3 +-
 .../internal/executor/sortedset/ZCardExecutor.java |   5 +-
 .../executor/sortedset/ZCountExecutor.java         |   5 +-
 .../executor/sortedset/ZLexCountExecutor.java      |   5 +-
 .../executor/sortedset/ZRangeByLexExecutor.java    |  14 +-
 .../executor/sortedset/ZRangeByScoreExecutor.java  |  19 +-
 .../executor/sortedset/ZRangeExecutor.java         |   8 +-
 .../internal/executor/sortedset/ZRankExecutor.java |   5 +-
 .../internal/executor/sortedset/ZRemExecutor.java  |   6 +-
 .../executor/sortedset/ZRemRangeByLexExecutor.java |   8 +-
 .../sortedset/ZRemRangeByRankExecutor.java         |  14 +-
 .../sortedset/ZRemRangeByScoreExecutor.java        |  14 +-
 .../internal/executor/sortedset/ZScanExecutor.java |   8 +-
 .../internal/executor/string/BitCountExecutor.java |  20 +-
 .../internal/executor/string/BitOpExecutor.java    |  33 +-
 .../internal/executor/string/BitPosExecutor.java   |  21 +-
 .../internal/executor/string/GetBitExecutor.java   |   3 +-
 .../internal/executor/string/GetRangeExecutor.java |   3 +-
 .../internal/executor/string/MGetExecutor.java     |   3 +-
 .../internal/executor/string/SetBitExecutor.java   |   8 +-
 .../internal/executor/string/SetEXExecutor.java    |   3 +-
 .../internal/executor/string/SetExecutor.java      |  32 +-
 .../internal/executor/string/SetNXExecutor.java    |   5 +-
 .../internal/executor/string/SetRangeExecutor.java |   3 +-
 .../internal/executor/string/StrlenExecutor.java   |   5 +-
 .../executor/transactions/ExecExecutor.java        |   7 +-
 .../serialization/BufferDataOutputStream.java      |  54 ++-
 .../internal/serialization/VersionOrdinalImpl.java |   3 +-
 .../internal/tcpserver/LocatorAddress.java         |  24 +-
 .../geode/internal/cache/wan/WANTestBase.java      |  18 +-
 .../wan/misc/NewWanAuthenticationDUnitTest.java    |   5 +-
 ...hutdownAllPersistentGatewaySenderDUnitTest.java |   3 +-
 .../internal/locator/wan/LocatorJoinMessage.java   |   6 +-
 .../web/controllers/AddFreeItemToOrders.java       |   3 +-
 .../geode/rest/internal/web/controllers/Order.java |   9 +-
 .../web/security/GeodeAuthenticationProvider.java  |   6 +-
 .../internal/rest/RebalanceIntegrationTest.java    |   3 +-
 .../rest/security/GeodeAuthenticationProvider.java |   6 +-
 .../ExportLogsStatsOverHttpDistributedTest.java    |   3 +-
 .../support/LoginHandlerInterceptor.java           |   6 +-
 729 files changed, 7262 insertions(+), 3812 deletions(-)

diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/Installer.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/Installer.java
index 4149360..1cb1bdc 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/Installer.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/Installer.java
@@ -224,8 +224,9 @@ public class Installer {
         index = i;
       }
     }
-    if (index == -1)
+    if (index == -1) {
       return null;
+    }
     if (nodelist.getLength() > (index + 1)) {
       return nodelist.item(index + 1);
     }
@@ -235,8 +236,9 @@ public class Installer {
   private Node append(final Document doc, final Node parent, final String element,
       final String value) {
     final Element child = doc.createElement(element);
-    if (value != null)
+    if (value != null) {
       child.setTextContent(value);
+    }
     parent.appendChild(child);
     return child;
   }
diff --git a/extensions/geode-modules/src/integrationTest/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheWriterIntegrationTest.java b/extensions/geode-modules/src/integrationTest/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheWriterIntegrationTest.java
index 866417b..9d9a10d 100644
--- a/extensions/geode-modules/src/integrationTest/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheWriterIntegrationTest.java
+++ b/extensions/geode-modules/src/integrationTest/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheWriterIntegrationTest.java
@@ -172,20 +172,23 @@ public class LocalSessionCacheWriterIntegrationTest {
 
     @Override
     public void beforeCreate(EntryEvent event) throws CacheWriterException {
-      if (throwExceptionOnCreate.get())
+      if (throwExceptionOnCreate.get()) {
         throw new RuntimeException("Mock Exception");
+      }
     }
 
     @Override
     public void beforeUpdate(EntryEvent event) throws CacheWriterException {
-      if (throwExceptionOnUpdate.get())
+      if (throwExceptionOnUpdate.get()) {
         throw new RuntimeException("Mock Exception");
+      }
     }
 
     @Override
     public void beforeDestroy(EntryEvent event) throws CacheWriterException {
-      if (throwExceptionOnDestroy.get())
+      if (throwExceptionOnDestroy.get()) {
         throw new RuntimeException("Mock Exception");
+      }
     }
   }
 
diff --git a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/AddFreeItemToOrders.java b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/AddFreeItemToOrders.java
index b9841f9..1bde245 100644
--- a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/AddFreeItemToOrders.java
+++ b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/AddFreeItemToOrders.java
@@ -83,31 +83,36 @@ public class AddFreeItemToOrders implements Function {
       result = (SelectResults) query.execute(queryArgs);
       int resultSize = result.size();
 
-      if (result instanceof Collection<?>)
+      if (result instanceof Collection<?>) {
         for (Object item : result) {
           keys.add(item);
         }
+      }
     } catch (FunctionDomainException e) {
-      if (cache != null)
+      if (cache != null) {
         cache.getLogger()
             .info("Caught FunctionDomainException while executing function AddFreeItemToOrders: "
                 + e.getMessage());
+      }
 
     } catch (TypeMismatchException e) {
-      if (cache != null)
+      if (cache != null) {
         cache.getLogger()
             .info("Caught TypeMismatchException while executing function AddFreeItemToOrders: "
                 + e.getMessage());
+      }
     } catch (NameResolutionException e) {
-      if (cache != null)
+      if (cache != null) {
         cache.getLogger()
             .info("Caught NameResolutionException while executing function AddFreeItemToOrders: "
                 + e.getMessage());
+      }
     } catch (QueryInvocationTargetException e) {
-      if (cache != null)
+      if (cache != null) {
         cache.getLogger().info(
             "Caught QueryInvocationTargetException while executing function AddFreeItemToOrders"
                 + e.getMessage());
+      }
     }
 
     // class has to be in classpath.
diff --git a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/GetDeliveredOrders.java b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/GetDeliveredOrders.java
index db2b5be..d257a74 100644
--- a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/GetDeliveredOrders.java
+++ b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/GetDeliveredOrders.java
@@ -59,33 +59,38 @@ public class GetDeliveredOrders implements Function {
       result = (SelectResults) query.execute();
       int resultSize = result.size();
 
-      if (result instanceof Collection<?>)
+      if (result instanceof Collection<?>) {
         for (Object item : result) {
           vals.add(item);
         }
+      }
     } catch (FunctionDomainException e) {
-      if (c != null)
+      if (c != null) {
         c.getLogger()
             .info("Caught FunctionDomainException while executing function GetDeliveredOrders: "
                 + e.getMessage());
+      }
 
     } catch (TypeMismatchException e) {
-      if (c != null)
+      if (c != null) {
         c.getLogger()
             .info("Caught TypeMismatchException while executing function GetDeliveredOrders: "
                 + e.getMessage());
+      }
 
     } catch (NameResolutionException e) {
-      if (c != null)
+      if (c != null) {
         c.getLogger()
             .info("Caught NameResolutionException while executing function GetDeliveredOrders: "
                 + e.getMessage());
+      }
 
     } catch (QueryInvocationTargetException e) {
-      if (c != null)
+      if (c != null) {
         c.getLogger().info(
             "Caught QueryInvocationTargetException while executing function GetDeliveredOrders: "
                 + e.getMessage());
+      }
 
     }
 
diff --git a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/Order.java b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/Order.java
index 6a0df77..6678f41 100644
--- a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/Order.java
+++ b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/Order.java
@@ -66,8 +66,9 @@ public class Order implements PdxSerializable {
   }
 
   public void addItem(final Item item) {
-    if (item != null)
+    if (item != null) {
       this.items.add(item);
+    }
   }
 
   public Long getPurchaseOrderNo() {
@@ -131,11 +132,13 @@ public class Order implements PdxSerializable {
   }
 
   public void setItems(List<Item> items) {
-    if (this.items == null)
+    if (this.items == null) {
       this.items = new ArrayList<Item>();
+    }
 
-    for (Item it : items)
+    for (Item it : items) {
       this.items.add(it);
+    }
   }
 
   public Date getOrderDate() {
diff --git a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/RedactingPostProcessor.java b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/RedactingPostProcessor.java
index af9fe81..37cc2c5 100644
--- a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/RedactingPostProcessor.java
+++ b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/rest/internal/web/controllers/RedactingPostProcessor.java
@@ -40,19 +40,22 @@ public class RedactingPostProcessor implements PostProcessor {
   @Override
   public Object processRegionValue(Object principal, String regionName, Object id,
       Object customer) {
-    if (customer == null)
+    if (customer == null) {
       return null;
+    }
     if (customer instanceof Customer) {
       String username = getUsername(principal);
       // Unable to retrieve the role at this point, so for this demo we'll just work with the
       // username
-      if (username.equals("super-user"))
+      if (username.equals("super-user")) {
         return customer;
+      }
       Customer cust = (Customer) customer;
       return new Customer(cust.getCustomerId(), cust.getFirstName(), cust.getLastName(),
           "*********");
-    } else
+    } else {
       return customer;
+    }
   }
 
   private String getUsername(final Object principal) {
diff --git a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ContainerInstall.java b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ContainerInstall.java
index 6706ba8..3d7ec92 100644
--- a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ContainerInstall.java
+++ b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ContainerInstall.java
@@ -470,8 +470,9 @@ public abstract class ContainerInstall {
         // Rewrite the node attributes
         rewriteNodeAttributes(node, attributes);
         // Write the tagId so that it can be found easier next time
-        if (tagId != null)
+        if (tagId != null) {
           ((Element) node).setAttribute("id", tagId);
+        }
       }
       // No node found creates new element under the parent tag passed in
       else {
diff --git a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ContainerManager.java b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ContainerManager.java
index 8fa9e9b..2a3e10d 100644
--- a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ContainerManager.java
+++ b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ContainerManager.java
@@ -46,8 +46,9 @@ public class ContainerManager {
   }
 
   public void cleanUp() throws IOException {
-    for (int i = 0; i < numContainers(); i++)
+    for (int i = 0; i < numContainers(); i++) {
       getContainer(i).cleanUp();
+    }
   }
 
   /**
@@ -65,8 +66,9 @@ public class ContainerManager {
    * The containers will not be running until one of the start methods is called.
    */
   public void addContainers(int numContainers, ContainerInstall install) throws IOException {
-    for (int i = 0; i < numContainers; i++)
+    for (int i = 0; i < numContainers; i++) {
       addContainer(install);
+    }
   }
 
   /**
@@ -87,8 +89,9 @@ public class ContainerManager {
    * Start all containers specified by the given indexes
    */
   public void startContainers(ArrayList<Integer> indexes) {
-    for (int index : indexes)
+    for (int index : indexes) {
       startContainer(index);
+    }
   }
 
   /**
@@ -111,8 +114,9 @@ public class ContainerManager {
    * Stop all containers specified by the given indexes
    */
   public void stopContainers(ArrayList<Integer> indexes) {
-    for (int index : indexes)
+    for (int index : indexes) {
       stopContainer(index);
+    }
   }
 
   /**
@@ -154,8 +158,9 @@ public class ContainerManager {
 
     ArrayList<Integer> indexes = new ArrayList<>();
     for (int i = 0; i < numContainers(); i++) {
-      if (getContainer(i).getState().toString().equals(state))
+      if (getContainer(i).getState().toString().equals(state)) {
         indexes.add(i);
+      }
     }
     return indexes;
   }
@@ -165,8 +170,9 @@ public class ContainerManager {
    */
   public ArrayList<ServerContainer> getContainersWithState(String state) {
     ArrayList<ServerContainer> statedContainers = new ArrayList<>();
-    for (int index : getContainerIndexesWithState(state))
+    for (int index : getContainerIndexesWithState(state)) {
       statedContainers.add(getContainer(index));
+    }
     return statedContainers;
   }
 
diff --git a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ServerContainer.java b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ServerContainer.java
index e96dff8..b25ff71 100644
--- a/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ServerContainer.java
+++ b/geode-assembly/geode-assembly-test/src/main/java/org/apache/geode/session/tests/ServerContainer.java
@@ -181,9 +181,10 @@ public abstract class ServerContainer {
    * calling the cargo container's start function
    */
   public void start() {
-    if (container.getState().isStarted())
+    if (container.getState().isStarted()) {
       throw new IllegalArgumentException("Container " + description
           + " failed to start because it is currently " + container.getState());
+    }
 
     LocalConfiguration config = getConfiguration();
     // Set container ports from available ports
@@ -403,9 +404,10 @@ public abstract class ServerContainer {
     LocalConfiguration config = getConfiguration();
     config.applyPortOffset();
 
-    if (!container.getState().isStarted())
+    if (!container.getState().isStarted()) {
       throw new IllegalStateException(
           "Container is not started, thus a port has not yet been assigned to the container.");
+    }
 
     return config.getPropertyValue(portType);
   }
diff --git a/geode-assembly/src/integrationTest/java/org/apache/geode/tools/pulse/PulseConnectivityTest.java b/geode-assembly/src/integrationTest/java/org/apache/geode/tools/pulse/PulseConnectivityTest.java
index fe40776..d63db93 100644
--- a/geode-assembly/src/integrationTest/java/org/apache/geode/tools/pulse/PulseConnectivityTest.java
+++ b/geode-assembly/src/integrationTest/java/org/apache/geode/tools/pulse/PulseConnectivityTest.java
@@ -67,8 +67,9 @@ public class PulseConnectivityTest {
   @Before
   public void setUp() throws Exception {
     Properties locatorProperties = new Properties();
-    if (!"localhost".equals(jmxBindAddress))
+    if (!"localhost".equals(jmxBindAddress)) {
       locatorProperties.setProperty(JMX_MANAGER_BIND_ADDRESS, jmxBindAddress);
+    }
     locator.withProperties(locatorProperties).startLocator();
   }
 
diff --git a/geode-assembly/src/uiTest/java/org/apache/geode/tools/pulse/ui/PulseAcceptanceTestBase.java b/geode-assembly/src/uiTest/java/org/apache/geode/tools/pulse/ui/PulseAcceptanceTestBase.java
index f716597..40120b0 100644
--- a/geode-assembly/src/uiTest/java/org/apache/geode/tools/pulse/ui/PulseAcceptanceTestBase.java
+++ b/geode-assembly/src/uiTest/java/org/apache/geode/tools/pulse/ui/PulseAcceptanceTestBase.java
@@ -170,11 +170,12 @@ public abstract class PulseAcceptanceTestBase {
 
       String displaySocketCount =
           getWebDriver().findElement(By.id(MEMBER_VIEW_SOCKETS_ID)).getText();
-      if (actualMember.getTotalFileDescriptorOpen() < 0)
+      if (actualMember.getTotalFileDescriptorOpen() < 0) {
         assertThat("NA").isEqualTo(displaySocketCount);
-      else
+      } else {
         assertThat(String.valueOf(actualMember.getTotalFileDescriptorOpen()))
             .isEqualTo(displaySocketCount);
+      }
 
       String displayedJVMPauses =
           getWebDriver().findElement(By.id(MEMBER_VIEW_JVMPAUSES_ID)).getText();
@@ -304,11 +305,12 @@ public abstract class PulseAcceptanceTestBase {
       String displayedEntrySize = getWebDriver()
           .findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[3]/div[2]/div"))
           .getText();
-      if (actualRegion.getEntrySize() > 0)
+      if (actualRegion.getEntrySize() > 0) {
         assertThat(new DecimalFormat("##.####").format(actualRegion.getEntrySize()))
             .isEqualTo(displayedEntrySize);
-      else
+      } else {
         assertThat("NA").isEqualTo(displayedEntrySize);
+      }
       builder.moveToElement(TreeMapMember).release().perform();
     }
   }
@@ -340,11 +342,12 @@ public abstract class PulseAcceptanceTestBase {
       String displayedSocketCount = getWebDriver()
           .findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[5]/div[2]/div"))
           .getText();
-      if (actualMember.getTotalFileDescriptorOpen() > 0)
+      if (actualMember.getTotalFileDescriptorOpen() > 0) {
         assertThat(String.valueOf(actualMember.getTotalFileDescriptorOpen()))
             .isEqualTo(displayedSocketCount);
-      else
+      } else {
         assertThat("NA").isEqualTo(displayedSocketCount);
+      }
       builder.moveToElement(TreeMapMember).release().perform();
     }
   }
diff --git a/geode-common/src/main/java/org/apache/geode/util/internal/GeodeConverter.java b/geode-common/src/main/java/org/apache/geode/util/internal/GeodeConverter.java
index 2dbd724..c580559 100644
--- a/geode-common/src/main/java/org/apache/geode/util/internal/GeodeConverter.java
+++ b/geode-common/src/main/java/org/apache/geode/util/internal/GeodeConverter.java
@@ -22,14 +22,17 @@ public class GeodeConverter {
       return stringValue;
     } else {
       Object o = null;
-      if (type.startsWith("java.lang."))
+      if (type.startsWith("java.lang.")) {
         type = type.substring(10);
+      }
 
-      if ("string".equalsIgnoreCase(type))
+      if ("string".equalsIgnoreCase(type)) {
         return stringValue;
+      }
 
-      if ("char".equalsIgnoreCase(type) || "Character".equals(type))
+      if ("char".equalsIgnoreCase(type) || "Character".equals(type)) {
         return stringValue.charAt(0);
+      }
 
       try {
         if ("byte".equalsIgnoreCase(type)) {
diff --git a/geode-concurrency-test/src/main/java/org/apache/geode/test/concurrency/loop/LoopRunner.java b/geode-concurrency-test/src/main/java/org/apache/geode/test/concurrency/loop/LoopRunner.java
index 68f4fe8..d7dea56 100644
--- a/geode-concurrency-test/src/main/java/org/apache/geode/test/concurrency/loop/LoopRunner.java
+++ b/geode-concurrency-test/src/main/java/org/apache/geode/test/concurrency/loop/LoopRunner.java
@@ -99,7 +99,9 @@ public class LoopRunner implements Runner {
 
     @Override
     public void execute() throws ExecutionException, InterruptedException {
-      while (callablesStarting.get() > 0);
+      while (callablesStarting.get() > 0) {
+        ;
+      }
 
       start.countDown();
       for (Future future : futures) {
diff --git a/geode-connectors/src/distributedTest/java/org/apache/geode/connectors/jdbc/internal/cli/ListMappingCommandDUnitTest.java b/geode-connectors/src/distributedTest/java/org/apache/geode/connectors/jdbc/internal/cli/ListMappingCommandDUnitTest.java
index 971950f..4979f0f 100644
--- a/geode-connectors/src/distributedTest/java/org/apache/geode/connectors/jdbc/internal/cli/ListMappingCommandDUnitTest.java
+++ b/geode-connectors/src/distributedTest/java/org/apache/geode/connectors/jdbc/internal/cli/ListMappingCommandDUnitTest.java
@@ -75,8 +75,9 @@ public class ListMappingCommandDUnitTest implements Serializable {
 
   private void executeSql(String sql) {
     for (MemberVM server : Arrays.asList(server1, server2, server3, server4)) {
-      if (server == null)
+      if (server == null) {
         continue;
+      }
       server.invoke(() -> {
         try {
           DataSource ds = JNDIInvoker.getDataSource("connection");
diff --git a/geode-connectors/src/main/java/org/apache/geode/connectors/jdbc/internal/xml/ElementType.java b/geode-connectors/src/main/java/org/apache/geode/connectors/jdbc/internal/xml/ElementType.java
index 072088b..890a628 100644
--- a/geode-connectors/src/main/java/org/apache/geode/connectors/jdbc/internal/xml/ElementType.java
+++ b/geode-connectors/src/main/java/org/apache/geode/connectors/jdbc/internal/xml/ElementType.java
@@ -82,8 +82,9 @@ public enum ElementType {
 
   static ElementType getTypeFromName(String typeName) {
     for (ElementType type : ElementType.values()) {
-      if (type.typeName.equals(typeName))
+      if (type.typeName.equals(typeName)) {
         return type;
+      }
     }
     throw new IllegalArgumentException("Invalid type '" + typeName + "'");
   }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/management/MemoryThresholdsDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/management/MemoryThresholdsDUnitTest.java
index c186b24..af89d0e 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/management/MemoryThresholdsDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/management/MemoryThresholdsDUnitTest.java
@@ -728,16 +728,19 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
               if (owners.contains(server1Id)) {
                 keyFoundOnSickMember = true;
                 try {
-                  if (useTx)
+                  if (useTx) {
                     getCache().getCacheTransactionManager().begin();
+                  }
                   pr.getCache().getLogger().fine("SWAP:putting in tx:" + useTx);
                   pr.put(key, "value");
-                  if (useTx)
+                  if (useTx) {
                     getCache().getCacheTransactionManager().commit();
+                  }
                 } catch (LowMemoryException ex) {
                   caughtException = true;
-                  if (useTx)
+                  if (useTx) {
                     getCache().getCacheTransactionManager().rollback();
+                  }
                 }
               } else {
                 // puts on healthy member should continue
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/management/MemoryThresholdsOffHeapDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/management/MemoryThresholdsOffHeapDUnitTest.java
index 59f35e7..7bd947e 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/management/MemoryThresholdsOffHeapDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/management/MemoryThresholdsOffHeapDUnitTest.java
@@ -866,16 +866,19 @@ public class MemoryThresholdsOffHeapDUnitTest extends ClientServerTestCase {
               if (hasCriticalOwners) {
                 keyFoundOnSickMember = true;
                 try {
-                  if (useTx)
+                  if (useTx) {
                     getCache().getCacheTransactionManager().begin();
+                  }
                   pr.getCache().getLogger().fine("SWAP:putting in tx:" + useTx);
                   pr.put(key, "value");
-                  if (useTx)
+                  if (useTx) {
                     getCache().getCacheTransactionManager().commit();
+                  }
                 } catch (LowMemoryException ex) {
                   caughtException = true;
-                  if (useTx)
+                  if (useTx) {
                     getCache().getCacheTransactionManager().rollback();
+                  }
                 }
               } else {
                 // puts on healthy member should continue
@@ -1557,8 +1560,9 @@ public class MemoryThresholdsOffHeapDUnitTest extends ClientServerTestCase {
 
             @Override
             public boolean done() {
-              if (!ohm.getState().isCritical())
+              if (!ohm.getState().isCritical()) {
                 return false;
+              }
               // Only done once the bucket has been marked sick
               try {
                 pr.getRegionAdvisor().checkIfBucketSick(bucketId, bigKey);
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/management/ResourceManagerDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/management/ResourceManagerDUnitTest.java
index d1dda5b..9252139 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/management/ResourceManagerDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/management/ResourceManagerDUnitTest.java
@@ -1689,8 +1689,9 @@ public class ResourceManagerDUnitTest extends JUnit4CacheTestCase {
       }
     });
 
-    if (true)
+    if (true) {
       return;
+    }
 
     // initiate moveBucket to move from otherVM to newVM
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/partition/PartitionRegionHelperDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/partition/PartitionRegionHelperDUnitTest.java
index dee881f..b9f7b43 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/partition/PartitionRegionHelperDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/partition/PartitionRegionHelperDUnitTest.java
@@ -105,12 +105,15 @@ public class PartitionRegionHelperDUnitTest extends JUnit4CacheTestCase {
     future1.join(60 * 1000);
     future2.join(60 * 1000);
     future3.join(60 * 1000);
-    if (future1.exceptionOccurred())
+    if (future1.exceptionOccurred()) {
       throw future1.getException();
-    if (future2.exceptionOccurred())
+    }
+    if (future2.exceptionOccurred()) {
       throw future2.getException();
-    if (future3.exceptionOccurred())
+    }
+    if (future3.exceptionOccurred()) {
       throw future3.getException();
+    }
 
     SerializableRunnable checkAssignment = new SerializableRunnable("check assignment") {
       @Override
@@ -224,12 +227,15 @@ public class PartitionRegionHelperDUnitTest extends JUnit4CacheTestCase {
     future1.join();
     future2.join();
     future3.join();
-    if (future1.exceptionOccurred())
+    if (future1.exceptionOccurred()) {
       throw future1.getException();
-    if (future2.exceptionOccurred())
+    }
+    if (future2.exceptionOccurred()) {
       throw future2.getException();
-    if (future3.exceptionOccurred())
+    }
+    if (future3.exceptionOccurred()) {
       throw future3.getException();
+    }
 
     SerializableRunnable checkAssignment = new SerializableRunnable("check assignment") {
       @Override
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
index 53b218d..3ab8c85 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
@@ -237,12 +237,14 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
           QueryUsingFunctionContextDUnitTest test = new QueryUsingFunctionContextDUnitTest();
           ArrayList queryResults2 =
               test.runQueryOnClientUsingFunc(function, PartitionedRegionName1, filter, queries[i]);
-          if (queryResults2 == null)
+          if (queryResults2 == null) {
             fail(queries[i] + "result is null from client function");
+          }
 
           ArrayList queryResults1 = test.runLDSQueryOnClientUsingFunc(func, filter, queries[i]);
-          if (queryResults1 == null)
+          if (queryResults1 == null) {
             fail(queries[i] + "result is null from LDS function");
+          }
 
           r[0][0] = queryResults1;
           r[0][1] = queryResults2;
@@ -311,11 +313,13 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
           QueryUsingFunctionContextDUnitTest test = new QueryUsingFunctionContextDUnitTest();
           ArrayList queryResults2 =
               test.runQueryOnClientUsingFunc(function, PartitionedRegionName1, filter, queries[i]);
-          if (queryResults2 == null)
+          if (queryResults2 == null) {
             fail(queries[i] + "result is null from client function");
+          }
           ArrayList queryResults1 = test.runLDSQueryOnClientUsingFunc(func, filter, queries[i]);
-          if (queryResults1 == null)
+          if (queryResults1 == null) {
             fail(queries[i] + "result is null from LDS function");
+          }
 
 
           r[0][0] = queryResults1;
@@ -346,8 +350,9 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
               Region KeyRegion = null;
               for (int i = 3; i < 7; i++) {
                 KeyRegion = ((PartitionedRegion) pr).getBucketRegion(i/* key */);
-                if (KeyRegion != null)
+                if (KeyRegion != null) {
                   KeyRegion.destroyRegion();
+                }
               }
             }
           }
@@ -409,8 +414,9 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
             Region KeyRegion = null;
             for (int i = 0; i < 7; i++) {
               KeyRegion = ((PartitionedRegion) pr).getBucketRegion(i/* key */);
-              if (KeyRegion != null)
+              if (KeyRegion != null) {
                 KeyRegion.destroyRegion();
+              }
             }
           }
         };
@@ -479,8 +485,9 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
             Region KeyRegion = null;
             for (int i = 6; i < 9; i++) {
               KeyRegion = ((PartitionedRegion) pr).getBucketRegion(i/* key */);
-              if (KeyRegion != null)
+              if (KeyRegion != null) {
                 KeyRegion.destroyRegion();
+              }
             }
           }
         };
@@ -579,8 +586,9 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
         for (int i = 3; i < 5; i++) {
           ArrayList queryResults2 =
               test.runQueryOnClientUsingFunc(function, PartitionedRegionName1, filter, queries[i]);
-          if (queryResults2 == null)
+          if (queryResults2 == null) {
             fail(queries[i] + "result is null from client function");
+          }
           r[j++][1] = queryResults2;
         }
         createIndex();
@@ -588,8 +596,9 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
         for (int i = 3; i < 5; i++) {
           ArrayList queryResults1 =
               test.runQueryOnClientUsingFunc(function, PartitionedRegionName1, filter, queries[i]);
-          if (queryResults1 == null)
+          if (queryResults1 == null) {
             fail(queries[i] + "result is null from client function");
+          }
           r[j++][0] = queryResults1;
         }
 
@@ -1011,8 +1020,9 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
       public void run2() throws CacheException {
         Cache cache = CacheFactory.getAnyInstance();
         Region region = cache.getRegion(regionName);
-        for (int j = from; j < to; j++)
+        for (int j = from; j < to; j++) {
           region.put(new Integer(j), portfolio[j]);
+        }
         LogWriterUtils.getLogWriter()
             .info("getCacheSerializableRunnableForPRPuts: Inserted Portfolio data on Region "
                 + regionName);
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/QueryConfigurationServiceConstraintsDistributedTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/QueryConfigurationServiceConstraintsDistributedTest.java
index 1839604..da3bd25 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/QueryConfigurationServiceConstraintsDistributedTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/QueryConfigurationServiceConstraintsDistributedTest.java
@@ -547,13 +547,16 @@ public class QueryConfigurationServiceConstraintsDistributedTest implements Seri
 
     @Override
     public boolean equals(Object o) {
-      if (this == o)
+      if (this == o) {
         return true;
-      if (o == null || getClass() != o.getClass())
+      }
+      if (o == null || getClass() != o.getClass()) {
         return false;
+      }
       QueryObject that = (QueryObject) o;
-      if (getId() != that.getId())
+      if (getId() != that.getId()) {
         return false;
+      }
 
       return getName() != null ? getName().equals(that.getName()) : that.getName() == null;
     }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
index 4a67d05..6c9d630 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
@@ -398,11 +398,13 @@ public class ConcurrentIndexInitOnOverflowRegionDUnitTest extends JUnit4CacheTes
 
             Region region = getCache().getRegion(regionName);
             for (int i = 0; i < 100; i++) {
-              if (i == 50)
+              if (i == 50) {
                 IndexManager.testHook = new LocalTestHook();
+              }
               region.put(i, new Portfolio(i));
-              if (i == 50)
+              if (i == 50) {
                 Wait.pause(20);
+              }
             }
           }
         });
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
index 1aacd14..d20bc07 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
@@ -150,8 +150,9 @@ public class ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest
     Cache cache = GemFireCacheImpl.getInstance();
     if (cache != null) {
       Region region = cache.getRegion(regionName);
-      if (region != null)
+      if (region != null) {
         region.destroyRegion();
+      }
     }
   }
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
index 1923da9..e48b301 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
@@ -125,8 +125,9 @@ public class ConcurrentIndexUpdateWithoutWLDUnitTest extends JUnit4DistributedTe
     Cache cache = GemFireCacheImpl.getInstance();
     if (cache != null) {
       Region region = cache.getRegion(regionName);
-      if (region != null)
+      if (region != null) {
         region.destroyRegion();
+      }
     }
   }
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/PutAllWithIndexPerfDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/PutAllWithIndexPerfDUnitTest.java
index a35748e..babc3b6 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/PutAllWithIndexPerfDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/internal/index/PutAllWithIndexPerfDUnitTest.java
@@ -123,8 +123,9 @@ public class PutAllWithIndexPerfDUnitTest extends JUnit4CacheTestCase {
         Map data = new HashMap();
         for (int i = 0; i < 10000; i++) {
           Object p = new PortfolioPdx(i);
-          if (i < 1000)
+          if (i < 1000) {
             warmupMap.put(i, p);
+          }
           data.put(i, p);
         }
 
@@ -169,8 +170,9 @@ public class PutAllWithIndexPerfDUnitTest extends JUnit4CacheTestCase {
         Map data = new HashMap();
         for (int i = 0; i < 10000; i++) {
           Object p = new PortfolioPdx(i);
-          if (i < 1000)
+          if (i < 1000) {
             warmupMap.put(i, p);
+          }
           data.put(i, p);
         }
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/partitioned/PRBasicQueryDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/partitioned/PRBasicQueryDUnitTest.java
index 252bcfe..c96bed8 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/partitioned/PRBasicQueryDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/partitioned/PRBasicQueryDUnitTest.java
@@ -372,8 +372,9 @@ public class PRBasicQueryDUnitTest extends CacheTestCase {
       public void run2() {
         Cache cache = getCache();
         Region region = cache.getRegion(name);
-        for (int i = 0; i < 100; i++)
+        for (int i = 0; i < 100; i++) {
           region.put(i, new Portfolio(i));
+        }
       }
     });
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/partitioned/PRQueryDUnitHelper.java b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/partitioned/PRQueryDUnitHelper.java
index 570ccbf..a55bab9 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache/query/partitioned/PRQueryDUnitHelper.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache/query/partitioned/PRQueryDUnitHelper.java
@@ -517,8 +517,9 @@ public class PRQueryDUnitHelper implements Serializable {
       public void run2() throws CacheException {
         Cache cache = getCache();
         Region region = cache.getRegion(regionName);
-        for (int j = from; j < to; j++)
+        for (int j = from; j < to; j++) {
           region.put(new Integer(j), portfolio[j]);
+        }
       }
     };
     return (CacheSerializableRunnable) prPuts;
@@ -598,8 +599,9 @@ public class PRQueryDUnitHelper implements Serializable {
       public void run2() throws CacheException {
         Cache cache = getCache();
         Region region = cache.getRegion(regionName);
-        for (int j = from, i = to; j < to; j++, i++)
+        for (int j = from, i = to; j < to; j++, i++) {
           region.put(new Integer(i), portfolio[j]);
+        }
       }
     };
     return (CacheSerializableRunnable) prPuts;
@@ -617,8 +619,9 @@ public class PRQueryDUnitHelper implements Serializable {
       public void run2() throws CacheException {
         Cache cache = getCache();
         Region region = cache.getRegion(regionName);
-        for (int j = from; j < to; j++)
+        for (int j = from; j < to; j++) {
           region.put(portfolio[j], portfolio[j]);
+        }
       }
     };
     return (CacheSerializableRunnable) prPuts;
@@ -1797,8 +1800,9 @@ public class PRQueryDUnitHelper implements Serializable {
           Collection indexes = qs.getIndexes();
           assertEquals(3, indexes.size());
           Iterator it = indexes.iterator();
-          while (it.hasNext())
+          while (it.hasNext()) {
             logger.info("Following indexes found : " + it.next());
+          }
           qs.removeIndexes(parRegion);
           logger.info("Removed all the index on this paritioned regions : " + parRegion);
           indexes = qs.getIndexes();
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache30/ClientRegisterInterestDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache30/ClientRegisterInterestDUnitTest.java
index d384389..942593f 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache30/ClientRegisterInterestDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache30/ClientRegisterInterestDUnitTest.java
@@ -322,8 +322,9 @@ public class ClientRegisterInterestDUnitTest extends ClientServerTestCase {
       @Override
       public boolean done() {
         if (!"VAL-1-1".equals(region1.get(key1)) || !"VAL-1-1".equals(region2.get(key2))
-            || !"VAL-1-1".equals(region3.get(key3)))
+            || !"VAL-1-1".equals(region3.get(key3))) {
           return false;
+        }
         return true;
       }
 
@@ -410,8 +411,9 @@ public class ClientRegisterInterestDUnitTest extends ClientServerTestCase {
     ev = new WaitCriterion() {
       @Override
       public boolean done() {
-        if (!"VAL-2-2".equals(region1.get(key1)) || !"VAL-2-2".equals(region3.get(key3)))
+        if (!"VAL-2-2".equals(region1.get(key1)) || !"VAL-2-2".equals(region3.get(key3))) {
           return false;
+        }
         return true;
       }
 
@@ -449,8 +451,9 @@ public class ClientRegisterInterestDUnitTest extends ClientServerTestCase {
       @Override
       public boolean done() {
         if (!"VAL-2-3".equals(region1.get(key1)) || !"VAL-2-2".equals(region2.get(key2))
-            || !"VAL-2-3".equals(region3.get(key3)))
+            || !"VAL-2-3".equals(region3.get(key3))) {
           return false;
+        }
         return true;
       }
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache30/DistAckMapMethodsDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache30/DistAckMapMethodsDUnitTest.java
index 3a00c9e..ddf05a8 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache30/DistAckMapMethodsDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache30/DistAckMapMethodsDUnitTest.java
@@ -208,8 +208,9 @@ public class DistAckMapMethodsDUnitTest extends JUnit4DistributedTestCase { // T
     obj2 = vm1.invoke(DistAckMapMethodsDUnitTest.class, "removeMethod", objArr);
     LogWriterUtils.getLogWriter().fine("111111111" + obj1);
     LogWriterUtils.getLogWriter().fine("2222222222" + obj2);
-    if (obj1 == null)
+    if (obj1 == null) {
       fail("region1.getMethod returned null");
+    }
     if (!(obj1.equals(obj2))) {
       fail("region.remove failed with distributed ack scope");
     }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache30/PutAllCallBkRemoteVMDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache30/PutAllCallBkRemoteVMDUnitTest.java
index 7b1ba41..ab1ef85 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache30/PutAllCallBkRemoteVMDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache30/PutAllCallBkRemoteVMDUnitTest.java
@@ -343,8 +343,9 @@ public class PutAllCallBkRemoteVMDUnitTest extends JUnit4DistributedTestCase {
     public void afterCreate(EntryEvent event) {
       paperRegion.put("callbackCame", "true");
       Integer counter = (Integer) paperRegion.get("afterCreate");
-      if (counter == null)
+      if (counter == null) {
         counter = new Integer(1);
+      }
       paperRegion.put("afterCreate", new Integer(counter.intValue() + 1));
 
       LogWriterUtils.getLogWriter().info("In afterCreate" + putAllcounter);
@@ -368,8 +369,9 @@ public class PutAllCallBkRemoteVMDUnitTest extends JUnit4DistributedTestCase {
     public void afterUpdate(EntryEvent event) {
       paperRegion.put("callbackCame", "true");
       Integer counter = (Integer) paperRegion.get("afterUpdate");
-      if (counter == null)
+      if (counter == null) {
         counter = new Integer(1);
+      }
       paperRegion.put("afterUpdate", new Integer(counter.intValue() + 1));
       LogWriterUtils.getLogWriter().info("In afterUpdate" + afterUpdateputAllcounter);
       if (afterUpdateputAllcounter == forUpdate) {
@@ -396,8 +398,9 @@ public class PutAllCallBkRemoteVMDUnitTest extends JUnit4DistributedTestCase {
     @Override
     public void beforeCreate(EntryEvent event) {
       Integer counter = (Integer) paperRegion.get("beforeCreate");
-      if (counter == null)
+      if (counter == null) {
         counter = new Integer(1);
+      }
       paperRegion.put("beforeCreate", new Integer(counter.intValue() + 1));
       LogWriterUtils.getLogWriter().info("*******BeforeCreate***** event=" + event);
     }
@@ -405,8 +408,9 @@ public class PutAllCallBkRemoteVMDUnitTest extends JUnit4DistributedTestCase {
     @Override
     public void beforeUpdate(EntryEvent event) {
       Integer counter = (Integer) paperRegion.get("beforeUpdate");
-      if (counter == null)
+      if (counter == null) {
         counter = new Integer(1);
+      }
       paperRegion.put("beforeUpdate", new Integer(counter.intValue() + 1));
       LogWriterUtils.getLogWriter().info("In beforeUpdate" + beforeUpdateputAllcounter);
       LogWriterUtils.getLogWriter().info("*******BeforeUpdate***** event=" + event);
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache30/RegionReliabilityTestCase.java b/geode-core/src/distributedTest/java/org/apache/geode/cache30/RegionReliabilityTestCase.java
index dc91031..5cd7805 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache30/RegionReliabilityTestCase.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache30/RegionReliabilityTestCase.java
@@ -1089,10 +1089,12 @@ public abstract class RegionReliabilityTestCase extends ReliabilityTestCase {
 
   @Test
   public void testCommitDistributionException() throws Exception {
-    if (getRegionScope().isGlobal())
+    if (getRegionScope().isGlobal()) {
       return; // skip test under Global
-    if (getRegionScope().isDistributedNoAck())
+    }
+    if (getRegionScope().isDistributedNoAck()) {
       return; // skip test under DistributedNoAck
+    }
 
     final String name = this.getUniqueName();
     final String roleA = name + "-A";
@@ -1219,8 +1221,9 @@ public abstract class RegionReliabilityTestCase extends ReliabilityTestCase {
 
   @Test
   public void testRegionDistributionException() throws Exception {
-    if (getRegionScope().isDistributedNoAck())
+    if (getRegionScope().isDistributedNoAck()) {
       return; // skip test under DistributedNoAck
+    }
 
     final String name = this.getUniqueName();
     final String roleA = name + "-A";
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache30/SlowRecDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache30/SlowRecDUnitTest.java
index e07b28d..04ff3d9 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache30/SlowRecDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache30/SlowRecDUnitTest.java
@@ -1065,8 +1065,9 @@ public class SlowRecDUnitTest extends JUnit4CacheTestCase {
     Object putKey = key1;
     boolean flag = true;
     for (int i = 0; i < 30; i++) {
-      if (i == 10)
+      if (i == 10) {
         putKey = key2;
+      }
       if (flag) {
         if (i == 6) {
           r1.invalidate(putKey, new Integer(i));
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/cache30/TXDistributedDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/cache30/TXDistributedDUnitTest.java
index afe88f1..1691127 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/cache30/TXDistributedDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/cache30/TXDistributedDUnitTest.java
@@ -1513,8 +1513,9 @@ public class TXDistributedDUnitTest extends JUnit4CacheTestCase {
                 + "|" + CommitReplyException.class.getName());
         origin.invoke(doTransaction);
       } finally {
-        if (ee != null)
+        if (ee != null) {
           ee.remove();
+        }
       }
 
       SerializableCallable allowCacheToShutdown = new SerializableCallable() {
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/distributed/DistributedLockBlackboardImpl.java b/geode-core/src/distributedTest/java/org/apache/geode/distributed/DistributedLockBlackboardImpl.java
index 599c28e..576eab0 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/distributed/DistributedLockBlackboardImpl.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/distributed/DistributedLockBlackboardImpl.java
@@ -41,8 +41,9 @@ public class DistributedLockBlackboardImpl extends UnicastRemoteObject
    * Creates a singleton event listeners blackboard.
    */
   public static DistributedLockBlackboard getInstance() throws Exception {
-    if (blackboard == null)
+    if (blackboard == null) {
       initialize();
+    }
     return blackboard;
   }
 
@@ -81,11 +82,13 @@ public class DistributedLockBlackboardImpl extends UnicastRemoteObject
   @Override
   public synchronized void setIsLocked(boolean isLocked) {
     if (isLocked) {
-      if (IsLocked < 1)
+      if (IsLocked < 1) {
         IsLocked = 1;
+      }
     } else {
-      if (IsLocked > 0)
+      if (IsLocked > 0) {
         IsLocked = 0;
+      }
     }
   }
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/distributed/DistributedLockServiceDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/distributed/DistributedLockServiceDUnitTest.java
index 3d39ea0..a4245a8 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/distributed/DistributedLockServiceDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/distributed/DistributedLockServiceDUnitTest.java
@@ -1101,8 +1101,9 @@ public final class DistributedLockServiceDUnitTest extends JUnit4DistributedTest
     thread2.start();
 
     // Interrupt second thread
-    while (!started)
+    while (!started) {
       Thread.yield();
+    }
     thread2.interrupt();
     ThreadUtils.join(thread2, 20 * 1000);
 
@@ -1169,8 +1170,9 @@ public final class DistributedLockServiceDUnitTest extends JUnit4DistributedTest
     if (logger.isDebugEnabled()) {
       logger.debug("[testLockIsNotInterruptible] interrupt second thread");
     }
-    while (!started)
+    while (!started) {
       Thread.yield();
+    }
     Thread.sleep(500);
     thread2.interrupt();
     // Expect it didn't get an exception and didn't lock the service
@@ -1573,8 +1575,9 @@ public final class DistributedLockServiceDUnitTest extends JUnit4DistributedTest
     thread2.start();
 
     // Interrupt second thread
-    while (!started)
+    while (!started) {
       Thread.yield();
+    }
     thread2.interrupt();
     ThreadUtils.join(thread2, 20 * 1000);
 
@@ -1624,8 +1627,9 @@ public final class DistributedLockServiceDUnitTest extends JUnit4DistributedTest
     thread2.start();
 
     // Interrupt second thread
-    while (!started)
+    while (!started) {
       Thread.yield();
+    }
     thread2.interrupt();
     // Expect it didn't get an exception and didn't lock the service
     Thread.sleep(500);
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/disttx/DistTXDebugDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/disttx/DistTXDebugDUnitTest.java
index de44527..ce2090f 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/disttx/DistTXDebugDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/disttx/DistTXDebugDUnitTest.java
@@ -954,11 +954,13 @@ public class DistTXDebugDUnitTest extends JUnit4CacheTestCase {
 
     @Override
     public boolean equals(Object o) {
-      if (this == o)
+      if (this == o) {
         return true;
+      }
 
-      if (!(o instanceof DummyKeyBasedRoutingResolver))
+      if (!(o instanceof DummyKeyBasedRoutingResolver)) {
         return false;
+      }
 
       DummyKeyBasedRoutingResolver otherDummyID = (DummyKeyBasedRoutingResolver) o;
       return (otherDummyID.dummyID.equals(dummyID));
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ClientServerGetAllDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ClientServerGetAllDUnitTest.java
index c007a22..1a259b2 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ClientServerGetAllDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ClientServerGetAllDUnitTest.java
@@ -112,10 +112,11 @@ public class ClientServerGetAllDUnitTest extends ClientServerTestCase {
           String key = (String) i.next();
           assertTrue(result.containsKey(key));
           Object value = result.get(key);
-          if (!key.equals(ClientServerTestCase.NON_EXISTENT_KEY))
+          if (!key.equals(ClientServerTestCase.NON_EXISTENT_KEY)) {
             assertEquals(key, value);
-          else
+          } else {
             assertEquals(null, value);
+          }
         }
 
         assertEquals(null, region.get(ClientServerTestCase.NON_EXISTENT_KEY));
@@ -164,10 +165,11 @@ public class ClientServerGetAllDUnitTest extends ClientServerTestCase {
           String key = (String) i.next();
           assertTrue(result.containsKey(key));
           Object value = result.get(key);
-          if (!key.equals(ClientServerTestCase.NON_EXISTENT_KEY))
+          if (!key.equals(ClientServerTestCase.NON_EXISTENT_KEY)) {
             assertEquals(key, value);
-          else
+          } else {
             assertEquals(null, value);
+          }
         }
 
         assertEquals(null, region.get(ClientServerTestCase.NON_EXISTENT_KEY));
@@ -462,10 +464,11 @@ public class ClientServerGetAllDUnitTest extends ClientServerTestCase {
           String key = (String) i.next();
           assertTrue(result.containsKey(key));
           Object value = result.get(key);
-          if (!key.equals(ClientServerTestCase.NON_EXISTENT_KEY))
+          if (!key.equals(ClientServerTestCase.NON_EXISTENT_KEY)) {
             assertEquals(key, value);
-          else
+          } else {
             assertEquals(null, value);
+          }
         }
 
         assertEquals(null, region.get(ClientServerTestCase.NON_EXISTENT_KEY));
@@ -540,10 +543,11 @@ public class ClientServerGetAllDUnitTest extends ClientServerTestCase {
           String key = (String) i.next();
           assertTrue(result.containsKey(key));
           Object value = result.get(key);
-          if (!key.equals(ClientServerTestCase.NON_EXISTENT_KEY))
+          if (!key.equals(ClientServerTestCase.NON_EXISTENT_KEY)) {
             assertEquals(key, value);
-          else
+          } else {
             assertEquals(null, value);
+          }
         }
         assertEquals(null, region.get(ClientServerTestCase.NON_EXISTENT_KEY));
       }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ClientServerTransactionDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ClientServerTransactionDUnitTest.java
index 5f46a56..3dfc829 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ClientServerTransactionDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ClientServerTransactionDUnitTest.java
@@ -2037,10 +2037,12 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
             "true");
         ClientCacheFactory ccf = new ClientCacheFactory();
         ccf.addPoolServer("localhost"/* getServerHostName(Host.getHost(0)) */, port1);
-        if (port2 != 0)
+        if (port2 != 0) {
           ccf.addPoolServer("localhost", port2);
-        if (port3 != 0)
+        }
+        if (port3 != 0) {
           ccf.addPoolServer("localhost", port3);
+        }
         ccf.setPoolSubscriptionEnabled(false);
         ccf.set(LOG_LEVEL, getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
@@ -2239,8 +2241,9 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
         int i = 0;
         while (it.hasNext()) {
           EntryEvent ev = (EntryEvent) it.next();
-          if (i == 0)
+          if (i == 0) {
             assertNull(ev.getNewValue());
+          }
           if (i > 1) {
             assertEquals(new CustId(i), ev.getKey());
             assertEquals(new Customer("name" + i, "address" + i), ev.getNewValue());
@@ -2265,8 +2268,9 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
         int i = 0;
         while (it.hasNext()) {
           EntryEvent ev = (EntryEvent) it.next();
-          if (i == 0)
+          if (i == 0) {
             assertNull(ev.getNewValue());
+          }
           if (i > 1) {
             assertEquals(new CustId(i), ev.getKey());
             assertEquals(new Customer("name" + i, "address" + i), ev.getNewValue());
@@ -3712,8 +3716,9 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
             "true");
         ClientCacheFactory ccf = new ClientCacheFactory();
         ccf.addPoolServer("localhost"/* getServerHostName(Host.getHost(0)) */, port1);
-        if (port2 != 0)
+        if (port2 != 0) {
           ccf.addPoolServer("localhost", port2);
+        }
         ccf.setPoolSubscriptionEnabled(false);
         ccf.set(LOG_LEVEL, getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ConcurrentMapOpsDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ConcurrentMapOpsDUnitTest.java
index c2ef40a..149496b 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ConcurrentMapOpsDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ConcurrentMapOpsDUnitTest.java
@@ -1456,8 +1456,9 @@ public class ConcurrentMapOpsDUnitTest extends JUnit4CacheTestCase {
 
     @Override
     public boolean equals(Object obj) {
-      if (!(obj instanceof CustomerDelta))
+      if (!(obj instanceof CustomerDelta)) {
         return false;
+      }
       CustomerDelta other = (CustomerDelta) obj;
       return this.name.equals(other.name) && this.address.equals(other.address);
     }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/PartitionedRegionCacheLoaderForRootRegion.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/PartitionedRegionCacheLoaderForRootRegion.java
index 0fb55c7..f0a2eb8 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/PartitionedRegionCacheLoaderForRootRegion.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/PartitionedRegionCacheLoaderForRootRegion.java
@@ -34,8 +34,9 @@ public class PartitionedRegionCacheLoaderForRootRegion implements CacheLoader, D
 
     /* checking the attributes set in xml file. */
     PartitionedRegion pr = (PartitionedRegion) helper.getRegion();
-    if (pr.getAttributes().getPartitionAttributes().getRedundantCopies() != 1)
+    if (pr.getAttributes().getPartitionAttributes().getRedundantCopies() != 1) {
       fail("Redundancy of the partition region is not 1");
+    }
 
     assertEquals(pr.getAttributes().getPartitionAttributes().getLocalMaxMemory(), 200);
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/PartitionedRegionCacheLoaderForSubRegion.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/PartitionedRegionCacheLoaderForSubRegion.java
index 9ad44a3..2523c5c 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/PartitionedRegionCacheLoaderForSubRegion.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/PartitionedRegionCacheLoaderForSubRegion.java
@@ -35,8 +35,9 @@ public class PartitionedRegionCacheLoaderForSubRegion implements CacheLoader, De
 
     /* checking the attributes set in xml file */
     PartitionedRegion pr = (PartitionedRegion) helper.getRegion();
-    if (pr.getAttributes().getPartitionAttributes().getRedundantCopies() != 1)
+    if (pr.getAttributes().getPartitionAttributes().getRedundantCopies() != 1) {
       fail("Redundancy of the partition region is not 1");
+    }
 
     assertEquals(pr.getAttributes().getPartitionAttributes().getGlobalProperties()
         .getProperty(PartitionAttributesFactory.GLOBAL_MAX_BUCKETS_PROPERTY), "11");
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/RemoteTransactionDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/RemoteTransactionDUnitTest.java
index 74bda5d..1a090d5 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/RemoteTransactionDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/RemoteTransactionDUnitTest.java
@@ -4350,8 +4350,9 @@ public class RemoteTransactionDUnitTest extends JUnit4CacheTestCase {
             TXEntryState es = rs.readEntry(key);
             assertEquals("txkey", key);
             assertNotNull(es.getValue(key, r, false));
-            if (key.equals("txkey"))
+            if (key.equals("txkey")) {
               assertTrue(es.isDirty());
+            }
           }
         }
         return null;
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/RemoveGlobalDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/RemoveGlobalDUnitTest.java
index 38f0821..4554e25 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/RemoveGlobalDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/RemoveGlobalDUnitTest.java
@@ -155,8 +155,9 @@ public class RemoveGlobalDUnitTest extends JUnit4DistributedTestCase { // TODO:
     });
 
     ThreadUtils.join(async, 30 * 1000);
-    if (async.exceptionOccurred())
+    if (async.exceptionOccurred()) {
       throw async.getException();
+    }
 
   }// end of testRemoveGlobalSingleVM
 
@@ -241,8 +242,9 @@ public class RemoveGlobalDUnitTest extends JUnit4DistributedTestCase { // TODO:
     });
 
     ThreadUtils.join(async, 30 * 1000);
-    if (async.exceptionOccurred())
+    if (async.exceptionOccurred()) {
       throw async.getException();
+    }
 
   }// end of testRemoveGlobalMultiVM
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/SizingFlagDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/SizingFlagDUnitTest.java
index d331abf..bc74d7f 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/SizingFlagDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/SizingFlagDUnitTest.java
@@ -977,18 +977,23 @@ public class SizingFlagDUnitTest extends JUnit4CacheTestCase {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (!(obj instanceof TestKey))
+      }
+      if (!(obj instanceof TestKey)) {
         return false;
+      }
       TestKey other = (TestKey) obj;
       if (value == null) {
-        if (other.value != null)
+        if (other.value != null) {
           return false;
-      } else if (!value.equals(other.value))
+        }
+      } else if (!value.equals(other.value)) {
         return false;
+      }
       return true;
     }
 
@@ -1036,17 +1041,22 @@ public class SizingFlagDUnitTest extends JUnit4CacheTestCase {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (!(obj instanceof TestObject))
+      }
+      if (!(obj instanceof TestObject)) {
         return false;
+      }
       TestObject other = (TestObject) obj;
-      if (sizeForSerialization != other.sizeForSerialization)
+      if (sizeForSerialization != other.sizeForSerialization) {
         return false;
-      if (sizeForSizer != other.sizeForSizer)
+      }
+      if (sizeForSizer != other.sizeForSizer) {
         return false;
+      }
       return true;
     }
 
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/TransactionsWithDeltaDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/TransactionsWithDeltaDUnitTest.java
index 8ab7fad..9fdcef3 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/TransactionsWithDeltaDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/TransactionsWithDeltaDUnitTest.java
@@ -200,8 +200,9 @@ public class TransactionsWithDeltaDUnitTest extends JUnit4CacheTestCase {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
+      }
       if (obj instanceof Customer) {
         Customer other = (Customer) obj;
         return this.id == other.id && this.name.equals(other.name);
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/ColocationFailoverDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/ColocationFailoverDUnitTest.java
index 702308d..2704f04 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/ColocationFailoverDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/ColocationFailoverDUnitTest.java
@@ -492,10 +492,12 @@ class KeyPartitionResolver implements PartitionResolver {
   public void close() {}
 
   public boolean equals(Object o) {
-    if (this == o)
+    if (this == o) {
       return true;
-    if (!(o instanceof KeyPartitionResolver))
+    }
+    if (!(o instanceof KeyPartitionResolver)) {
       return false;
+    }
     KeyPartitionResolver otherKeyPartitionResolver = (KeyPartitionResolver) o;
     return otherKeyPartitionResolver.getName().equals(getName());
   }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/LocalDataSetDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/LocalDataSetDUnitTest.java
index a8420b9..e066004 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/LocalDataSetDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/LocalDataSetDUnitTest.java
@@ -369,10 +369,12 @@ class LDSPartitionResolver implements PartitionResolver {
   public void close() {}
 
   public boolean equals(Object o) {
-    if (this == o)
+    if (this == o) {
       return true;
-    if (!(o instanceof LDSPartitionResolver))
+    }
+    if (!(o instanceof LDSPartitionResolver)) {
       return false;
+    }
     LDSPartitionResolver otherKeyPartitionResolver = (LDSPartitionResolver) o;
     return otherKeyPartitionResolver.getName().equals(getName());
   }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/PRClientServerFunctionExecutionNoAckDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/PRClientServerFunctionExecutionNoAckDUnitTest.java
index daf376c..cf18fa1 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/PRClientServerFunctionExecutionNoAckDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/PRClientServerFunctionExecutionNoAckDUnitTest.java
@@ -120,8 +120,9 @@ public class PRClientServerFunctionExecutionNoAckDUnitTest extends PRClientServe
     try {
       TimeKeeper t = new TimeKeeper();
       t.start();
-      for (int i = 0; i < NUM_ITERATION; i++)
+      for (int i = 0; i < NUM_ITERATION; i++) {
         execute(member, Boolean.TRUE, functionNoAck, isByName, toRegister);
+      }
       t.stop();
       logger.info("Time taken to execute boolean based" + NUM_ITERATION
           + "NoAck functions :" + t.getTimeInMs());
@@ -138,8 +139,9 @@ public class PRClientServerFunctionExecutionNoAckDUnitTest extends PRClientServe
       }
       TimeKeeper t = new TimeKeeper();
       t.start();
-      for (int i = 0; i < NUM_ITERATION; i++)
+      for (int i = 0; i < NUM_ITERATION; i++) {
         execute(member, testKeysSet, functionNoAck, isByName, toRegister);
+      }
       t.stop();
       logger.info(
           "Time taken to execute setbased" + NUM_ITERATION + "NoAck functions :" + t.getTimeInMs());
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/PRColocationDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/PRColocationDUnitTest.java
index 0ffb996..0cadc4a 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/PRColocationDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/PRColocationDUnitTest.java
@@ -2027,8 +2027,9 @@ public class PRColocationDUnitTest extends JUnit4CacheTestCase {
             break;
           }
         }
-        if (isSecondary)
+        if (isSecondary) {
           secondaryBucketListForCustomer.add(me.getKey());
+        }
       }
       Iterator primaryBucketIterator = primaryBucketListForCustomer.iterator();
       while (primaryBucketIterator.hasNext()) {
@@ -2069,8 +2070,9 @@ public class PRColocationDUnitTest extends JUnit4CacheTestCase {
             break;
           }
         }
-        if (isSecondary)
+        if (isSecondary) {
           secondaryBucketListForOrder.add(me.getKey());
+        }
       }
       Iterator primaryBucketIterator = primaryBucketListForOrder.iterator();
       while (primaryBucketIterator.hasNext()) {
@@ -2112,8 +2114,9 @@ public class PRColocationDUnitTest extends JUnit4CacheTestCase {
             break;
           }
         }
-        if (isSecondary)
+        if (isSecondary) {
           secondaryBucketListForShipment.add(me.getKey());
+        }
       }
       Iterator primaryBucketIterator = primaryBucketListForShipment.iterator();
       while (primaryBucketIterator.hasNext()) {
@@ -2356,10 +2359,11 @@ public class PRColocationDUnitTest extends JUnit4CacheTestCase {
     assertNotNull(partitionedregion);
     boolean exceptionThrown = false;
     try {
-      if (destroy)
+      if (destroy) {
         partitionedregion.destroyRegion();
-      else
+      } else {
         partitionedregion.close();
+      }
     } catch (IllegalStateException e) {
       exceptionThrown = true;
     }
@@ -2642,11 +2646,13 @@ public class PRColocationDUnitTest extends JUnit4CacheTestCase {
 
     @Override
     public boolean equals(Object o) {
-      if (this == o)
+      if (this == o) {
         return true;
+      }
 
-      if (!(o instanceof DummyKeyBasedRoutingResolver))
+      if (!(o instanceof DummyKeyBasedRoutingResolver)) {
         return false;
+      }
 
       DummyKeyBasedRoutingResolver otherDummyID = (DummyKeyBasedRoutingResolver) o;
       return (otherDummyID.dummyID.equals(dummyID));
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/TimeKeeper.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/TimeKeeper.java
index a3e69e0..dce1169 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/TimeKeeper.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/TimeKeeper.java
@@ -35,7 +35,8 @@ class TimeKeeper {
       return -1;
     } else if (endTime == startTime) {
       return 1;
-    } else
+    } else {
       return endTime - startTime;
+    }
   }
 }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HAClearDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HAClearDUnitTest.java
index c413760..b8d20e5 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HAClearDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HAClearDUnitTest.java
@@ -147,8 +147,9 @@ public class HAClearDUnitTest extends JUnit4DistributedTestCase {
           }
         }
 
-        if (!gotClearCallback)
+        if (!gotClearCallback) {
           fail("test failed");
+        }
         gotClearCallback = false;
       }
     });
@@ -167,8 +168,9 @@ public class HAClearDUnitTest extends JUnit4DistributedTestCase {
           }
         }
 
-        if (!gotClearCallback)
+        if (!gotClearCallback) {
           fail("test failed");
+        }
         gotClearCallback = false;
       }
     });
@@ -213,8 +215,9 @@ public class HAClearDUnitTest extends JUnit4DistributedTestCase {
           }
         }
 
-        if (!gotClearCallback)
+        if (!gotClearCallback) {
           fail("test failed");
+        }
         gotClearCallback = false;
       }
     });
@@ -233,8 +236,9 @@ public class HAClearDUnitTest extends JUnit4DistributedTestCase {
           }
         }
 
-        if (!gotClearCallback)
+        if (!gotClearCallback) {
           fail("test failed");
+        }
         gotClearCallback = false;
       }
     });
@@ -301,8 +305,9 @@ public class HAClearDUnitTest extends JUnit4DistributedTestCase {
           }
         }
 
-        if (!gotDestroyRegionCallback)
+        if (!gotDestroyRegionCallback) {
           fail("test failed");
+        }
         gotDestroyRegionCallback = false;
       }
     });
@@ -321,8 +326,9 @@ public class HAClearDUnitTest extends JUnit4DistributedTestCase {
           }
         }
 
-        if (!gotDestroyRegionCallback)
+        if (!gotDestroyRegionCallback) {
           fail("test failed");
+        }
         gotDestroyRegionCallback = false;
       }
     });
@@ -369,8 +375,9 @@ public class HAClearDUnitTest extends JUnit4DistributedTestCase {
           }
         }
 
-        if (!gotDestroyRegionCallback)
+        if (!gotDestroyRegionCallback) {
           fail("test failed");
+        }
         gotDestroyRegionCallback = false;
       }
     });
@@ -388,8 +395,9 @@ public class HAClearDUnitTest extends JUnit4DistributedTestCase {
           }
         }
 
-        if (!gotDestroyRegionCallback)
+        if (!gotDestroyRegionCallback) {
           fail("test failed");
+        }
         gotDestroyRegionCallback = false;
       }
     });
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HADuplicateDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HADuplicateDUnitTest.java
index 60137e2..a69f329 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HADuplicateDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HADuplicateDUnitTest.java
@@ -130,8 +130,9 @@ public class HADuplicateDUnitTest extends JUnit4DistributedTestCase {
           }
         }
 
-        if (waitFlag)
+        if (waitFlag) {
           fail("test failed");
+        }
       }
     });
 
@@ -139,8 +140,9 @@ public class HADuplicateDUnitTest extends JUnit4DistributedTestCase {
     client1.invoke(new CacheSerializableRunnable("validateDuplicates") {
       @Override
       public void run2() throws CacheException {
-        if (!isEventDuplicate)
+        if (!isEventDuplicate) {
           fail(" Not all duplicates received");
+        }
 
       }
     });
@@ -287,8 +289,9 @@ public class HADuplicateDUnitTest extends JUnit4DistributedTestCase {
     @Override
     public void afterUpdate(EntryEvent event) {
       Object value = storeEvents.get(event.getKey());
-      if (value == null)
+      if (value == null) {
         isEventDuplicate = false;
+      }
       synchronized (dummyObj) {
         try {
           put_counter++;
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HAGIIBugDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HAGIIBugDUnitTest.java
index d6b6001..358c88d 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HAGIIBugDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HAGIIBugDUnitTest.java
@@ -185,8 +185,9 @@ public class HAGIIBugDUnitTest extends JUnit4DistributedTestCase {
     async[0] = vm0.invokeAsync(putFrmVm("vm0_2"));
     t1.start();
     ThreadUtils.join(t1, 30 * 1000);
-    if (isTestFailed)
+    if (isTestFailed) {
       fail("HARegionQueue can not be created");
+    }
 
     for (int count = 0; count < 1; count++) {
       ThreadUtils.join(async[count], 30 * 1000);
@@ -200,16 +201,18 @@ public class HAGIIBugDUnitTest extends JUnit4DistributedTestCase {
 
     boolean validationFlag = false;
     validateResults(validationFlag);
-    if (keys_set_before_gii.size() != 0)
+    if (keys_set_before_gii.size() != 0) {
       fail("Data in the HARegion Queue is inconsistent for the keys that are put before GII");
+    }
 
     validationFlag = true;
     validateResults(validationFlag);
     LogWriterUtils.getLogWriter().info(
         "No. of keys that are missed by HARegion Queue during GII " + keys_set_after_gii.size());
 
-    if (keys_set_after_gii.size() != 0)
+    if (keys_set_after_gii.size() != 0) {
       fail("Set of the keys are missed by HARegion Queue during GII");
+    }
 
   }
 
@@ -294,8 +297,9 @@ public class HAGIIBugDUnitTest extends JUnit4DistributedTestCase {
         Region region = cache.getRegion(Region.SEPARATOR + REGION_NAME);
         int j = 0;
         while (true) {
-          if (isStop)
+          if (isStop) {
             break;
+          }
           for (int i = 0; i < NO_OF_PUTS; i++) {
             region.put(whichVm + j, whichVm + j);
             j++;
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HARegionQueueDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HARegionQueueDUnitTest.java
index c552952..a0e426c 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HARegionQueueDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/ha/HARegionQueueDUnitTest.java
@@ -904,8 +904,9 @@ public class HARegionQueueDUnitTest extends JUnit4DistributedTestCase {
           switch (opType) {
             case PUT:
               rgn.put("key" + threadID, "val" + counter++);
-              if (counter == 10)
+              if (counter == 10) {
                 counter = 0;
+              }
               break;
             case TAKE:
               cnf = (Conflatable) hrq.take();
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/partitioned/PartitionResolverDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/partitioned/PartitionResolverDUnitTest.java
index 06e1c22..5a6191f 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/partitioned/PartitionResolverDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/partitioned/PartitionResolverDUnitTest.java
@@ -408,47 +408,61 @@ public class PartitionResolverDUnitTest extends JUnit4CacheTestCase {
         CustId custId = new CustId(6);
         Customer customer = new Customer("customer6", "address6");
         getGemfireCache().getLogger().fine("SWAP:Begin");
-        if (isTx)
+        if (isTx) {
           mgr.begin();
+        }
         custRegion.put(custId, customer);
-        if (isTx)
+        if (isTx) {
           mgr.commit();
+        }
 
-        if (isTx)
+        if (isTx) {
           mgr.begin();
+        }
         custRegion.invalidate(custId);
-        if (isTx)
+        if (isTx) {
           mgr.commit();
+        }
 
-        if (isTx)
+        if (isTx) {
           mgr.begin();
+        }
         custRegion.put(custId, customer);
-        if (isTx)
+        if (isTx) {
           mgr.commit();
+        }
 
-        if (isTx)
+        if (isTx) {
           mgr.begin();
+        }
         custRegion.destroy(custId);
-        if (isTx)
+        if (isTx) {
           mgr.commit();
+        }
 
-        if (isTx)
+        if (isTx) {
           mgr.begin();
+        }
         custRegion.put(custId, customer);
-        if (isTx)
+        if (isTx) {
           mgr.commit();
+        }
 
-        if (isTx)
+        if (isTx) {
           mgr.begin();
+        }
         custRegion.containsKey(custId);
-        if (isTx)
+        if (isTx) {
           mgr.commit();
+        }
 
-        if (isTx)
+        if (isTx) {
           mgr.begin();
+        }
         custRegion.containsValueForKey(custId);
-        if (isTx)
+        if (isTx) {
           mgr.commit();
+        }
         return null;
       }
     });
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
index 6bd83f8..072a422 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
@@ -125,12 +125,14 @@ public class EventIDVerificationInP2PDUnitTest extends JUnit4DistributedTestCase
   public static void createServerCache(Integer type) throws Exception {
     new EventIDVerificationInP2PDUnitTest().createCache(new Properties());
     AttributesFactory factory = new AttributesFactory();
-    if (type.intValue() == DISTRIBUTED_ACK)
+    if (type.intValue() == DISTRIBUTED_ACK) {
       factory.setScope(Scope.DISTRIBUTED_ACK);
-    if (type.intValue() == GLOBAL)
+    }
+    if (type.intValue() == GLOBAL) {
       factory.setScope(Scope.GLOBAL);
-    else
+    } else {
       factory.setScope(Scope.DISTRIBUTED_NO_ACK);
+    }
 
     factory.setDataPolicy(DataPolicy.REPLICATE);
     factory.addCacheListener(new CacheListenerAdapter() {
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/HAInterestTestCase.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/HAInterestTestCase.java
index 6623ad1..f215a43 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/HAInterestTestCase.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/HAInterestTestCase.java
@@ -257,8 +257,9 @@ public class HAInterestTestCase extends JUnit4DistributedTestCase {
       @Override
       public boolean done() {
         Entry re = r1.getEntry(k1);
-        if (re == null)
+        if (re == null) {
           return false;
+        }
         Object val = re.getValue();
         return client_k1.equals(val);
       }
@@ -274,8 +275,9 @@ public class HAInterestTestCase extends JUnit4DistributedTestCase {
       @Override
       public boolean done() {
         Entry re = r1.getEntry(k2);
-        if (re == null)
+        if (re == null) {
           return false;
+        }
         Object val = re.getValue();
         return client_k2.equals(val);
       }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
index b3616cf..bdb4644 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
@@ -429,17 +429,21 @@ public class InterestListEndpointDUnitTest extends JUnit4DistributedTestCase {
         @Override
         public boolean done() {
           Entry e1 = r.getEntry(k1);
-          if (e1 == null)
+          if (e1 == null) {
             return false;
+          }
           Entry e2 = r.getEntry(k2);
-          if (e2 == null)
+          if (e2 == null) {
             return false;
+          }
           Object v1 = e1.getValue();
-          if (!server_k1.equals(v1))
+          if (!server_k1.equals(v1)) {
             return false;
+          }
           Object v2 = e2.getValue();
-          if (!client_k2.equals(v2))
+          if (!client_k2.equals(v2)) {
             return false;
+          }
           // our state is ready for the assertions
           return true;
         }
@@ -447,11 +451,13 @@ public class InterestListEndpointDUnitTest extends JUnit4DistributedTestCase {
         @Override
         public String description() {
           Entry e1 = r.getEntry(k1);
-          if (e1 == null)
+          if (e1 == null) {
             return "Entry for " + k1 + " is null";
+          }
           Entry e2 = r.getEntry(k2);
-          if (e2 == null)
+          if (e2 == null) {
             return "Entry for " + k2 + " is null";
+          }
           Object v1 = e1.getValue();
           if (!server_k1.equals(v1)) {
             return "v1 supposed to be " + server_k1 + " but is " + v1;
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/InterestRegrListenerDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/InterestRegrListenerDUnitTest.java
index b05e1b0..3519c99 100644
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/InterestRegrListenerDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/InterestRegrListenerDUnitTest.java
@@ -155,8 +155,9 @@ public class InterestRegrListenerDUnitTest extends JUnit4DistributedTestCase {
       public void afterUnregisterInterest(InterestRegistrationEvent event) {
         Integer count = InterestRegrListenerDUnitTest.this.listnerMap.get(UNREGISTER_INTEREST);
         int intCount = 0;
-        if (count != null)
+        if (count != null) {
           intCount = count.intValue();
+        }
         intCount++;
         InterestRegrListenerDUnitTest.this.listnerMap.put(UNREGISTER_INTEREST, intCount);
         LogWriterUtils.getLogWriter()
@@ -169,8 +170,9 @@ public class InterestRegrListenerDUnitTest extends JUnit4DistributedTestCase {
       public void afterRegisterInterest(InterestRegistrationEvent event) {
         Integer count = InterestRegrListenerDUnitTest.this.listnerMap.get(REGISTER_INTEREST);
         int intCount = 0;
-        if (count != null)
+        if (count != null) {
           intCount = count.intValue();
+        }
         intCount++;
         InterestRegrListenerDUnitTest.this.listnerMap.put(REGISTER_INTEREST, intCount);
         LogWriterUtils.getLogWriter()
@@ -490,10 +492,11 @@ public class InterestRegrListenerDUnitTest extends JUnit4DistributedTestCase {
   }
 
   private int getMapValueForKey(Map<String, Integer> map, String key) {
-    if (map.containsKey(key))
+    if (map.containsKey(key)) {
       return map.get(key).intValue();
-    else
+    } else {
       return 0;
+    }
   }
 
 }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/NewRegionAttributesDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/NewRegionAttributesDUnitTest.java
index 13b03f1..499c38a 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/NewRegionAttributesDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/cache/tier/sockets/NewRegionAttributesDUnitTest.java
@@ -281,8 +281,9 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException expected) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail("UnsupportedOperationException was not thrown as expected for registerInterest(key)");
+      }
     }
 
     // test registerInterest(key,policy)
@@ -292,9 +293,10 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException expected) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail(
             "UnsupportedOperationException was not thrown as expected for  registerInterest(key,policy)");
+      }
     }
 
     // test registerInterest(keylist)
@@ -304,9 +306,10 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException expected) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail(
             "UnsupportedOperationException was not thrown as expected for registerInterest(keylist)");
+      }
     }
 
     // test registerInterest(keylist,policy)
@@ -316,9 +319,10 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException expected) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail(
             "UnsupportedOperationException was not thrown as expected for registerInterest(keylist,policy)");
+      }
     }
 
     // test registerInterestRegex(expr)
@@ -328,9 +332,10 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException expected) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail(
             "UnsupportedOperationException was not thrown as expected for registerInterestRegex(expr)");
+      }
     }
 
     // test registerInterestRegex(expr,policy)
@@ -340,9 +345,10 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException expected) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail(
             "UnsupportedOperationException was not thrown as expected for registerInterestRegex(expr,policy)");
+      }
     }
   }
 
@@ -369,9 +375,10 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException expected) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail(
             "UnsupportedOperationException was not thrown as expected for unregisterInterest(key)");
+      }
     }
 
     // test unregisterInterest(keylist)
@@ -381,9 +388,10 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException expected) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail(
             "UnsupportedOperationException was not thrown as expected for unregisterInterest(keylist)");
+      }
     }
 
     // test unregisterInterestRegex(expr)
@@ -393,9 +401,10 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException expected) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail(
             "UnsupportedOperationException was not thrown as expected for unregisterInterestRegex(expr)");
+      }
     }
   }
 
@@ -417,8 +426,9 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException e) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail("UnsupportedOperationException was not thrown as expected for getInterestList()");
+      }
     }
 
     // test getInterestListRegex()
@@ -429,8 +439,9 @@ public class NewRegionAttributesDUnitTest extends JUnit4DistributedTestCase {
     } catch (UnsupportedOperationException e) {
       exceptionOccurred = true;
     } finally {
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail("UnsupportedOperationException was not thrown as expected for getInterestListRegex()");
+      }
     }
   }
 }
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/dunit/TransactionTimeOutDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/dunit/TransactionTimeOutDUnitTest.java
index ebcbe4f..ccb537b 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/dunit/TransactionTimeOutDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/dunit/TransactionTimeOutDUnitTest.java
@@ -81,8 +81,9 @@ public class TransactionTimeOutDUnitTest extends JUnit4DistributedTestCase {
     props.setProperty(CACHE_XML_FILE, path);
 
     ds = (new TransactionTimeOutDUnitTest()).getSystem(props);
-    if (cache == null || cache.isClosed())
+    if (cache == null || cache.isClosed()) {
       cache = CacheFactory.create(ds);
+    }
   }
 
   private void closeCache() {
@@ -90,8 +91,9 @@ public class TransactionTimeOutDUnitTest extends JUnit4DistributedTestCase {
       if (cache != null && !cache.isClosed()) {
         cache.close();
       }
-      if (ds != null && ds.isConnected())
+      if (ds != null && ds.isConnected()) {
         ds.disconnect();
+      }
     } catch (Exception e) {
       fail("Exception in closing cache and disconnecting ds due to ", e);
     }
@@ -191,8 +193,9 @@ public class TransactionTimeOutDUnitTest extends JUnit4DistributedTestCase {
       } catch (Exception e) {
         exceptionOccurred = true;
       }
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail("Exception did not occur although was supposed to occur");
+      }
     } catch (Exception e) {
       fail("failed in naming lookup: ", e);
     }
@@ -302,8 +305,9 @@ public class TransactionTimeOutDUnitTest extends JUnit4DistributedTestCase {
       utx.commit();
       sql = "select * from newTable1 where id = 1";
       ResultSet rs = sm.executeQuery(sql);
-      if (!rs.next())
+      if (!rs.next()) {
         fail("Transaction not committed");
+      }
       sql = "drop table newTable1";
       sm.execute(sql);
       sm.close();
@@ -332,8 +336,9 @@ public class TransactionTimeOutDUnitTest extends JUnit4DistributedTestCase {
       sm.execute(sql);
       sql = "select * from newTable2 where id = 1";
       ResultSet rs = sm.executeQuery(sql);
-      if (!rs.next())
+      if (!rs.next()) {
         fail("Database not updated");
+      }
       sm.close();
       conn.close();
       assertThat(utx.getStatus() == Status.STATUS_ACTIVE);
@@ -385,8 +390,9 @@ public class TransactionTimeOutDUnitTest extends JUnit4DistributedTestCase {
       sm.execute(sql);
       sql = "select * from newTable3 where id = 1";
       ResultSet rs = sm.executeQuery(sql);
-      if (!rs.next())
+      if (!rs.next()) {
         fail("Transaction not committed");
+      }
       sql = "drop table newTable3";
       sm.execute(sql);
       sm.close();
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/dunit/TxnTimeOutDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/dunit/TxnTimeOutDUnitTest.java
index cd0cad7..ba389f4 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/dunit/TxnTimeOutDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/dunit/TxnTimeOutDUnitTest.java
@@ -77,8 +77,9 @@ public class TxnTimeOutDUnitTest extends JUnit4DistributedTestCase {
     props.setProperty(CACHE_XML_FILE, path);
     props.setProperty(LOG_LEVEL, LogWriterUtils.getDUnitLogLevel());
     ds = (new TxnTimeOutDUnitTest()).getSystem(props);
-    if (cache == null || cache.isClosed())
+    if (cache == null || cache.isClosed()) {
       cache = CacheFactory.create(ds);
+    }
   }
 
   public static Cache getCache() {
@@ -100,8 +101,9 @@ public class TxnTimeOutDUnitTest extends JUnit4DistributedTestCase {
       if (cache != null && !cache.isClosed()) {
         cache.close();
       }
-      if (ds != null && ds.isConnected())
+      if (ds != null && ds.isConnected()) {
         ds.disconnect();
+      }
 
     } catch (Exception e) {
       fail("Exception in closing cache or ds due to " + e);
@@ -216,8 +218,9 @@ public class TxnTimeOutDUnitTest extends JUnit4DistributedTestCase {
       } catch (Exception e) {
         exceptionOccurred = true;
       }
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail("Exception did not occur although was supposed to occur");
+      }
     } catch (Exception e) {
       LogWriterUtils.getLogWriter().fine("Exception caught " + e);
       fail("failed in naming lookup: " + e);
@@ -246,8 +249,9 @@ public class TxnTimeOutDUnitTest extends JUnit4DistributedTestCase {
       } catch (Exception e) {
         exceptionOccurred = true;
       }
-      if (!exceptionOccurred)
+      if (!exceptionOccurred) {
         fail("Exception did not occur although was supposed to occur");
+      }
     } catch (Exception e) {
       LogWriterUtils.getLogWriter().fine("Exception caught " + e);
       fail("failed in naming lookup: " + e);
diff --git a/geode-core/src/distributedTest/java/org/apache/geode/pdx/JSONPdxClientServerDUnitTest.java b/geode-core/src/distributedTest/java/org/apache/geode/pdx/JSONPdxClientServerDUnitTest.java
index 5559e60..53d1b8a 100755
--- a/geode-core/src/distributedTest/java/org/apache/geode/pdx/JSONPdxClientServerDUnitTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/pdx/JSONPdxClientServerDUnitTest.java
@@ -350,8 +350,9 @@ public class JSONPdxClientServerDUnitTest extends JUnit4CacheTestCase {
     for (i = 0; i < ba.length; i++) {
       int cbyte = ba[i];
 
-      if (cbyte == INT_TAB || cbyte == INT_LF || cbyte == INT_CR || cbyte == INT_SPACE)
+      if (cbyte == INT_TAB || cbyte == INT_LF || cbyte == INT_CR || cbyte == INT_SPACE) {
         continue;
+      }
       withoutspace[j++] = ba[i];
     }
 
@@ -382,16 +383,19 @@ public class JSONPdxClientServerDUnitTest extends JUnit4CacheTestCase {
   }
 
   public void compareByteArray(byte[] b1, byte[] b2) {
-    if (b1.length != b2.length)
+    if (b1.length != b2.length) {
       throw new IllegalStateException(
           "Json byte array length are not equal " + b1.length + " ; " + b2.length);
+    }
 
-    if (Boolean.getBoolean(JSONFormatter.SORT_JSON_FIELD_NAMES_PROPERTY))
+    if (Boolean.getBoolean(JSONFormatter.SORT_JSON_FIELD_NAMES_PROPERTY)) {
       return;// we just need to compare length as blob will be different because fields are sorted
+    }
 
     for (int i = 0; i < b1.length; i++) {
-      if (b1[i] != b2[i])
+      if (b1[i] != b2[i]) {
         throw new IllegalStateException("Json byte arrays are not equal ");
+      }
     }
   }
 
@@ -405,8 +409,9 @@ public class JSONPdxClientServerDUnitTest extends JUnit4CacheTestCase {
     for (i = 0; i < ba.length; i++) {
       int cbyte = ba[i];
 
-      if (cbyte == INT_TAB || cbyte == INT_LF || cbyte == INT_CR || cbyte == INT_SPACE)
+      if (cbyte == INT_TAB || cbyte == INT_LF || cbyte == INT_CR || cbyte == INT_SPACE) {
         continue;
+      }
       withoutspace[j++] = ba[i];
     }
 
@@ -427,8 +432,9 @@ public class JSONPdxClientServerDUnitTest extends JUnit4CacheTestCase {
     int i = 0;
     for (String jsonFileName : dir.list()) {
 
-      if (!jsonFileName.contains(".txt"))
+      if (!jsonFileName.contains(".txt")) {
         continue;
+      }
       try {
         byte[] ba = getBytesFromFile(dir.getAbsolutePath() + File.separator + jsonFileName);
         JSONDatas[i++] = new JSONData(jsonFileName, ba);
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/CopyJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/CopyJUnitTest.java
index 9e89663..2467eab 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/CopyJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/CopyJUnitTest.java
@@ -184,15 +184,19 @@ public class CopyJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       ModifiableInteger other = (ModifiableInteger) obj;
-      if (v != other.v)
+      if (v != other.v) {
         return false;
+      }
       return true;
     }
   }
@@ -580,20 +584,26 @@ public class CopyJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       Complex1 other = (Complex1) obj;
       if (hashMap == null) {
-        if (other.hashMap != null)
+        if (other.hashMap != null) {
           return false;
-      } else if (!hashMap.equals(other.hashMap))
+        }
+      } else if (!hashMap.equals(other.hashMap)) {
         return false;
-      if (season != other.season)
+      }
+      if (season != other.season) {
         return false;
+      }
       return true;
     }
   }
@@ -616,25 +626,33 @@ public class CopyJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       Complex2 other = (Complex2) obj;
-      if (id != other.id)
+      if (id != other.id) {
         return false;
+      }
       if (innerList == null) {
-        if (other.innerList != null)
+        if (other.innerList != null) {
           return false;
-      } else if (!innerList.equals(other.innerList))
+        }
+      } else if (!innerList.equals(other.innerList)) {
         return false;
+      }
       if (str == null) {
-        if (other.str != null)
+        if (other.str != null) {
           return false;
-      } else if (!str.equals(other.str))
+        }
+      } else if (!str.equals(other.str)) {
         return false;
+      }
       return true;
     }
   }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/TXJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/TXJUnitTest.java
index 044f5c5..0f6180f 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/TXJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/TXJUnitTest.java
@@ -710,8 +710,9 @@ public class TXJUnitTest {
         assertEquals(true, ev.isCallbackArgumentAvailable());
         assertTrue(!ev.isOriginRemote());
         assertTrue(!ev.getOperation().isExpiration());
-        if (!isPR())
+        if (!isPR()) {
           assertTrue(!ev.getOperation().isDistributed());
+        }
       }
     }
     reg1.localDestroy("key1");
@@ -779,8 +780,9 @@ public class TXJUnitTest {
         assertEquals(true, ev.isCallbackArgumentAvailable());
         assertTrue(!ev.isOriginRemote());
         assertTrue(!ev.getOperation().isExpiration());
-        if (!isPR())
+        if (!isPR()) {
           assertTrue(!ev.getOperation().isDistributed());
+        }
       }
     }
     reg1.localDestroy("key1");
@@ -3141,9 +3143,10 @@ public class TXJUnitTest {
       assertNotNull(event.getRegion().getCache().getCacheTransactionManager());
       assertEquals(this.getTXId(), event.getTransactionId());
 
-      if (!isPR())
+      if (!isPR()) {
         assertEquals("IsDistributed Assertion!", this.isDistributed(),
             event.getOperation().isDistributed());
+      }
       assertEquals(this.getKey(), event.getKey());
       assertSame(this.getCallBackArg(), event.getCallbackArgument());
       if (newValIdentCheck) {
@@ -3660,8 +3663,9 @@ public class TXJUnitTest {
     cbv.setTXId(txMgr.getTransactionId());
     cbv.setExpectedCount(appCallCount++);
     this.region.localDestroy(key1, callBackArg);
-    if (!isPR())
+    if (!isPR()) {
       vCw.localDestroyMakeup(1); // Account for cacheWriter not begin called
+    }
     assertTrue("Non-TX LocalDestroy Validation Assertion", cbv.passedValidation());
     cbv.suspendValidation(true);
     this.region.create(key1, value1);
@@ -3672,8 +3676,9 @@ public class TXJUnitTest {
     cbv.setTXId(txMgr.getTransactionId());
     cbv.setExpectedCount(appCallCount++);
     this.region.localDestroy(key1, callBackArg);
-    if (!isPR())
+    if (!isPR()) {
       vCw.localDestroyMakeup(1); // Account for cacheWriter not begin called
+    }
     this.txMgr.commit();
     assertTrue("TX LocalDestroy Validation Assertion", cbv.passedValidation());
 
@@ -4354,8 +4359,9 @@ public class TXJUnitTest {
       public void close() {}
     });
     LocalRegion reg1 = (LocalRegion) this.region;
-    if (isPR())
+    if (isPR()) {
       ((PartitionedRegion) reg1).setHaveCacheLoader();
+    }
     assertTrue(!reg1.containsKey("key1"));
     assertEquals("LV 1", reg1.get("key1"));
     assertTrue(reg1.containsKey("key1"));
@@ -6311,7 +6317,7 @@ public class TXJUnitTest {
         public void run() {
           try {
             region.put("syncKey4", "syncVal4");
-            while (true)
+            while (true) {
               synchronized (signal) {
                 signal[0] = 1;
                 signal.notify();
@@ -6320,6 +6326,7 @@ public class TXJUnitTest {
                   break;
                 }
               }
+            }
           } catch (Exception error) {
             fail("Non-tx thread failure due to: " + error);
           }
@@ -6327,7 +6334,7 @@ public class TXJUnitTest {
       };
       t.start();
       try {
-        while (true)
+        while (true) {
           synchronized (signal) {
             if (signal[0] == 1) {
               signal[0] = 0;
@@ -6337,6 +6344,7 @@ public class TXJUnitTest {
               signal.wait();
             }
           }
+        }
       } catch (InterruptedException dangit) {
         fail("Tx thread waiting for non-tx thread failed due to : " + dangit);
       }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/ProxyJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/ProxyJUnitTest.java
index 1d8ea57..78a9712 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/ProxyJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/ProxyJUnitTest.java
@@ -1125,6 +1125,8 @@ public class ProxyJUnitTest {
    */
   private void waitForSystemTimeChange() {
     long start = System.currentTimeMillis();
-    while (System.currentTimeMillis() == start);
+    while (System.currentTimeMillis() == start) {
+      ;
+    }
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/operations/PutOperationContextJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/operations/PutOperationContextJUnitTest.java
index 5d24cb4..2972637 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/operations/PutOperationContextJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/operations/PutOperationContextJUnitTest.java
@@ -216,18 +216,23 @@ public class PutOperationContextJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       PdxValue other = (PdxValue) obj;
       if (v == null) {
-        if (other.v != null)
+        if (other.v != null) {
           return false;
-      } else if (!v.equals(other.v))
+        }
+      } else if (!v.equals(other.v)) {
         return false;
+      }
       return true;
     }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/QueryJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/QueryJUnitTest.java
index 119a6fd..65003c2 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/QueryJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/QueryJUnitTest.java
@@ -127,8 +127,9 @@ public class QueryJUnitTest {
     CacheUtils.log("testIsCompiled");
     String queryStr = "SELECT DISTINCT * FROM /root";
     Query q = CacheUtils.getQueryService().newQuery(queryStr);
-    if (q.isCompiled())
+    if (q.isCompiled()) {
       fail("Query.isCompiled() returns true for non-compiled query");
+    }
   }
 
   @Test
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/QueryServiceRegressionTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/QueryServiceRegressionTest.java
index 447de42..94058f0 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/QueryServiceRegressionTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/QueryServiceRegressionTest.java
@@ -134,14 +134,17 @@ public class QueryServiceRegressionTest {
       CacheUtils.getLogger().fine("Executing:" + queryStr);
       try {
         r = q.execute();
-        if (i == 1)
+        if (i == 1) {
           fail("should have thrown an AmbiguousNameException");
+        }
       } catch (AmbiguousNameException e) {
-        if (i != 1)
+        if (i != 1) {
           throw e; // if it's 1 then pass
+        }
       }
-      if (r != null)
+      if (r != null) {
         CacheUtils.getLogger().fine(Utils.printResult(r));
+      }
     }
   }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/ComparisonOperatorsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/ComparisonOperatorsJUnitTest.java
index b1c49ec..de3e303 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/ComparisonOperatorsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/ComparisonOperatorsJUnitTest.java
@@ -101,8 +101,9 @@ public class ComparisonOperatorsJUnitTest {
               isPassed = (p.getID() >= value);
               break;
           }
-          if (!isPassed)
+          if (!isPassed) {
             fail(this.getName() + " failed for operator " + operators[i]);
+          }
         }
       } else {
         fail(this.getName() + " failed for operator " + operators[i]);
@@ -147,8 +148,9 @@ public class ComparisonOperatorsJUnitTest {
               isPassed = (p.getP1().getSecId().compareTo(value) >= 0);
               break;
           }
-          if (!isPassed)
+          if (!isPassed) {
             fail(this.getName() + " failed for operator " + operators[i]);
+          }
         }
       } else {
         fail(this.getName() + " failed for operator " + operators[i]);
@@ -178,8 +180,9 @@ public class ComparisonOperatorsJUnitTest {
               isPassed = (p.getP2() != value);
               break;
           }
-          if (!isPassed)
+          if (!isPassed) {
             fail(this.getName() + " failed for operator " + operators[i]);
+          }
         }
       } else {
         fail(this.getName() + " failed for operator " + operators[i]);
@@ -201,8 +204,9 @@ public class ComparisonOperatorsJUnitTest {
             "SELECT DISTINCT * FROM /Portfolios where " + var + operators[i] + " UNDEFINED");
         Object result = query.execute();
         if (result instanceof Collection) {
-          if (((Collection) result).size() != 0)
+          if (((Collection) result).size() != 0) {
             fail(this.getName() + " failed for operator " + operators[i]);
+          }
         } else {
           fail(this.getName() + " failed for operator " + operators[i]);
         }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/ConstantsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/ConstantsJUnitTest.java
index 7ee67d3..b5def0a 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/ConstantsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/ConstantsJUnitTest.java
@@ -57,8 +57,9 @@ public class ConstantsJUnitTest {
     Query query =
         CacheUtils.getQueryService().newQuery("SELECT DISTINCT * FROM /Portfolios where TRUE");
     Object result = query.execute();
-    if (!(result instanceof Collection) || ((Collection) result).size() != 4)
+    if (!(result instanceof Collection) || ((Collection) result).size() != 4) {
       fail(query.getQueryString());
+    }
   }
 
   @Test
@@ -66,8 +67,9 @@ public class ConstantsJUnitTest {
     Query query =
         CacheUtils.getQueryService().newQuery("SELECT DISTINCT * FROM /Portfolios where FALSE");
     Object result = query.execute();
-    if (!(result instanceof Collection) || ((Collection) result).size() != 0)
+    if (!(result instanceof Collection) || ((Collection) result).size() != 0) {
       fail(query.getQueryString());
+    }
   }
 
   @Test
@@ -75,13 +77,15 @@ public class ConstantsJUnitTest {
     Query query =
         CacheUtils.getQueryService().newQuery("SELECT DISTINCT * FROM /Portfolios where UNDEFINED");
     Object result = query.execute();
-    if (!(result instanceof Collection) || ((Collection) result).size() != 0)
+    if (!(result instanceof Collection) || ((Collection) result).size() != 0) {
       fail(query.getQueryString());
+    }
 
     query = CacheUtils.getQueryService().newQuery("SELECT DISTINCT * FROM UNDEFINED");
     result = query.execute();
-    if (!(result instanceof Collection) || ((Collection) result).size() != 0)
+    if (!(result instanceof Collection) || ((Collection) result).size() != 0) {
       fail(query.getQueryString());
+    }
   }
 
   @Test
@@ -89,12 +93,14 @@ public class ConstantsJUnitTest {
     Query query =
         CacheUtils.getQueryService().newQuery("SELECT DISTINCT * FROM /Portfolios where NULL");
     Object result = query.execute();
-    if (!(result instanceof Collection) || ((Collection) result).size() != 0)
+    if (!(result instanceof Collection) || ((Collection) result).size() != 0) {
       fail(query.getQueryString());
+    }
 
     query = CacheUtils.getQueryService().newQuery("SELECT DISTINCT * FROM NULL");
     result = query.execute();
-    if (!(result instanceof Collection) || ((Collection) result).size() != 0)
+    if (!(result instanceof Collection) || ((Collection) result).size() != 0) {
       fail(query.getQueryString());
+    }
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/DistinctResultsWithDupValuesInRegionJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/DistinctResultsWithDupValuesInRegionJUnitTest.java
index c38cd1d..b22dc36 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/DistinctResultsWithDupValuesInRegionJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/DistinctResultsWithDupValuesInRegionJUnitTest.java
@@ -433,8 +433,9 @@ public class DistinctResultsWithDupValuesInRegionJUnitTest {
     for (int i = 1; i <= numElem; i++) {
       Portfolio obj = new Portfolio(i);
       region.put(i, obj);
-      if (i % (numElem / 5) == 0)
+      if (i % (numElem / 5) == 0) {
         obj.status = null;
+      }
       region.put(i + numElem, obj);
       CacheUtils.log(obj);
     }
@@ -451,8 +452,9 @@ public class DistinctResultsWithDupValuesInRegionJUnitTest {
     for (int i = 1; i <= numElem; i++) {
       Portfolio obj = new Portfolio(i);
       region.put(i, obj);
-      if (i % (numElem / 5) == 0)
+      if (i % (numElem / 5) == 0) {
         obj.status = null;
+      }
       region.put(i + numElem, obj);
       CacheUtils.log(obj);
     }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/FunctionJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/FunctionJUnitTest.java
index 36e35b3..3f5b323 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/FunctionJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/FunctionJUnitTest.java
@@ -105,8 +105,9 @@ public class FunctionJUnitTest {
       Iterator iter = ((Collection) result).iterator();
       while (iter.hasNext()) {
         Portfolio p = (Portfolio) iter.next();
-        if (p.getP2() == null)
+        if (p.getP2() == null) {
           fail(query.getQueryString());
+        }
       }
     }
     Object testData[][] = {{"string", Boolean.TRUE}, {new Integer(0), Boolean.TRUE},
@@ -115,8 +116,9 @@ public class FunctionJUnitTest {
     for (int i = 0; i < testData.length; i++) {
       query = CacheUtils.getQueryService().newQuery("IS_DEFINED($1)");
       result = query.execute(testData[i]);
-      if (!result.equals(testData[i][1]))
+      if (!result.equals(testData[i][1])) {
         fail(query.getQueryString() + " for " + testData[i][0]);
+      }
     }
   }
 
@@ -129,8 +131,9 @@ public class FunctionJUnitTest {
       Iterator iter = ((Collection) result).iterator();
       while (iter.hasNext()) {
         Portfolio p = (Portfolio) iter.next();
-        if (p.getP2() != null)
+        if (p.getP2() != null) {
           fail(query.getQueryString());
+        }
       }
     }
     Object testData[][] = {{"string", Boolean.FALSE}, {new Integer(0), Boolean.FALSE},
@@ -139,8 +142,9 @@ public class FunctionJUnitTest {
     for (int i = 0; i < testData.length; i++) {
       query = CacheUtils.getQueryService().newQuery("IS_UNDEFINED($1)");
       result = query.execute(testData[i]);
-      if (!result.equals(testData[i][1]))
+      if (!result.equals(testData[i][1])) {
         fail(query.getQueryString() + " for " + testData[i][0]);
+      }
     }
   }
 
@@ -149,8 +153,9 @@ public class FunctionJUnitTest {
     Query query = CacheUtils.getQueryService()
         .newQuery("ELEMENT(SELECT DISTINCT * FROM /Portfolios where ID =1).status");
     Object result = query.execute();
-    if (!result.equals("inactive"))
+    if (!result.equals("inactive")) {
       fail(query.getQueryString());
+    }
     try {
       query = CacheUtils.getQueryService()
           .newQuery("ELEMENT(SELECT DISTINCT * FROM /Portfolios where ID <= 1).status");
@@ -165,13 +170,15 @@ public class FunctionJUnitTest {
   public void testNVL() throws Exception {
     Query query = CacheUtils.getQueryService().newQuery("nvl(NULL, 'foundNull')");
     Object result = query.execute();
-    if (!result.equals("foundNull"))
+    if (!result.equals("foundNull")) {
       fail(query.getQueryString());
+    }
 
     query = CacheUtils.getQueryService().newQuery("nvl('notNull', 'foundNull')");
     result = query.execute();
-    if (result.equals("foundNull"))
+    if (result.equals("foundNull")) {
       fail(query.getQueryString());
+    }
 
     query = CacheUtils.getQueryService().newQuery(
         "select distinct * from /Portfolios pf where nvl(pf.position2,'foundNull') = 'foundNull'");
@@ -237,8 +244,9 @@ public class FunctionJUnitTest {
       query = qs.newQuery(queries[i]);
       result = query.execute();
       // CacheUtils.log(((Date)result));
-      if (!result.equals(date))
+      if (!result.equals(date)) {
         fail(query.getQueryString());
+      }
     }
 
     for (int i = 0; i < noCheckQueries.length; i++) {
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IUM6Bug32345ReJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IUM6Bug32345ReJUnitTest.java
index 8997167..bc02ae7 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IUM6Bug32345ReJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IUM6Bug32345ReJUnitTest.java
@@ -182,19 +182,24 @@ public class IUM6Bug32345ReJUnitTest {
     while (itert1.hasNext()) {
       Struct stc2 = (Struct) itert2.next();
       Struct stc1 = (Struct) itert1.next();
-      if (stc2.get(strg2[0]) != stc1.get(strg1[0]))
+      if (stc2.get(strg2[0]) != stc1.get(strg1[0])) {
         fail(
             "FAILED: In both the Cases the first member of StructSet i.e. Portfolio are different. ");
-      if (stc2.get(strg2[1]) != stc1.get(strg1[1]))
+      }
+      if (stc2.get(strg2[1]) != stc1.get(strg1[1])) {
         fail("FAILED: In both the cases Positions are different");
+      }
       if (!StringUtils.equals(((Position) stc2.get(strg2[1])).secId,
-          ((Position) stc1.get(strg1[1])).secId))
+          ((Position) stc1.get(strg1[1])).secId)) {
         fail("FAILED: In both the cases Positions secIds are different");
+      }
       if (((Portfolio) stc2.get(strg2[0])).isActive() != ((Portfolio) stc1.get(strg1[0]))
-          .isActive())
+          .isActive()) {
         fail("FAILED: Status of the Portfolios found are different");
-      if (((Portfolio) stc2.get(strg2[0])).getID() != ((Portfolio) stc1.get(strg1[0])).getID())
+      }
+      if (((Portfolio) stc2.get(strg2[0])).getID() != ((Portfolio) stc1.get(strg1[0])).getID()) {
         fail("FAILED: IDs of the Portfolios found are different");
+      }
     }
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
   }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IUMJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IUMJUnitTest.java
index c5ada92..256de4f 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IUMJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IUMJUnitTest.java
@@ -209,10 +209,12 @@ public class IUMJUnitTest {
     itert3 = set3.iterator();
     while (itert3.hasNext()) {
       Struct stc3 = (Struct) itert3.next();
-      if (!((Position) stc3.get(strg3[1])).secId.equals("IBM"))
+      if (!((Position) stc3.get(strg3[1])).secId.equals("IBM")) {
         fail("FAILED:  secId found is not IBM");
-      if (((Portfolio) stc3.get(strg3[0])).isActive() != false)
+      }
+      if (((Portfolio) stc3.get(strg3[0])).isActive() != false) {
         fail("FAILED:Portfolio in Search result is Active");
+      }
     }
 
   }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexOperatorJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexOperatorJUnitTest.java
index 1756957..2f7531a 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexOperatorJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexOperatorJUnitTest.java
@@ -54,11 +54,13 @@ public class IndexOperatorJUnitTest {
   public void testWithString() throws Exception {
     String str = "xyz";
     Character c = (Character) runQuery(str, 0);
-    if (c.charValue() != 'x')
+    if (c.charValue() != 'x') {
       fail();
+    }
     Character d = (Character) runQuery(str, 2);
-    if (d.charValue() != 'z')
+    if (d.charValue() != 'z') {
       fail();
+    }
   }
 
   @Test
@@ -67,18 +69,21 @@ public class IndexOperatorJUnitTest {
     int index = 1;
     String stringArray[] = {"a", "b"};
     result = runQuery(stringArray, index);
-    if (result == null || !stringArray[index].equals(result))
+    if (result == null || !stringArray[index].equals(result)) {
       fail("failed for String array");
+    }
 
     int intArray[] = {1, 2};
     result = runQuery(intArray, index);
-    if (result == null || intArray[index] != ((Integer) result).intValue())
+    if (result == null || intArray[index] != ((Integer) result).intValue()) {
       fail("failed for int array");
+    }
 
     Object objectArray[] = {"a", "b"};
     result = runQuery(objectArray, index);
-    if (result == null || !objectArray[index].equals(result))
+    if (result == null || !objectArray[index].equals(result)) {
       fail("failed for String array");
+    }
 
   }
 
@@ -90,8 +95,9 @@ public class IndexOperatorJUnitTest {
     Object result = null;
     int index = 1;
     result = runQuery(list, index);
-    if (result == null || !list.get(index).equals(result))
+    if (result == null || !list.get(index).equals(result)) {
       fail("failed for List");
+    }
   }
 
   @Test
@@ -103,8 +109,9 @@ public class IndexOperatorJUnitTest {
     Object result = null;
     Object index = "1";
     result = runQuery(map, index);
-    if (result == null || !map.get(index).equals(result))
+    if (result == null || !map.get(index).equals(result)) {
       fail("failed for Map");
+    }
   }
 
   @Test
@@ -117,8 +124,9 @@ public class IndexOperatorJUnitTest {
     Object result = null;
     Object index = "2";
     result = runQuery(region, index);
-    if (result == null || !region.get(index).equals(result))
+    if (result == null || !region.get(index).equals(result)) {
       fail("failed for Region");
+    }
   }
 
   @Test
@@ -127,8 +135,9 @@ public class IndexOperatorJUnitTest {
     Query q = CacheUtils.getQueryService().newQuery("$1[0][0]");
     Object params[] = {array, new Integer(0)};
     Character result = (Character) q.execute(params);
-    if (result == null || result.charValue() != 'a')
+    if (result == null || result.charValue() != 'a') {
       fail();
+    }
   }
 
   @Test
@@ -145,8 +154,9 @@ public class IndexOperatorJUnitTest {
     map.put("0", new Integer(11));
     map.put("1", new Integer(12));
     Object result = runQuery(map, null);
-    if (result != null)
+    if (result != null) {
       fail();
+    }
   }
 
   @Test
@@ -171,8 +181,9 @@ public class IndexOperatorJUnitTest {
     map.put("0", new Integer(11));
     map.put("1", new Integer(12));
     Object result = runQuery(map, QueryService.UNDEFINED);
-    if (result != null)
+    if (result != null) {
       fail();
+    }
   }
 
   @Test
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexPrimaryKeyUsageJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexPrimaryKeyUsageJUnitTest.java
index b8b61c2..d4387b8 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexPrimaryKeyUsageJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexPrimaryKeyUsageJUnitTest.java
@@ -53,8 +53,9 @@ public class IndexPrimaryKeyUsageJUnitTest {
   public void setUp() throws java.lang.Exception {
     CacheUtils.startCache();
     Region r = CacheUtils.createRegion("portfolios", Portfolio.class);
-    for (int i = 0; i < 4; i++)
+    for (int i = 0; i < 4; i++) {
       r.put(i + "", new Portfolio(i));
+    }
   }
 
   @After
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexUsageInNestedQueryJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexUsageInNestedQueryJUnitTest.java
index 44fd0ba..001b54e 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexUsageInNestedQueryJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexUsageInNestedQueryJUnitTest.java
@@ -48,8 +48,9 @@ public class IndexUsageInNestedQueryJUnitTest {
   public void setUp() throws java.lang.Exception {
     CacheUtils.startCache();
     Region r = CacheUtils.createRegion("portfolios", Portfolio.class);
-    for (int i = 0; i < 4; i++)
+    for (int i = 0; i < 4; i++) {
       r.put(i + "", new Portfolio(i));
+    }
   }
 
   @After
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexUseMultFrmSnglCondJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexUseMultFrmSnglCondJUnitTest.java
index 37b610f..7089134 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexUseMultFrmSnglCondJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexUseMultFrmSnglCondJUnitTest.java
@@ -167,12 +167,14 @@ public class IndexUseMultFrmSnglCondJUnitTest {
     while (iter1.hasNext()) {
       Struct stc2 = (Struct) iter2.next();
       Struct stc1 = (Struct) iter1.next();
-      if (stc2.get(strAr2[0]) != stc1.get(strAr1[0]))
+      if (stc2.get(strAr2[0]) != stc1.get(strAr1[0])) {
         fail(
             "FAILED: In both the Cases the first member of StructSet i.e. Portfolio are different. ");
+      }
       if (stc2.get(strAr2[1]) != stc1.get(strAr1[1])
-          || !((Position) stc1.get(strAr1[1])).secId.equals("IBM"))
+          || !((Position) stc1.get(strAr1[1])).secId.equals("IBM")) {
         fail("FAILED: In both the cases either Positions Or secIds obtained are different");
+      }
     }
 
     CacheUtils.compareResultsOfWithAndWithoutIndex(r, this);
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexWithSngleFrmAndMultCondQryJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexWithSngleFrmAndMultCondQryJUnitTest.java
index cf3ea6b..e1dae0c 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexWithSngleFrmAndMultCondQryJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IndexWithSngleFrmAndMultCondQryJUnitTest.java
@@ -189,19 +189,24 @@ public class IndexWithSngleFrmAndMultCondQryJUnitTest {
     while (itert1.hasNext()) {
       Struct stc2 = (Struct) itert2.next();
       Struct stc1 = (Struct) itert1.next();
-      if (stc2.get(strg2[0]) != stc1.get(strg1[0]))
+      if (stc2.get(strg2[0]) != stc1.get(strg1[0])) {
         fail(
             "FAILED: In both the Cases the first member of StructSet i.e. Portfolio are different. ");
-      if (stc2.get(strg2[1]) != stc1.get(strg1[1]))
+      }
+      if (stc2.get(strg2[1]) != stc1.get(strg1[1])) {
         fail("FAILED: In both the cases Positions are different");
+      }
       if (!StringUtils.equals(((Position) stc2.get(strg2[1])).secId,
-          ((Position) stc1.get(strg1[1])).secId))
+          ((Position) stc1.get(strg1[1])).secId)) {
         fail("FAILED: In both the cases Positions secIds are different");
+      }
       if (((Portfolio) stc2.get(strg2[0])).isActive() != ((Portfolio) stc1.get(strg1[0]))
-          .isActive())
+          .isActive()) {
         fail("FAILED: Status of the Portfolios found are different");
-      if (((Portfolio) stc2.get(strg2[0])).getID() != ((Portfolio) stc1.get(strg1[0])).getID())
+      }
+      if (((Portfolio) stc2.get(strg2[0])).getID() != ((Portfolio) stc1.get(strg1[0])).getID()) {
         fail("FAILED: IDs of the Portfolios found are different");
+      }
     }
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
   }
@@ -305,19 +310,24 @@ public class IndexWithSngleFrmAndMultCondQryJUnitTest {
     while (itert1.hasNext()) {
       Struct stc2 = (Struct) itert2.next();
       Struct stc1 = (Struct) itert1.next();
-      if (stc2.get(strg2[0]) != stc1.get(strg1[0]))
+      if (stc2.get(strg2[0]) != stc1.get(strg1[0])) {
         fail(
             "FAILED: In both the Cases the first member of StructSet i.e. Portfolio are different. ");
-      if (stc2.get(strg2[1]) != stc1.get(strg1[1]))
+      }
+      if (stc2.get(strg2[1]) != stc1.get(strg1[1])) {
         fail("FAILED: In both the cases Positions are different");
+      }
       if (!StringUtils.equals(((Position) stc2.get(strg2[1])).secId,
-          ((Position) stc1.get(strg1[1])).secId))
+          ((Position) stc1.get(strg1[1])).secId)) {
         fail("FAILED: In both the cases Positions secIds are different");
+      }
       if (((Portfolio) stc2.get(strg2[0])).isActive() != ((Portfolio) stc1.get(strg1[0]))
-          .isActive())
+          .isActive()) {
         fail("FAILED: Status of the Portfolios found are different");
-      if (((Portfolio) stc2.get(strg2[0])).getID() != ((Portfolio) stc1.get(strg1[0])).getID())
+      }
+      if (((Portfolio) stc2.get(strg2[0])).getID() != ((Portfolio) stc1.get(strg1[0])).getID()) {
         fail("FAILED: IDs of the Portfolios found are different");
+      }
     }
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
   }
@@ -579,17 +589,20 @@ public class IndexWithSngleFrmAndMultCondQryJUnitTest {
       Object pos2 = itert2.next();
       Object pos1 = itert1.next();
       Object posFromRegion = region.get(((Portfolio) pos1).getPk());
-      if (!pos1.equals(pos2))
+      if (!pos1.equals(pos2)) {
         fail(
             "FAILED: In both the Cases the first member of StructSet i.e. Portfolio are different. ");
+      }
       if (checkReferentialIntegrity) {
         assertTrue(pos2 == pos1);
         assertTrue(pos2 == posFromRegion);
       }
-      if (((Portfolio) pos2).isActive() != ((Portfolio) pos1).isActive())
+      if (((Portfolio) pos2).isActive() != ((Portfolio) pos1).isActive()) {
         fail("FAILED: Status of the Portfolios found are different");
-      if (((Portfolio) pos2).getID() != ((Portfolio) pos1).getID())
+      }
+      if (((Portfolio) pos2).getID() != ((Portfolio) pos1).getID()) {
         fail("FAILED: IDs of the Portfolios found are different");
+      }
     }
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
 
@@ -736,9 +749,10 @@ public class IndexWithSngleFrmAndMultCondQryJUnitTest {
       Object pos2 = itert2.next();
       Object pos1 = itert1.next();
       Object posFromRegion = region.get(((Portfolio) pos1).getPk());
-      if (!pos1.equals(pos2))
+      if (!pos1.equals(pos2)) {
         fail(
             "FAILED: In both the Cases the first member of StructSet i.e. Portfolio are different. ");
+      }
       if (checkReferentialIntegrity) {
         assertTrue(pos2 == pos1);
         assertTrue(pos2 == posFromRegion);
@@ -755,10 +769,12 @@ public class IndexWithSngleFrmAndMultCondQryJUnitTest {
        * if(((Position)stc2.get(strg2[1])).secId != ((Position)stc1.get(strg1[1])).secId)
        * fail("FAILED: In both the cases Positions secIds are different");
        */
-      if (((Portfolio) pos2).isActive() != ((Portfolio) pos1).isActive())
+      if (((Portfolio) pos2).isActive() != ((Portfolio) pos1).isActive()) {
         fail("FAILED: Status of the Portfolios found are different");
-      if (((Portfolio) pos2).getID() != ((Portfolio) pos1).getID())
+      }
+      if (((Portfolio) pos2).getID() != ((Portfolio) pos1).getID()) {
         fail("FAILED: IDs of the Portfolios found are different");
+      }
     }
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
 
@@ -961,17 +977,20 @@ public class IndexWithSngleFrmAndMultCondQryJUnitTest {
       Object pos2 = itert2.next();
       Object pos1 = itert1.next();
       Object posFromRegion = region.get(((Portfolio) pos1).getPk());
-      if (!pos1.equals(pos2))
+      if (!pos1.equals(pos2)) {
         fail(
             "FAILED: In both the Cases the first member of StructSet i.e. Portfolio are different. ");
+      }
       if (checkReferentialIntegrity) {
         assertTrue(pos2 == pos1);
         assertTrue(pos2 == posFromRegion);
       }
-      if (((Portfolio) pos2).isActive() != ((Portfolio) pos1).isActive())
+      if (((Portfolio) pos2).isActive() != ((Portfolio) pos1).isActive()) {
         fail("FAILED: Status of the Portfolios found are different");
-      if (((Portfolio) pos2).getID() != ((Portfolio) pos1).getID())
+      }
+      if (((Portfolio) pos2).getID() != ((Portfolio) pos1).getID()) {
         fail("FAILED: IDs of the Portfolios found are different");
+      }
     }
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
 
@@ -1170,17 +1189,20 @@ public class IndexWithSngleFrmAndMultCondQryJUnitTest {
       Object pos2 = itert2.next();
       Object pos1 = itert1.next();
       Object posFromRegion = region.get(((Portfolio) pos1).getPk());
-      if (!pos1.equals(pos2))
+      if (!pos1.equals(pos2)) {
         fail(
             "FAILED: In both the Cases the first member of StructSet i.e. Portfolio are different. ");
+      }
       if (checkReferentialIntegrity) {
         assertTrue(pos2 == pos1);
         assertTrue(pos2 == posFromRegion);
       }
-      if (((Portfolio) pos2).isActive() != ((Portfolio) pos1).isActive())
+      if (((Portfolio) pos2).isActive() != ((Portfolio) pos1).isActive()) {
         fail("FAILED: Status of the Portfolios found are different");
-      if (((Portfolio) pos2).getID() != ((Portfolio) pos1).getID())
+      }
+      if (((Portfolio) pos2).getID() != ((Portfolio) pos1).getID()) {
         fail("FAILED: IDs of the Portfolios found are different");
+      }
     }
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IteratorTypeDefJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IteratorTypeDefJUnitTest.java
index 856edee..4637639 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IteratorTypeDefJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IteratorTypeDefJUnitTest.java
@@ -84,13 +84,15 @@ public class IteratorTypeDefJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         Object r = q.execute();
-        if (!(r instanceof SelectResults))
+        if (!(r instanceof SelectResults)) {
           fail(
               "testIteratorDefSyntaxForObtainingResultBag: Test failed as obtained Result Data not an instance of SelectResults. Query= "
                   + q.getQueryString());
-        if (((SelectResults) r).getCollectionType().allowsDuplicates())
+        }
+        if (((SelectResults) r).getCollectionType().allowsDuplicates()) {
           fail(
               "testIteratorDefSyntaxForObtainingResultBag: results of query should not allow duplicates, but says it does");
+        }
       } catch (Exception e) {
         e.printStackTrace();
         fail(q.getQueryString());
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IteratorTypeDefaultTypesJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IteratorTypeDefaultTypesJUnitTest.java
index 846286b..9f2a662 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IteratorTypeDefaultTypesJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IteratorTypeDefaultTypesJUnitTest.java
@@ -68,8 +68,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefIntegerArray: Query fetched zero results ");
+        }
 
       } catch (Exception e) {
         e.printStackTrace();
@@ -95,8 +96,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefIntegerArrayList: Query fetched zero results ");
+        }
       } catch (Exception e) {
         e.printStackTrace();
         fail(q.getQueryString());
@@ -121,8 +123,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefString: Query fetched zero results ");
+        }
 
       } catch (Exception e) {
         e.printStackTrace();
@@ -147,8 +150,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefBoolean: Query fetched zero results ");
+        }
       } catch (Exception e) {
         e.printStackTrace();
         fail(q.getQueryString());
@@ -173,8 +177,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefByte: Query fetched zero results ");
+        }
       } catch (Exception e) {
         e.printStackTrace();
         fail(q.getQueryString());
@@ -198,8 +203,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefShort: Query fetched zero results ");
+        }
       } catch (Exception e) {
         e.printStackTrace();
         fail(q.getQueryString());
@@ -223,8 +229,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefLong: Query fetched zero results ");
+        }
       } catch (Exception e) {
         e.printStackTrace();
         fail(q.getQueryString());
@@ -248,8 +255,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefDouble: Query fetched zero results ");
+        }
       } catch (Exception e) {
         e.printStackTrace();
         fail(q.getQueryString());
@@ -273,8 +281,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefFloat: Query fetched zero results ");
+        }
       } catch (Exception e) {
         e.printStackTrace();
         fail(q.getQueryString());
@@ -298,8 +307,9 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() < 1)
+        if (rs.size() < 1) {
           fail("testIteratorDefChar: Query fetched zero results ");
+        }
       } catch (Exception e) {
         e.printStackTrace();
         fail(q.getQueryString());
@@ -333,9 +343,10 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() != 1)
+        if (rs.size() != 1) {
           fail("testNonStaticInnerClassTypeDef: Query fetched results with size =" + rs.size()
               + " FOr Query number = " + (i + 1));
+        }
 
       } catch (Exception e) {
         e.printStackTrace();
@@ -370,9 +381,10 @@ public class IteratorTypeDefaultTypesJUnitTest {
       try {
         q = CacheUtils.getQueryService().newQuery(queries[i]);
         SelectResults rs = (SelectResults) q.execute(params);
-        if (rs.size() != 1)
+        if (rs.size() != 1) {
           fail("testStaticInnerClassTypeDef: Query fetched results with size =" + rs.size()
               + " FOr Query number = " + (i + 1));
+        }
 
       } catch (Exception e) {
         e.printStackTrace();
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IumMultConditionJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IumMultConditionJUnitTest.java
index 84f90a9..b6cce82 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IumMultConditionJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/IumMultConditionJUnitTest.java
@@ -191,19 +191,24 @@ public class IumMultConditionJUnitTest {
     while (itert1.hasNext()) {
       Struct stc2 = (Struct) itert2.next();
       Struct stc1 = (Struct) itert1.next();
-      if (stc2.get(strg2[0]) != stc1.get(strg1[0]))
+      if (stc2.get(strg2[0]) != stc1.get(strg1[0])) {
         fail(
             "FAILED: In both the Cases the first member of StructSet i.e. Portfolio are different. ");
-      if (stc2.get(strg2[1]) != stc1.get(strg1[1]))
+      }
+      if (stc2.get(strg2[1]) != stc1.get(strg1[1])) {
         fail("FAILED: In both the cases Positions are different");
+      }
       if (!StringUtils.equals(((Position) stc2.get(strg2[1])).secId,
-          ((Position) stc1.get(strg1[1])).secId))
+          ((Position) stc1.get(strg1[1])).secId)) {
         fail("FAILED: In both the cases Positions secIds are different");
+      }
       if (((Portfolio) stc2.get(strg2[0])).isActive() != ((Portfolio) stc1.get(strg1[0]))
-          .isActive())
+          .isActive()) {
         fail("FAILED: Status of the Portfolios found are different");
-      if (((Portfolio) stc2.get(strg2[0])).getID() != ((Portfolio) stc1.get(strg1[0])).getID())
+      }
+      if (((Portfolio) stc2.get(strg2[0])).getID() != ((Portfolio) stc1.get(strg1[0])).getID()) {
         fail("FAILED: IDs of the Portfolios found are different");
+      }
     }
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
   }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/LimitClauseJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/LimitClauseJUnitTest.java
index dfbaf92..68f8fc6 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/LimitClauseJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/LimitClauseJUnitTest.java
@@ -79,8 +79,9 @@ public class LimitClauseJUnitTest {
   public void tearDown() throws Exception {
     CacheUtils.closeCache();
     IndexManager indexManager = ((LocalRegion) region).getIndexManager();
-    if (indexManager != null)
+    if (indexManager != null) {
       indexManager.destroy();
+    }
   }
 
 
@@ -970,8 +971,9 @@ public class LimitClauseJUnitTest {
       Region region = CacheUtils.createRegion("portfolios1", Portfolio.class);
       for (int i = 1; i < 100; i++) {
         Portfolio p = new Portfolio(i);
-        if (i < 50)
+        if (i < 50) {
           p.status = "active";
+        }
         region.put(Integer.toString(i), p);
       }
 
@@ -1002,8 +1004,9 @@ public class LimitClauseJUnitTest {
       Region region = CacheUtils.createRegion("portfolios1", Portfolio.class);
       for (int i = 1; i < 100; i++) {
         Portfolio p = new Portfolio(i);
-        if (i < 50)
+        if (i < 50) {
           p.status = "active";
+        }
         region.put(Integer.toString(i), p);
       }
 
@@ -1041,8 +1044,9 @@ public class LimitClauseJUnitTest {
       Region region = CacheUtils.createRegion("portfolios1", Portfolio.class);
       for (int i = 1; i < 100; i++) {
         Portfolio p = new Portfolio(i);
-        if (i < 50)
+        if (i < 50) {
           p.status = "active";
+        }
         region.put(Integer.toString(i), p);
       }
 
@@ -1078,8 +1082,9 @@ public class LimitClauseJUnitTest {
       Region region = CacheUtils.createRegion("portfolios1", Portfolio.class);
       for (int i = 1; i < 100; i++) {
         Portfolio p = new Portfolio(i);
-        if (i < 50)
+        if (i < 50) {
           p.status = "active";
+        }
         region.put(Integer.toString(i), p);
       }
 
@@ -1115,8 +1120,9 @@ public class LimitClauseJUnitTest {
       Region region = CacheUtils.createRegion("portfolios1", Portfolio.class);
       for (int i = 1; i < 100; i++) {
         Portfolio p = new Portfolio(i);
-        if (i < 50)
+        if (i < 50) {
           p.status = "active";
+        }
         region.put(Integer.toString(i), p);
       }
 
@@ -1153,8 +1159,9 @@ public class LimitClauseJUnitTest {
       Region region = CacheUtils.createRegion("portfolios1", Portfolio.class);
       for (int i = 1; i < 10; i++) {
         Portfolio p = new Portfolio(i);
-        if (i == 2)
+        if (i == 2) {
           p = new Portfolio(1);
+        }
         region.put(Integer.toString(i), p);
       }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/LogicalOperatorsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/LogicalOperatorsJUnitTest.java
index d2defd8..f954c31 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/LogicalOperatorsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/LogicalOperatorsJUnitTest.java
@@ -68,8 +68,9 @@ public class LogicalOperatorsJUnitTest {
         Object result = query.execute(params);
         // CacheUtils.log("LogicalTest "+validOperands[i]+" AND "+validOperands[j]+" = "+result+"
         // "+checkResult("AND", result, validOperands[i], validOperands[j]));
-        if (!checkResult("AND", result, validOperands[i], validOperands[j]))
+        if (!checkResult("AND", result, validOperands[i], validOperands[j])) {
           fail(validOperands[i] + " AND " + validOperands[j] + " returns " + result);
+        }
       }
     }
     for (int i = 0; i < validOperands.length; i++) {
@@ -99,8 +100,9 @@ public class LogicalOperatorsJUnitTest {
         Object result = query.execute(params);
         // CacheUtils.log("LogicalTest "+validOperands[i]+" OR "+validOperands[j]+" = "+result+"
         // "+checkResult("OR", result, validOperands[i], validOperands[j]));
-        if (!checkResult("OR", result, validOperands[i], validOperands[j]))
+        if (!checkResult("OR", result, validOperands[i], validOperands[j])) {
           fail(validOperands[i] + " OR " + validOperands[j] + " returns " + result);
+        }
       }
     }
 
@@ -127,8 +129,9 @@ public class LogicalOperatorsJUnitTest {
       Object result = query.execute(validOperands);
       // CacheUtils.log("LogicalTest "+"NOT "+validOperands[i]+" = "+result+" "+checkResult("NOT",
       // result, validOperands[i], null));
-      if (!checkResult("NOT", result, validOperands[i], null))
+      if (!checkResult("NOT", result, validOperands[i], null)) {
         fail("NOT " + validOperands[i] + " returns " + result);
+      }
     }
 
     for (int j = 0; j < invalidOperands.length; j++) {
@@ -150,44 +153,54 @@ public class LogicalOperatorsJUnitTest {
         operand1 = operand2;
         operand2 = temp;
       }
-      if (operand1 == null)
+      if (operand1 == null) {
         return result.equals(QueryService.UNDEFINED);
+      }
 
       if (operator.equalsIgnoreCase("AND")) {
 
-        if (operand1.equals(Boolean.FALSE))
+        if (operand1.equals(Boolean.FALSE)) {
           return result.equals(Boolean.FALSE);
+        }
 
-        if (operand2 != null && operand2.equals(Boolean.FALSE))
+        if (operand2 != null && operand2.equals(Boolean.FALSE)) {
           return result.equals(Boolean.FALSE);
+        }
 
-        if (operand1 == QueryService.UNDEFINED || operand2 == QueryService.UNDEFINED)
+        if (operand1 == QueryService.UNDEFINED || operand2 == QueryService.UNDEFINED) {
           return result.equals(QueryService.UNDEFINED);
+        }
 
-        if (operand2 == null)
+        if (operand2 == null) {
           return result.equals(QueryService.UNDEFINED);
+        }
 
         return result.equals(Boolean.TRUE);
 
       } else if (operator.equalsIgnoreCase("OR")) {
 
-        if (operand1.equals(Boolean.TRUE))
+        if (operand1.equals(Boolean.TRUE)) {
           return result.equals(Boolean.TRUE);
+        }
 
-        if (operand2 != null && operand2.equals(Boolean.TRUE))
+        if (operand2 != null && operand2.equals(Boolean.TRUE)) {
           return result.equals(Boolean.TRUE);
+        }
 
-        if (operand1 == QueryService.UNDEFINED || operand2 == QueryService.UNDEFINED)
+        if (operand1 == QueryService.UNDEFINED || operand2 == QueryService.UNDEFINED) {
           return result == QueryService.UNDEFINED;
+        }
 
-        if (/* operand1 == null || not possible */ operand2 == null)
+        if (/* operand1 == null || not possible */ operand2 == null) {
           return result == QueryService.UNDEFINED;
+        }
 
         return result.equals(Boolean.FALSE);
 
       } else if (operator.equalsIgnoreCase("NOT")) {
-        if (operand1 instanceof Boolean)
+        if (operand1 instanceof Boolean) {
           return ((Boolean) result).booleanValue() != ((Boolean) operand1).booleanValue();
+        }
         return result == QueryService.UNDEFINED;
       }
     } catch (Exception e) {
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/MultipleRegionsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/MultipleRegionsJUnitTest.java
index d9c847f..11cc94f 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/MultipleRegionsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/MultipleRegionsJUnitTest.java
@@ -79,8 +79,9 @@ public class MultipleRegionsJUnitTest {
     for (int i = 0; i < queries.length; i++) {
       Query query = qs.newQuery(queries[i]);
       Object result = query.execute();
-      if (((Collection) result).size() != SizeArray[i])
+      if (((Collection) result).size() != SizeArray[i]) {
         fail("Size of Result is not as Expected");
+      }
     }
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/NestedQueryJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/NestedQueryJUnitTest.java
index 9ce776f..fb11e61 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/NestedQueryJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/NestedQueryJUnitTest.java
@@ -77,8 +77,9 @@ public class NestedQueryJUnitTest {
   public void setUp() throws java.lang.Exception {
     CacheUtils.startCache();
     Region r = CacheUtils.createRegion("Portfolios", Portfolio.class);
-    for (int i = 0; i < 4; i++)
+    for (int i = 0; i < 4; i++) {
       r.put(i + "", new Portfolio(i));
+    }
   }
 
   @After
@@ -230,8 +231,9 @@ public class NestedQueryJUnitTest {
     while (itert1.hasNext()) {
       Portfolio p1 = (Portfolio) itert1.next();
       Portfolio p2 = (Portfolio) itert2.next();
-      if (!set1.contains(p2) || !set2.contains(p1))
+      if (!set1.contains(p2) || !set2.contains(p1)) {
         fail("FAILED: In both the Cases the members of ResultsSet are different.");
+      }
     }
     CacheUtils.compareResultsOfWithAndWithoutIndex(r, this);
   }
@@ -332,11 +334,13 @@ public class NestedQueryJUnitTest {
           found = true;
         }
       }
-      if (!found)
+      if (!found) {
         pass = false;
+      }
     }
-    if (!pass)
+    if (!pass) {
       fail("Test failed");
+    }
 
     CacheUtils.compareResultsOfWithAndWithoutIndex(r, this);
   }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/QRegionInterfaceJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/QRegionInterfaceJUnitTest.java
index 07dd10b..9879e64 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/QRegionInterfaceJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/QRegionInterfaceJUnitTest.java
@@ -60,8 +60,9 @@ public class QRegionInterfaceJUnitTest {
     Query query = CacheUtils.getQueryService()
         .newQuery("select distinct * from /Portfolios.keys where toString = '1'");
     Collection result = (Collection) query.execute();
-    if (!result.iterator().next().equals("1"))
+    if (!result.iterator().next().equals("1")) {
       fail(query.getQueryString());
+    }
   }
 
   @Test
@@ -70,8 +71,9 @@ public class QRegionInterfaceJUnitTest {
         .newQuery("select distinct * from /Portfolios.values where ID = 1");
     Collection result = (Collection) query.execute();
     Portfolio p = (Portfolio) result.iterator().next();
-    if (p.getID() != 1)
+    if (p.getID() != 1) {
       fail(query.getQueryString());
+    }
   }
 
   @Test
@@ -80,8 +82,9 @@ public class QRegionInterfaceJUnitTest {
         .newQuery("select distinct * from /Portfolios.entries where value.ID = 1 and key = '1'");
     Collection result = (Collection) query.execute();
     Region.Entry entry = (Region.Entry) result.iterator().next();
-    if (!entry.getKey().equals("1") || ((Portfolio) entry.getValue()).getID() != 1)
+    if (!entry.getKey().equals("1") || ((Portfolio) entry.getValue()).getID() != 1) {
       fail(query.getQueryString());
+    }
   }
 
   @Test
@@ -91,8 +94,9 @@ public class QRegionInterfaceJUnitTest {
     for (int i = 0; i < testData.length; i++) {
       Query query = CacheUtils.getQueryService().newQuery(testData[i][0]);
       String result = query.execute().toString();
-      if (!result.equals(testData[i][1]))
+      if (!result.equals(testData[i][1])) {
         fail(query.getQueryString());
+      }
     }
   }
 
@@ -101,8 +105,9 @@ public class QRegionInterfaceJUnitTest {
     Query query = CacheUtils.getQueryService()
         .newQuery("select distinct * from /Portfolios.keySet where toString = '1'");
     Collection result = (Collection) query.execute();
-    if (!result.iterator().next().equals("1"))
+    if (!result.iterator().next().equals("1")) {
       fail(query.getQueryString());
+    }
   }
 
   @Test
@@ -110,8 +115,9 @@ public class QRegionInterfaceJUnitTest {
     Query query = CacheUtils.getQueryService().newQuery(
         "select distinct key from /Portfolios.entrySet , value.positions.values   where value.ID = 1 and key = '1'");
     Collection result = (Collection) query.execute();
-    if (!result.iterator().next().equals("1"))
+    if (!result.iterator().next().equals("1")) {
       fail(query.getQueryString());
+    }
   }
 
   @Test
@@ -121,8 +127,9 @@ public class QRegionInterfaceJUnitTest {
       Query query = CacheUtils.getQueryService().newQuery(testData[i][0]);
       String result =
           query.execute(new Object[] {CacheUtils.getRegion("/Portfolios").get("1")}).toString();
-      if (!result.equals(testData[i][1]))
+      if (!result.equals(testData[i][1])) {
         fail(query.getQueryString());
+      }
     }
   }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/StructMemberAccessJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/StructMemberAccessJUnitTest.java
index 6046a16..f144186 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/StructMemberAccessJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/functional/StructMemberAccessJUnitTest.java
@@ -129,15 +129,17 @@ public class StructMemberAccessJUnitTest {
       Object o = q.execute();
       if (o instanceof SelectResults) {
         SelectResults sr = (SelectResults) o;
-        if (sr instanceof StructSet && i != 2)
+        if (sr instanceof StructSet && i != 2) {
           fail(
               " StructMemberAccess::testResultComposition: Got StrcutSet when expecting ResultSet");
+        }
         CollectionType ct = sr.getCollectionType();
         CacheUtils.log("***Elememt Type of Colelction = " + ct.getElementType());
         CacheUtils.log((sr.getCollectionType()).getElementType().getSimpleClassName());
         List ls = sr.asList();
-        for (int j = 0; j < ls.size(); ++j)
+        for (int j = 0; j < ls.size(); ++j) {
           CacheUtils.log("Object in the resultset = " + ls.get(j).getClass());
+        }
         switch (i) {
           case 0:
             if (ct.getElementType().getSimpleClassName().equals("Portfolio")) {
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/CompiledJunctionInternalsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/CompiledJunctionInternalsJUnitTest.java
index 862cb03..06f5bc6 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/CompiledJunctionInternalsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/CompiledJunctionInternalsJUnitTest.java
@@ -2894,7 +2894,8 @@ public class CompiledJunctionInternalsJUnitTest {
   public void tearDown() throws Exception {
     CacheUtils.closeCache();
     IndexManager indexManager = ((LocalRegion) region).getIndexManager();
-    if (indexManager != null)
+    if (indexManager != null) {
       indexManager.destroy();
+    }
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/ProjectionAttributeJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/ProjectionAttributeJUnitTest.java
index c140cbc..9a50453 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/ProjectionAttributeJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/ProjectionAttributeJUnitTest.java
@@ -88,8 +88,9 @@ public class ProjectionAttributeJUnitTest {
       String qStr = queries[i];
       Query q = qs.newQuery(qStr);
       SelectResults r = (SelectResults) q.execute();
-      if (i < 4 && r.getCollectionType().getElementType().isStructType())
+      if (i < 4 && r.getCollectionType().getElementType().isStructType()) {
         fail(q.getQueryString());
+      }
 
       if (i > 3) {
         assertTrue(r.getCollectionType().getElementType().isStructType());
@@ -100,15 +101,17 @@ public class ProjectionAttributeJUnitTest {
     String qStr = "select distinct * from /pos p ";
     Query q = qs.newQuery(qStr);
     Object r = q.execute();
-    if (r instanceof StructSet)
+    if (r instanceof StructSet) {
       fail(q.getQueryString());
+    }
   }
 
   private void checkNames(SelectResults results, String query) {
     int i1 = query.indexOf(" distinct ");
     int i2 = query.indexOf(" from ");
-    if (i1 < 0 || i2 < 0)
+    if (i1 < 0 || i2 < 0) {
       fail(query);
+    }
     String projStr = query.substring(i1 + " distinct ".length(), i2);
     // CacheUtils.log("projStr = "+projStr);
     QCompiler compiler = new QCompiler();
@@ -119,18 +122,22 @@ public class ProjectionAttributeJUnitTest {
       String name = names[i];
       Object arr[] = (Object[]) projAttrs.get(i);
       String nameToMatch = "";
-      if (arr[0] != null)
+      if (arr[0] != null) {
         nameToMatch = (String) arr[0];
-      else {
-        if (arr[1] instanceof CompiledID)
+      } else {
+        if (arr[1] instanceof CompiledID) {
           nameToMatch = ((CompiledID) arr[1]).getId();
-        if (arr[1] instanceof CompiledPath)
+        }
+        if (arr[1] instanceof CompiledPath) {
           nameToMatch = ((CompiledPath) arr[1]).getTailID();
-        if (arr[1] instanceof CompiledLiteral)
+        }
+        if (arr[1] instanceof CompiledLiteral) {
           nameToMatch = (((CompiledLiteral) arr[1])._obj).toString();
+        }
       }
-      if (!nameToMatch.equals(name))
+      if (!nameToMatch.equals(name)) {
         fail(query);
+      }
     }
   }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryFromClauseCanonicalizationJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryFromClauseCanonicalizationJUnitTest.java
index 367616f..cf8bca5 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryFromClauseCanonicalizationJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryFromClauseCanonicalizationJUnitTest.java
@@ -148,8 +148,9 @@ public class QueryFromClauseCanonicalizationJUnitTest {
       }
 
     }
-    if (overallTestFailed)
+    if (overallTestFailed) {
       Assert.fail();
+    }
 
   }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryObserverCallbacksTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryObserverCallbacksTest.java
index b8194d4..df21737 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryObserverCallbacksTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryObserverCallbacksTest.java
@@ -230,8 +230,9 @@ public class QueryObserverCallbacksTest {
     @Override
     public void beforeIndexLookup(Index index, int oper, Object key) {
       dbIndx[j++] = index;
-      if (j == 3)
+      if (j == 3) {
         j = 0;
+      }
     }
 
     @Override
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryUtilsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryUtilsJUnitTest.java
index e4ce4c0..7bfc819 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryUtilsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/QueryUtilsJUnitTest.java
@@ -102,8 +102,9 @@ public class QueryUtilsJUnitTest {
     finalList.add(indexToItrMappping[0]);
     finalList.add(expand);
     ResultsSet indexResult = new ResultsSet(new ObjectTypeImpl(Portfolio.class));
-    for (int i = 0; i < po.length; ++i)
+    for (int i = 0; i < po.length; ++i) {
       indexResult.add(po[i]);
+    }
     List expandList = new LinkedList();
     expandList.add(expand);
     List dataList = new ArrayList();
@@ -164,8 +165,9 @@ public class QueryUtilsJUnitTest {
     finalList.add(indexToItrMappping[0]);
 
     ResultsSet indexResult = new ResultsSet(new ObjectTypeImpl(Portfolio.class));
-    for (int i = 0; i < po.length; ++i)
+    for (int i = 0; i < po.length; ++i) {
       indexResult.add(po[i]);
+    }
     List expandList = new LinkedList();
     expandList.add(expand[0]);
     expandList.add(expand[1]);
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/DeclarativeIndexCreationJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/DeclarativeIndexCreationJUnitTest.java
index 1baeed1..60626bf 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/DeclarativeIndexCreationJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/DeclarativeIndexCreationJUnitTest.java
@@ -79,9 +79,10 @@ public class DeclarativeIndexCreationJUnitTest {
       CacheUtils.log("List of indexes= " + im.toString());
       RegionAttributes ra = root.getAttributes();
       assertTrue(!ra.getIndexMaintenanceSynchronous());
-    } else
+    } else {
       fail(
           "DeclarativeIndexCreationJUnitTest::testAsynchronousIndexCreatedOnRoot_PortfoliosRegion:No index found in the root region");
+    }
   }
 
   @Test
@@ -94,14 +95,16 @@ public class DeclarativeIndexCreationJUnitTest {
       CacheUtils.log("List of indexes= " + im.toString());
       RegionAttributes ra = root.getAttributes();
       assertTrue(ra.getIndexMaintenanceSynchronous());
-    } else
+    } else {
       fail(
           "DeclarativeIndexCreationJUnitTest::testSynchronousIndexCreatedOnRoot_StringRegion Region:No index found in the root region");
+    }
     root = cache.getRegion("/root/string1");
     im = IndexUtils.getIndexManager((InternalCache) cache, root, true);
-    if (!im.isIndexMaintenanceTypeSynchronous())
+    if (!im.isIndexMaintenanceTypeSynchronous()) {
       fail(
           "DeclarativeIndexCreationJUnitTest::testSynchronousIndexCreatedOnRoot_StringRegion: The index update type not synchronous if no index-update-type attribuet specified in cache.cml");
+    }
   }
 
   @Test
@@ -114,8 +117,9 @@ public class DeclarativeIndexCreationJUnitTest {
       CacheUtils.log("List of indexes= " + im.toString());
       RegionAttributes ra = root.getAttributes();
       assertTrue(ra.getIndexMaintenanceSynchronous());
-    } else
+    } else {
       fail(
           "DeclarativeIndexCreationJUnitTest::testAsynchronousIndexCreatedOnRoot_PortfoliosRegion:No index found in the root region");
+    }
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/IndexManagerIntegrationTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/IndexManagerIntegrationTest.java
index c4fd7e2..346049c 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/IndexManagerIntegrationTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/IndexManagerIntegrationTest.java
@@ -232,10 +232,12 @@ public class IndexManagerIntegrationTest {
 
     @Override
     public boolean equals(Object o) {
-      if (this == o)
+      if (this == o) {
         return true;
-      if (o == null || getClass() != o.getClass())
+      }
+      if (o == null || getClass() != o.getClass()) {
         return false;
+      }
       TestQueryObject that = (TestQueryObject) o;
       return id == that.id;
     }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/ProgRegionCreationIndexUpdateTypeJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/ProgRegionCreationIndexUpdateTypeJUnitTest.java
index dacc66c..b90d3a4 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/ProgRegionCreationIndexUpdateTypeJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/cache/query/internal/index/ProgRegionCreationIndexUpdateTypeJUnitTest.java
@@ -50,8 +50,9 @@ public class ProgRegionCreationIndexUpdateTypeJUnitTest {
 
   @After
   public void tearDown() throws Exception {
-    if (!cache.isClosed())
+    if (!cache.isClosed()) {
       cache.close();
+    }
 
   }
 
@@ -69,9 +70,10 @@ public class ProgRegionCreationIndexUpdateTypeJUnitTest {
     Region region = cache.createRegion("region1", regionAttributes);
     IndexManager im = IndexUtils.getIndexManager((InternalCache) cache, region, true);
 
-    if (!im.isIndexMaintenanceTypeSynchronous())
+    if (!im.isIndexMaintenanceTypeSynchronous()) {
       fail(
           "IndexMaintenanceTest::testProgrammaticIndexUpdateType: Index Update Type found to be asynchronous when it was marked explicitly synchronous");
+    }
 
     // Create a Region with index mainteneace type as explicit asynchronous
     attributesFactory = new AttributesFactory();
@@ -79,9 +81,10 @@ public class ProgRegionCreationIndexUpdateTypeJUnitTest {
     regionAttributes = attributesFactory.create();
     region = cache.createRegion("region2", regionAttributes);
     im = IndexUtils.getIndexManager((InternalCache) cache, region, true);
-    if (im.isIndexMaintenanceTypeSynchronous())
+    if (im.isIndexMaintenanceTypeSynchronous()) {
       fail(
           "IndexMaintenanceTest::testProgrammaticIndexUpdateType: Index Update Type found to be synchronous when it was marked explicitly asynchronous");
+    }
 
     // create a default region & check index maintenecae type .It should be
     // synchronous
@@ -89,9 +92,10 @@ public class ProgRegionCreationIndexUpdateTypeJUnitTest {
     regionAttributes = attributesFactory.create();
     region = cache.createRegion("region3", regionAttributes);
     im = IndexUtils.getIndexManager((InternalCache) cache, region, true);
-    if (!im.isIndexMaintenanceTypeSynchronous())
+    if (!im.isIndexMaintenanceTypeSynchronous()) {
       fail(
           "IndexMaintenanceTest::testProgrammaticIndexUpdateType: Index Update Type found to be asynchronous when it default RegionAttributes should have created synchronous update type");
+    }
 
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGroupsMessengerJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGroupsMessengerJUnitTest.java
index 25c86a2..a9d1c69 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGroupsMessengerJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGroupsMessengerJUnitTest.java
@@ -570,8 +570,9 @@ public class JGroupsMessengerJUnitTest {
       } else {
         m.setSrc(fakeMember);
         UNICAST3.Header oldHeader = (UNICAST3.Header) m.getHeader(unicastHeaderId);
-        if (oldHeader == null)
+        if (oldHeader == null) {
           continue;
+        }
         UNICAST3.Header newHeader =
             UNICAST3.Header.createDataHeader(seqno, oldHeader.connId(), seqno == 1);
         seqno += 1;
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest.java
index 9a59707..8485589 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest.java
@@ -48,14 +48,16 @@ public class RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest {
     {
       byte[] bytesValue = new byte[] {1, 2, 3, 4};
       r.put("bytesValue", bytesValue.clone());
-      if (r.replace("bytesValue", "", ""))
+      if (r.replace("bytesValue", "", "")) {
         fail("expected replace to fail");
+      }
       if (!r.replace("bytesValue", bytesValue, "")) {
         fail("expected replace to happen");
       }
       r.put("bytesValue", bytesValue.clone());
-      if (r.remove("bytesValue", ""))
+      if (r.remove("bytesValue", "")) {
         fail("expected remove to fail");
+      }
       if (!r.remove("bytesValue", bytesValue)) {
         fail("expected remove to happen");
       }
@@ -63,14 +65,16 @@ public class RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest {
     {
       boolean[] booleanValue = new boolean[] {true, false, true, false};
       r.put("booleanValue", booleanValue.clone());
-      if (r.replace("booleanValue", "", ""))
+      if (r.replace("booleanValue", "", "")) {
         fail("expected replace to fail");
+      }
       if (!r.replace("booleanValue", booleanValue, "")) {
         fail("expected replace to happen");
       }
       r.put("booleanValue", booleanValue.clone());
-      if (r.remove("booleanValue", ""))
+      if (r.remove("booleanValue", "")) {
         fail("expected remove to fail");
+      }
       if (!r.remove("booleanValue", booleanValue)) {
         fail("expected remove to happen");
       }
@@ -78,14 +82,16 @@ public class RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest {
     {
       short[] shortValue = new short[] {1, 2, 3, 4};
       r.put("shortValue", shortValue.clone());
-      if (r.replace("shortValue", "", ""))
+      if (r.replace("shortValue", "", "")) {
         fail("expected replace to fail");
+      }
       if (!r.replace("shortValue", shortValue, "")) {
         fail("expected replace to happen");
       }
       r.put("shortValue", shortValue.clone());
-      if (r.remove("shortValue", ""))
+      if (r.remove("shortValue", "")) {
         fail("expected remove to fail");
+      }
       if (!r.remove("shortValue", shortValue)) {
         fail("expected remove to happen");
       }
@@ -93,14 +99,16 @@ public class RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest {
     {
       char[] charValue = new char[] {1, 2, 3, 4};
       r.put("charValue", charValue.clone());
-      if (r.replace("charValue", "", ""))
+      if (r.replace("charValue", "", "")) {
         fail("expected replace to fail");
+      }
       if (!r.replace("charValue", charValue, "")) {
         fail("expected replace to happen");
       }
       r.put("charValue", charValue.clone());
-      if (r.remove("charValue", ""))
+      if (r.remove("charValue", "")) {
         fail("expected remove to fail");
+      }
       if (!r.remove("charValue", charValue)) {
         fail("expected remove to happen");
       }
@@ -108,14 +116,16 @@ public class RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest {
     {
       int[] intValue = new int[] {1, 2, 3, 4};
       r.put("intValue", intValue.clone());
-      if (r.replace("intValue", "", ""))
+      if (r.replace("intValue", "", "")) {
         fail("expected replace to fail");
+      }
       if (!r.replace("intValue", intValue, "")) {
         fail("expected replace to happen");
       }
       r.put("intValue", intValue.clone());
-      if (r.remove("intValue", ""))
+      if (r.remove("intValue", "")) {
         fail("expected remove to fail");
+      }
       if (!r.remove("intValue", intValue)) {
         fail("expected remove to happen");
       }
@@ -123,14 +133,16 @@ public class RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest {
     {
       long[] longValue = new long[] {1, 2, 3, 4};
       r.put("longValue", longValue.clone());
-      if (r.replace("longValue", "", ""))
+      if (r.replace("longValue", "", "")) {
         fail("expected replace to fail");
+      }
       if (!r.replace("longValue", longValue, "")) {
         fail("expected replace to happen");
       }
       r.put("longValue", longValue.clone());
-      if (r.remove("longValue", ""))
+      if (r.remove("longValue", "")) {
         fail("expected remove to fail");
+      }
       if (!r.remove("longValue", longValue)) {
         fail("expected remove to happen");
       }
@@ -138,14 +150,16 @@ public class RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest {
     {
       float[] floatValue = new float[] {1, 2, 3, 4};
       r.put("floatValue", floatValue.clone());
-      if (r.replace("floatValue", "", ""))
+      if (r.replace("floatValue", "", "")) {
         fail("expected replace to fail");
+      }
       if (!r.replace("floatValue", floatValue, "")) {
         fail("expected replace to happen");
       }
       r.put("floatValue", floatValue.clone());
-      if (r.remove("floatValue", ""))
+      if (r.remove("floatValue", "")) {
         fail("expected remove to fail");
+      }
       if (!r.remove("floatValue", floatValue)) {
         fail("expected remove to happen");
       }
@@ -153,14 +167,16 @@ public class RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest {
     {
       double[] doubleValue = new double[] {1, 2, 3, 4};
       r.put("doubleValue", doubleValue.clone());
-      if (r.replace("doubleValue", "", ""))
+      if (r.replace("doubleValue", "", "")) {
         fail("expected replace to fail");
+      }
       if (!r.replace("doubleValue", doubleValue, "")) {
         fail("expected replace to happen");
       }
       r.put("doubleValue", doubleValue.clone());
-      if (r.remove("doubleValue", ""))
+      if (r.remove("doubleValue", "")) {
         fail("expected remove to fail");
+      }
       if (!r.remove("doubleValue", doubleValue)) {
         fail("expected remove to happen");
       }
@@ -171,14 +187,16 @@ public class RegionOperationsEqualityShouldUseArrayEqualsIntegrationTest {
       r.put("oaValue", oaValue);
       Object[] deepCloneOaValue = new Object[] {new byte[] {1, 2, 3, 4}, new short[] {1, 2, 3, 4},
           new int[] {1, 2, 3, 4}, "hello sweet world!"};
-      if (r.replace("oaValue", "", ""))
+      if (r.replace("oaValue", "", "")) {
         fail("expected replace to fail");
+      }
       if (!r.replace("oaValue", deepCloneOaValue, "")) {
         fail("expected replace to happen");
       }
       r.put("oaValue", oaValue);
-      if (r.remove("oaValue", ""))
+      if (r.remove("oaValue", "")) {
         fail("expected remove to fail");
+      }
       if (!r.remove("oaValue", deepCloneOaValue)) {
         fail("expected remove to happen");
       }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ConcurrentFlushingAndRegionOperationsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ConcurrentFlushingAndRegionOperationsJUnitTest.java
index f831576..a0e3279 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ConcurrentFlushingAndRegionOperationsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ConcurrentFlushingAndRegionOperationsJUnitTest.java
@@ -261,8 +261,9 @@ public class ConcurrentFlushingAndRegionOperationsJUnitTest extends DiskRegionTe
       public void afterWritingBytes() {
         if (!alreadyComeHere) {
           DiskEntry de = (DiskEntry) ((LocalRegion) region).basicGetEntry("Key");
-          if (de == null)
+          if (de == null) {
             return; // this is caused by the first flush
+          }
           DiskId id = de.getDiskId();
           long oldOplogId = id.getOplogId();
           long oldOplogOffset = id.getOffsetInOplog();
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ConcurrentRegionOperationsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ConcurrentRegionOperationsJUnitTest.java
index 49b64ff..b911632 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ConcurrentRegionOperationsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ConcurrentRegionOperationsJUnitTest.java
@@ -542,8 +542,9 @@ public class ConcurrentRegionOperationsJUnitTest extends DiskRegionTestingBase {
   }
 
   void validate(Region r1, Region r2) {
-    if (!this.validate)
+    if (!this.validate) {
       return;
+    }
 
     Collection entrySet = r2.entrySet();
     Iterator iterator = entrySet.iterator();
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/DiskRegRecoveryJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/DiskRegRecoveryJUnitTest.java
index 0a8462d..045a091 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/DiskRegRecoveryJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/DiskRegRecoveryJUnitTest.java
@@ -187,8 +187,9 @@ public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
      */
     if (cache != null) {
       cache.close();
-      if (logWriter.fineEnabled())
+      if (logWriter.fineEnabled()) {
         logWriter.fine("Cache closed");
+      }
     }
 
     /**
@@ -200,8 +201,9 @@ public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
       } catch (Exception e) {
         fail(" failure in creation of cache due to " + e);
       }
-      if (logWriter.fineEnabled())
+      if (logWriter.fineEnabled()) {
         logWriter.fine("Cache created to test the recovery..");
+      }
       // Create region
       diskProps.setPersistBackup(true);
       diskProps.setRegionName("RecoveryTestRegion");
@@ -236,8 +238,9 @@ public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
      */
     if (cache != null) {
       cache.close();
-      if (logWriter.fineEnabled())
+      if (logWriter.fineEnabled()) {
         logWriter.fine("Cache closed");
+      }
     }
 
     /**
@@ -249,8 +252,9 @@ public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
       } catch (Exception e) {
         fail(" failure in creation of cache due to " + e);
       }
-      if (logWriter.fineEnabled())
+      if (logWriter.fineEnabled()) {
         logWriter.fine("Cache created to test the recovery..");
+      }
       // Create region
       diskProps.setPersistBackup(true);
       diskProps.setRegionName("RecoveryTestRegion");
@@ -343,8 +347,9 @@ public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
      */
     if (cache != null) {
       cache.close();
-      if (logWriter.fineEnabled())
+      if (logWriter.fineEnabled()) {
         logWriter.fine("Cache closed");
+      }
     }
 
     /**
@@ -356,8 +361,9 @@ public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
       } catch (Exception e) {
         fail(" failure in creation of cache due to " + e);
       }
-      if (logWriter.fineEnabled())
+      if (logWriter.fineEnabled()) {
         logWriter.fine("Cache created to test the recovery..");
+      }
       // Create region
       diskProps.setPersistBackup(true);
       diskProps.setRegionName("RecoveryTestRegion");
@@ -436,8 +442,9 @@ public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
      */
     if (cache != null) {
       cache.close();
-      if (logWriter.fineEnabled())
+      if (logWriter.fineEnabled()) {
         logWriter.fine("Cache closed");
+      }
     }
 
     /**
@@ -449,8 +456,9 @@ public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
       } catch (Exception e) {
         fail(" failure in creation of cache due to " + e);
       }
-      if (logWriter.fineEnabled())
+      if (logWriter.fineEnabled()) {
         logWriter.fine("Cache created to test the recovery..");
+      }
       // Create region
       diskProps.setPersistBackup(true);
       diskProps.setRegionName("RecoveryTestRegion");
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/DiskRegionClearJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/DiskRegionClearJUnitTest.java
index c2739e8..81dc885 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/DiskRegionClearJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/DiskRegionClearJUnitTest.java
@@ -162,8 +162,9 @@ public class DiskRegionClearJUnitTest {
     }
     ThreadUtils.join(thread, 10 * 60 * 1000);
     assertTrue(counter == 3);
-    if (!cleared)
+    if (!cleared) {
       fail("clear not done although puts have been done");
+    }
   }
 
   @Test
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionCreationJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionCreationJUnitTest.java
index 3a26b40..2d9ae15 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionCreationJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionCreationJUnitTest.java
@@ -146,8 +146,9 @@ public class PartitionedRegionCreationJUnitTest {
     }
 
     // test for redundancy < 0
-    if (pr != null && !pr.isDestroyed())
+    if (pr != null && !pr.isDestroyed()) {
       pr.destroyRegion();
+    }
     redundancy = -5;
     try {
       pr = (PartitionedRegion) PartitionedRegionTestHelper.createPartitionedRegion(regionname,
@@ -278,14 +279,16 @@ public class PartitionedRegionCreationJUnitTest {
 
     Region root = (PartitionedRegionTestHelper
         .getExistingRegion(PartitionedRegionHelper.PR_ROOT_REGION_NAME));
-    if (root == null)
+    if (root == null) {
       fail("testpartionedRegionInitialization() - the "
           + PartitionedRegionHelper.PR_ROOT_REGION_NAME + " do not exists");
+    }
     RegionAttributes regionAttribs = root.getAttributes();
     Scope scope = regionAttribs.getScope();
-    if (!scope.isDistributedAck())
+    if (!scope.isDistributedAck()) {
       fail("testpartionedRegionInitialization() - the "
           + PartitionedRegionHelper.PR_ROOT_REGION_NAME + " scope is not distributed_ack");
+    }
     assertEquals(DataPolicy.REPLICATE, regionAttribs.getDataPolicy());
 
   }
@@ -307,9 +310,10 @@ public class PartitionedRegionCreationJUnitTest {
       Region region = (Region) itr.next();
       String name = ((PartitionedRegion) region).getRegionIdentifier();
       PartitionRegionConfig prConfig = (PartitionRegionConfig) root.get(name);
-      if (prConfig == null)
+      if (prConfig == null) {
         fail("testpartionedRegionRegistration() - PartionedRegion - " + name
             + " configs do not exists in  region - " + root.getName());
+      }
     }
 
   }
@@ -319,8 +323,9 @@ public class PartitionedRegionCreationJUnitTest {
    *
    */
   private void createMultiplePartitionedRegions() {
-    if (PRCreateDone)
+    if (PRCreateDone) {
       return;
+    }
     int numthread = 0;
     long giveupTime = System.currentTimeMillis() + GeodeAwaitility.getTimeout().getValueInMS();
     while (numthread < TOTAL_THREADS && giveupTime > System.currentTimeMillis()) {
@@ -344,15 +349,18 @@ public class PartitionedRegionCreationJUnitTest {
    */
   private void verifyCreateResults() {
     GeodeAwaitility.await().untilAsserted(() -> {
-      if (TOTAL_RETURNS != TOTAL_THREADS)
+      if (TOTAL_RETURNS != TOTAL_THREADS) {
         fail("Failed -- Total thread returned is not same as number of threads created");
+      }
 
-      if (TOTAL_PR_CREATED != (TOTAL_THREADS / 2))
+      if (TOTAL_PR_CREATED != (TOTAL_THREADS / 2)) {
         fail("Failed -- Total Partioned Region created is not correct.  Total created = "
             + TOTAL_PR_CREATED + " but expected " + (TOTAL_THREADS / 2));
+      }
 
-      if (TOTAL_PR_CREATION_FAIL != (TOTAL_THREADS / 2))
+      if (TOTAL_PR_CREATION_FAIL != (TOTAL_THREADS / 2)) {
         fail("Failed -- Total Partioned Region creation failures is not correct");
+      }
     });
   }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluatorIntegrationTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluatorIntegrationTest.java
index 98c3176..92439b7 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluatorIntegrationTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluatorIntegrationTest.java
@@ -91,8 +91,9 @@ public class PartitionedRegionQueryEvaluatorIntegrationTest {
     ArrayList buckList = new ArrayList();
     for (Iterator itr = n2bMap.entrySet().iterator(); itr.hasNext();) {
       Map.Entry entry = (Map.Entry) itr.next();
-      if (entry.getValue() != null)
+      if (entry.getValue() != null) {
         buckList.addAll((List) entry.getValue());
+      }
     }
     // checking size of the two lists
     assertEquals("Unexpected number of buckets", totalNoOfBuckets, buckList.size());
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionSingleNodeOperationsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionSingleNodeOperationsJUnitTest.java
index e8de2b5..f53e587 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionSingleNodeOperationsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/PartitionedRegionSingleNodeOperationsJUnitTest.java
@@ -118,8 +118,9 @@ public class PartitionedRegionSingleNodeOperationsJUnitTest {
     }
     logger.info("<ExpectedException action=remove>" + expectedExceptions + "</ExpectedException>");
 
-    if (!pr.isDestroyed())
+    if (!pr.isDestroyed()) {
       pr.destroyRegion();
+    }
 
     pr = (PartitionedRegion) PartitionedRegionTestHelper.createPartitionedRegion(regionname,
         String.valueOf(400), 0);
@@ -144,8 +145,9 @@ public class PartitionedRegionSingleNodeOperationsJUnitTest {
       assertEquals((num + 1) * 2, ((GemFireCacheImpl) pr.getCache()).getCachePerfStats().getPuts());
     }
 
-    if (!pr.isDestroyed())
+    if (!pr.isDestroyed()) {
       pr.destroyRegion();
+    }
 
     pr = (PartitionedRegion) PartitionedRegionTestHelper.createPartitionedRegion(regionname,
         String.valueOf(400), 0);
@@ -214,8 +216,9 @@ public class PartitionedRegionSingleNodeOperationsJUnitTest {
 
     for (int num = 0; num < 3; num++) {
       Object retval = pr.get(new Integer(num));
-      if (retval != null)
+      if (retval != null) {
         fail("testDestroy()- entry not destroyed  properly in destroy(key)");
+      }
     }
 
     logger.info(addExpected);
@@ -483,9 +486,10 @@ public class PartitionedRegionSingleNodeOperationsJUnitTest {
     pr.put("K1", "V1");
     pr.get("K1");
     pr.close();
-    if (!pr.isClosed || !pr.isDestroyed())
+    if (!pr.isClosed || !pr.isDestroyed()) {
       fail("testClose(): After close isClosed = " + pr.isClosed + " and isDestroyed = "
           + pr.isDestroyed());
+    }
     try {
       pr.put("K2", "V2");
       fail("testClose(): put operation completed on a closed PartitionedRegion. ");
@@ -520,9 +524,10 @@ public class PartitionedRegionSingleNodeOperationsJUnitTest {
     pr.put("K1", "V1");
     pr.get("K1");
     pr.localDestroyRegion();
-    if (pr.isClosed || !pr.isDestroyed())
+    if (pr.isClosed || !pr.isDestroyed()) {
       fail("testClose(): After close isClosed = " + pr.isClosed + " and isDestroyed = "
           + pr.isDestroyed());
+    }
     try {
       pr.put("K2", "V2");
       fail("testClose(): put operation completed on a closed PartitionedRegion. ");
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
index dd87f17..8561ddc 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
@@ -92,8 +92,9 @@ public class DiskRegionOverflowAsyncRollingOpLogJUnitTest extends DiskRegionTest
       region.get("" + i);
     }
     long endTimeGet = System.currentTimeMillis();
-    if (debug)
+    if (debug) {
       System.out.println(" done with getting 0-9999 entries fuatling in from current oplog");
+    }
 
     // Perf stats for get op
     float etGet = endTimeGet - startTimeGet;
@@ -104,8 +105,9 @@ public class DiskRegionOverflowAsyncRollingOpLogJUnitTest extends DiskRegionTest
     String statsGet =
         "etGet=" + etGet + "ms gets/sec=" + opPerSecGet + " bytes/sec=" + bytesPerSecGet;
     log.info(statsGet);
-    if (debug)
+    if (debug) {
       System.out.println("Perf Stats of get which is fauting in from current Oplog :" + statsGet);
+    }
 
   }
 
@@ -132,8 +134,9 @@ public class DiskRegionOverflowAsyncRollingOpLogJUnitTest extends DiskRegionTest
       region.get("" + i);
     }
     long endTimeGet2 = System.currentTimeMillis();
-    if (debug)
+    if (debug) {
       System.out.println(" done with getting 10000-19999 which will fault in from second oplog");
+    }
     // to fault-in entries from H-tree first verify that the rolling of oplog is
     // over
     if (((LocalRegion) region).getDiskRegion().isBackup()) {
@@ -157,8 +160,9 @@ public class DiskRegionOverflowAsyncRollingOpLogJUnitTest extends DiskRegionTest
       region.get("" + i);
     }
     long endTimeGet1 = System.currentTimeMillis();
-    if (debug)
+    if (debug) {
       System.out.println(" done with getting 0-9999 entries from H-tree");
+    }
 
     region.close(); // closes disk file which will flush all buffers
 
@@ -171,8 +175,9 @@ public class DiskRegionOverflowAsyncRollingOpLogJUnitTest extends DiskRegionTest
     String statsGet1 =
         "etGet=" + etGet1 + "ms gets/sec=" + opPerSecGet1 + " bytes/sec=" + bytesPerSecGet1;
     log.info(statsGet1);
-    if (debug)
+    if (debug) {
       System.out.println("Perf Stats of get which is fauting in from H-tree  :" + statsGet1);
+    }
 
     // Perf stats for get op (fauting in from second op log)
     float etGet2 = endTimeGet2 - startTimeGet2;
@@ -183,8 +188,9 @@ public class DiskRegionOverflowAsyncRollingOpLogJUnitTest extends DiskRegionTest
     String statsGet2 =
         "etGet=" + etGet2 + "ms gets/sec=" + opPerSecGet2 + " bytes/sec=" + bytesPerSecGet2;
     log.info(statsGet2);
-    if (debug)
+    if (debug) {
       System.out.println("Perf Stats of get which is fauting in from Second OpLog  :" + statsGet2);
+    }
     unSetCacheObserverCallBack();
   }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ha/BlockingHARQAddOperationJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ha/BlockingHARQAddOperationJUnitTest.java
index c215767..2a007c9 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ha/BlockingHARQAddOperationJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ha/BlockingHARQAddOperationJUnitTest.java
@@ -137,8 +137,9 @@ public class BlockingHARQAddOperationJUnitTest extends HARQAddOperationJUnitTest
     assertNotNull(obj);
     assertEquals(id1, obj.getEventId());
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
   }
 
   /**
@@ -194,8 +195,9 @@ public class BlockingHARQAddOperationJUnitTest extends HARQAddOperationJUnitTest
       assertNotNull(c);
     }
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
     this.logWriter.info("HARQAddOperationJUnitTest : testConcurrentBlockingTake END");
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ha/HARQAddOperationJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ha/HARQAddOperationJUnitTest.java
index 6e1f7d7..7f6f744 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ha/HARQAddOperationJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/ha/HARQAddOperationJUnitTest.java
@@ -387,8 +387,9 @@ public class HARQAddOperationJUnitTest {
     ThreadUtils.join(t1, 180 * 1000);
     ThreadUtils.join(t2, 180 * 1000);
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
 
     assertEquals(0, regionqueue.getAvailableIds().size());
     assertEquals(2, regionqueue.getLastDispatchedSequenceId(id2));
@@ -439,8 +440,9 @@ public class HARQAddOperationJUnitTest {
     ThreadUtils.join(t1, 180 * 1000);
     ThreadUtils.join(t2, 180 * 1000);
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
 
     assertEquals(0, regionqueue.getAvailableIds().size());
     assertEquals(2, regionqueue.getLastDispatchedSequenceId(id2));
@@ -524,8 +526,9 @@ public class HARQAddOperationJUnitTest {
 
     this.logWriter.info("HARQAddOperationJUnitTest : testCleanUpForConflation after join");
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
 
     assertEquals(
         "size of the conflation map should be 1 but actual size is "
@@ -597,8 +600,9 @@ public class HARQAddOperationJUnitTest {
       ThreadUtils.join(threads[k], 180 * 1000);
     }
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
 
     List pickObjects = regionqueue.peek(batchSize);
     assertEquals(batchSize, pickObjects.size());
@@ -658,8 +662,9 @@ public class HARQAddOperationJUnitTest {
       ThreadUtils.join(threads[k], 180 * 1000);
     }
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
 
     List pickObject = regionqueue.peek(batchSize);
     assertEquals(numOfThreads, pickObject.size());
@@ -723,8 +728,9 @@ public class HARQAddOperationJUnitTest {
       ThreadUtils.join(threads[k], 180 * 1000);
     }
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
 
     testFailed = false;
     message = null;
@@ -769,8 +775,9 @@ public class HARQAddOperationJUnitTest {
       ThreadUtils.join(threads_peek_remove[k], 180 * 1000);
     }
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
 
     for (int i = 0; i < numOfThreads; i++) {
       assertEquals(3,
@@ -826,8 +833,9 @@ public class HARQAddOperationJUnitTest {
       ThreadUtils.join(threads[k], 180 * 1000);
     }
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
 
     testFailed = false;
     message = null;
@@ -871,8 +879,9 @@ public class HARQAddOperationJUnitTest {
       ThreadUtils.join(threads_peek_remove[k], 180 * 1000);
     }
 
-    if (testFailed)
+    if (testFailed) {
       fail("Test failed due to " + message);
+    }
 
     assertEquals(5, regionqueue.getAvailableIds().size());
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
index a731442..fb5f6b2 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
@@ -107,8 +107,9 @@ public class ConnectionProxyJUnitTest {
     system.getLogWriter().info(removeExpectedREM);
 
     this.system.disconnect();
-    if (proxy != null)
+    if (proxy != null) {
       proxy.destroy();
+    }
   }
 
   /**
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/AbstractPoolCacheJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/AbstractPoolCacheJUnitTest.java
index 7ead2a6..81cd44e 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/AbstractPoolCacheJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/AbstractPoolCacheJUnitTest.java
@@ -77,9 +77,10 @@ public class AbstractPoolCacheJUnitTest {
     Context ctx = cache.getJNDIContext();
     GemFireBasicDataSource ds = (GemFireBasicDataSource) ctx.lookup("java:/SimpleDataSource");
     Connection conn = ds.getConnection();
-    if (conn == null)
+    if (conn == null) {
       fail(
           "DataSourceFactoryTest-testGetSimpleDataSource() Error in creating the GemFireBasicDataSource");
+    }
   }
 
   @Test
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/CleanUpJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/CleanUpJUnitTest.java
index 3d54b15..91e6492 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/CleanUpJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/CleanUpJUnitTest.java
@@ -69,9 +69,10 @@ public class CleanUpJUnitTest {
       Context ctx = cache.getJNDIContext();
       GemFireBasicDataSource ds = (GemFireBasicDataSource) ctx.lookup("java:/SimpleDataSource");
       Connection conn = ds.getConnection();
-      if (conn == null)
+      if (conn == null) {
         fail(
             "DataSourceFactoryTest-testGetSimpleDataSource() Error in creating the GemFireBasicDataSource");
+      }
     } catch (Exception e) {
       fail("Exception occurred in testGetSimpleDataSource due to " + e);
       e.printStackTrace();
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/ConnectionPoolCacheImplJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/ConnectionPoolCacheImplJUnitTest.java
index e8fdad2..f3cf84f 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/ConnectionPoolCacheImplJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/ConnectionPoolCacheImplJUnitTest.java
@@ -74,8 +74,9 @@ public class ConnectionPoolCacheImplJUnitTest {
     Context ctx = cache.getJNDIContext();
     GemFireBasicDataSource ds = (GemFireBasicDataSource) ctx.lookup("java:/SimpleDataSource");
     Connection conn = ds.getConnection();
-    if (conn == null)
+    if (conn == null) {
       fail(
           "DataSourceFactoryTest-testGetSimpleDataSource() Error in creating the GemFireBasicDataSource");
+    }
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/ConnectionPoolingJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/ConnectionPoolingJUnitTest.java
index d5ccc88..a777c6e 100755
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/ConnectionPoolingJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/ConnectionPoolingJUnitTest.java
@@ -244,8 +244,9 @@ public class ConnectionPoolingJUnitTest {
           ex.printStackTrace();
         }
       }
-      if (numConn != maxPoolSize)
+      if (numConn != maxPoolSize) {
         fail("#### Error in filling the the connection pool from " + threadName);
+      }
       ThreadB.start();
       logger.debug(" AFTER starting THREADB");
       int numC = 0;
@@ -277,8 +278,9 @@ public class ConnectionPoolingJUnitTest {
           ex.printStackTrace();
         }
       }
-      if (numC != maxPoolSize)
+      if (numC != maxPoolSize) {
         fail("#### Error in returning all the connections to the  pool from " + threadName);
+      }
       logger.debug(" ****************Returned all connections " + threadName + "***********");
     }
   }
@@ -317,8 +319,9 @@ public class ConnectionPoolingJUnitTest {
             e.printStackTrace();
           }
         }
-        if (numConn2 != maxPoolSize)
+        if (numConn2 != maxPoolSize) {
           fail("#### Error in getting all connections from the " + threadName);
+        }
         logger.debug(" ****************GOT ALL connections " + threadName + "***********");
       } catch (Exception e1) {
         e1.printStackTrace();
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/DataSourceFactoryJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/DataSourceFactoryJUnitTest.java
index eac946e..2385ee4 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/DataSourceFactoryJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/datasource/DataSourceFactoryJUnitTest.java
@@ -61,9 +61,10 @@ public class DataSourceFactoryJUnitTest {
     Context ctx = cache.getJNDIContext();
     GemFireBasicDataSource ds = (GemFireBasicDataSource) ctx.lookup("java:/SimpleDataSource");
     Connection conn = ds.getConnection();
-    if (conn == null)
+    if (conn == null) {
       fail(
           "DataSourceFactoryJUnitTest-testGetSimpleDataSource() Error in creating the GemFireBasicDataSource");
+    }
   }
 
   @Test
@@ -72,9 +73,10 @@ public class DataSourceFactoryJUnitTest {
     DataSource ds =
         (DataSource) ctx.lookup("java:/PooledDataSource");
     Connection conn = ds.getConnection();
-    if (conn == null)
+    if (conn == null) {
       fail(
           "DataSourceFactoryJUnitTest-testGetPooledDataSource() Error in creating the PooledDataSource");
+    }
   }
 
   @Test
@@ -86,8 +88,9 @@ public class DataSourceFactoryJUnitTest {
     // GemFireTransactionDataSource ds =
     // (GemFireTransactionDataSource)dsf.getTranxDataSource(map);
     Connection conn = ds.getConnection();
-    if (conn == null)
+    if (conn == null) {
       fail(
           "DataSourceFactoryJUnitTest-testGetTranxDataSource() Error in creating the getTranxDataSource");
+    }
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/jta/GlobalTransactionJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/jta/GlobalTransactionJUnitTest.java
index 1eaeb14..7023a54 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/jta/GlobalTransactionJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/jta/GlobalTransactionJUnitTest.java
@@ -73,9 +73,10 @@ public class GlobalTransactionJUnitTest {
     Context ctx = cache.getJNDIContext();
     GemFireBasicDataSource ds = (GemFireBasicDataSource) ctx.lookup("java:/SimpleDataSource");
     Connection conn = ds.getConnection();
-    if (conn == null)
+    if (conn == null) {
       fail(
           "DataSourceFactoryTest-testGetSimpleDataSource() Error in creating the GemFireBasicDataSource");
+    }
   }
 
   @Test
@@ -103,8 +104,9 @@ public class GlobalTransactionJUnitTest {
       } catch (SQLException e) {
         exceptionoccurred = true;
       }
-      if (exceptionoccurred)
+      if (exceptionoccurred) {
         fail("SQLException occurred while trying to enlist resource");
+      }
       utx.rollback();
     } catch (Exception e) {
       try {
@@ -129,8 +131,9 @@ public class GlobalTransactionJUnitTest {
       } catch (RollbackException e) {
         exceptionoccurred = true;
       }
-      if (exceptionoccurred)
+      if (exceptionoccurred) {
         fail("exception occurred while trying to register synchronization ");
+      }
       utx.rollback();
     } catch (Exception e) {
       try {
@@ -157,8 +160,9 @@ public class GlobalTransactionJUnitTest {
       } catch (SQLException e) {
         exceptionoccurred = true;
       }
-      if (!exceptionoccurred)
+      if (!exceptionoccurred) {
         fail("SQLException not occurred although the transaction was marked for rollback");
+      }
       utx.rollback();
     } catch (Exception e) {
       try {
@@ -185,8 +189,9 @@ public class GlobalTransactionJUnitTest {
       } catch (RollbackException e) {
         exceptionoccurred = true;
       }
-      if (!exceptionoccurred)
+      if (!exceptionoccurred) {
         fail("RollbackException not occurred although the transaction was marked for rollback");
+      }
       utx.rollback();
     } catch (Exception e) {
       try {
@@ -204,8 +209,9 @@ public class GlobalTransactionJUnitTest {
     utx.begin();
     tm.suspend();
     Transaction txn1 = tm.getTransaction();
-    if (txn1 != null)
+    if (txn1 != null) {
       fail("suspend failed to suspend the transaction");
+    }
   }
 
   @Test
@@ -214,8 +220,9 @@ public class GlobalTransactionJUnitTest {
     Transaction txn = tm.getTransaction();
     Transaction txn1 = tm.suspend();
     tm.resume(txn1);
-    if (txn != tm.getTransaction())
+    if (txn != tm.getTransaction()) {
       fail("resume failed ");
+    }
     utx.commit();
   }
 }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/jta/functional/CacheJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/jta/functional/CacheJUnitTest.java
index 7ebbdd4..3b80299 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/jta/functional/CacheJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/jta/functional/CacheJUnitTest.java
@@ -139,12 +139,13 @@ public class CacheJUnitTest {
       ta.rollback();
       fail(" failed " + e.getMessage());
     } finally {
-      if (conn != null)
+      if (conn != null) {
         try {
           conn.close();
         } catch (SQLException ex) {
           fail("SQL exception: " + ex.getMessage());
         }
+      }
     }
   }
 
@@ -194,22 +195,25 @@ public class CacheJUnitTest {
       }
 
     } catch (NamingException e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" failed " + e.getMessage());
     } catch (SQLException e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" failed " + e.getMessage());
     } catch (Exception e) {
       ta.rollback();
       fail(" failed " + e.getMessage());
     } finally {
-      if (conn != null)
+      if (conn != null) {
         try {
           conn.close();
         } catch (SQLException e) {
         }
+      }
     }
   }
 
@@ -291,23 +295,27 @@ public class CacheJUnitTest {
       ta.rollback();
       fail(" test 3 failed ");
     } catch (NamingException e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" test 3 failed " + e.getMessage());
     } catch (SQLException e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" test 3 failed " + e.getMessage());
     } catch (Exception e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" test 3 failed " + e.getMessage());
     } finally {
-      if (conn != null)
+      if (conn != null) {
         try {
           conn.close();
         } catch (SQLException e) {
         }
+      }
     }
   }
 
@@ -386,23 +394,27 @@ public class CacheJUnitTest {
       ta.rollback();
       fail(" failed " + e.getMessage());
     } catch (NamingException e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" failed " + e.getMessage());
     } catch (SQLException e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" failed " + e.getMessage());
     } catch (Exception e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" failed " + e.getMessage());
     } finally {
-      if (conn != null)
+      if (conn != null) {
         try {
           conn.close();
         } catch (SQLException e) {
         }
+      }
     }
   }
 
@@ -525,12 +537,13 @@ public class CacheJUnitTest {
       ta.rollback();
       fail(" failed: " + e.getMessage());
     } finally {
-      if (conn != null)
+      if (conn != null) {
         try {
           conn.close();
         } catch (SQLException ex) {
           fail("Exception: " + ex.getMessage());
         }
+      }
     }
   }
 
@@ -597,8 +610,9 @@ public class CacheJUnitTest {
       assertEquals("cache value found is: " + tok, "\"value1\"", tok);
 
     } catch (CacheExistsException e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" failed due to: " + e.getMessage());
     } catch (NamingException e) {
       ta.rollback();
@@ -607,15 +621,17 @@ public class CacheJUnitTest {
       ta.rollback();
       fail(" failed due to: " + e.getMessage());
     } catch (Exception e) {
-      if (rollback_chances)
+      if (rollback_chances) {
         ta.rollback();
+      }
       fail(" failed due to: " + e.getMessage());
     } finally {
-      if (conn != null)
+      if (conn != null) {
         try {
           conn.close();
         } catch (Exception e) {
         }
+      }
     }
   }
 
@@ -691,11 +707,12 @@ public class CacheJUnitTest {
         ta.rollback();
       }
     } finally {
-      if (conn != null)
+      if (conn != null) {
         try {
           conn.close();
         } catch (SQLException e) {
         }
+      }
     }
   }
 
@@ -758,14 +775,16 @@ public class CacheJUnitTest {
         boolean matched1 = jtaObj.checkTableAgainstData(this.tblName, (field1 + ""));
         boolean matched2 = jtaObj.checkTableAgainstData(this.tblName, (field2 + ""));
 
-        if (matched1)
+        if (matched1) {
           System.out.print("(PK " + field1 + "found ");
-        else
+        } else {
           System.out.print("(PK " + field1 + "not found ");
-        if (matched2)
+        }
+        if (matched2) {
           System.out.print("PK " + field2 + "found)");
-        else
+        } else {
           System.out.print("PK " + field2 + "not found)");
+        }
 
         if (matched1 & matched2) {
           System.out.println("ok");
@@ -782,17 +801,19 @@ public class CacheJUnitTest {
     } catch (Exception e) {
       ta.rollback();
     } finally {
-      if (conn1 != null)
+      if (conn1 != null) {
         try {
           conn1.close();
         } catch (SQLException e) {
         }
+      }
 
-      if (conn2 != null)
+      if (conn2 != null) {
         try {
           conn2.close();
         } catch (SQLException e) {
         }
+      }
     }
 
   }
@@ -875,11 +896,12 @@ public class CacheJUnitTest {
       fail(" failed due to: " + e.getMessage());
       ta.rollback();
     } finally {
-      if (conn != null)
+      if (conn != null) {
         try {
           conn.close();
         } catch (SQLException e) {
         }
+      }
     }
 
   }
@@ -904,8 +926,9 @@ public class CacheJUnitTest {
     Region re = currRegion.createSubregion("employee", fac.create());
     String retVal = (String) re.get(TABLEID); // TABLEID correspondes to
                                               // "name1".
-    if (!retVal.equals("newname"))
+    if (!retVal.equals("newname")) {
       fail("Uncommitted value 'newname' not read by cacheloader name = " + retVal);
+    }
     utx.rollback();
 
     DataSource ds = (DataSource) ctx.lookup("java:/XAPooledDataSource");
@@ -915,8 +938,9 @@ public class CacheJUnitTest {
     ResultSet rs = stm.executeQuery(str);
     rs.next();
     String str1 = rs.getString(1);
-    if (!str1.equals("name2"))
+    if (!str1.equals("name2")) {
       fail("Rollback not occurred on XAConnection got in a cache loader");
+    }
   }
 
   /**
@@ -974,8 +998,9 @@ public class CacheJUnitTest {
         } catch (SQLException e) {
           fail(" failed to drop, " + e.getMessage());
         }
-      } else
+      } else {
         fail("unable to create table");
+      }
 
       /** Code meant for Oracle DB **/
       /*
@@ -993,8 +1018,9 @@ public class CacheJUnitTest {
     } catch (Exception e) {
       fail("failed, " + e.getMessage());
     } finally {
-      if (conn != null)
+      if (conn != null) {
         conn.close();
+      }
     }
   }
 
@@ -1047,8 +1073,9 @@ public class CacheJUnitTest {
         } catch (SQLException e) {
           fail(" failed to drop, " + e.getMessage());
         }
-      } else
+      } else {
         fail("table do not exists");
+      }
 
       /*** Code meant for Oracle DB ***/
       /*
@@ -1066,11 +1093,12 @@ public class CacheJUnitTest {
     } catch (Exception e) {
       fail("failed, " + e.getMessage());
     } finally {
-      if (conn != null)
+      if (conn != null) {
         try {
           conn.close();
         } catch (SQLException e) {
         }
+      }
     }
   }
 
@@ -1140,18 +1168,20 @@ public class CacheJUnitTest {
         fail(", PK " + this.tblIDFld + " found in db)" + "   " + "rollback for conn #2 failed");
       }
     } finally {
-      if (conn1 != null)
+      if (conn1 != null) {
         try {
           conn1.close();
         } catch (SQLException ex) {
           fail(" Exception: " + ex.getMessage());
         }
-      if (conn2 != null)
+      }
+      if (conn2 != null) {
         try {
           conn2.close();
         } catch (SQLException ex) {
           fail(" Exception: " + ex.getMessage());
         }
+      }
     }
   }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/statistics/StatTypesAreRolledOverRegressionTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/statistics/StatTypesAreRolledOverRegressionTest.java
index 37e61ea..b70b445 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/statistics/StatTypesAreRolledOverRegressionTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/statistics/StatTypesAreRolledOverRegressionTest.java
@@ -147,8 +147,9 @@ public class StatTypesAreRolledOverRegressionTest {
       }
 
       for (ResourceInst resourceInstance : resources) {
-        if (resourceInstance == null)
+        if (resourceInstance == null) {
           continue;
+        }
         assertThat(resourceInstance.getName()).isNotNull();
         assertThat(resourceInstance.getType()).isNotNull();
         assertThat(resourceInstance.getType().getName()).isEqualTo(this.statisticsType.getName());
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/ConcurrentHashMapJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/ConcurrentHashMapJUnitTest.java
index 1412203..5b28482 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/ConcurrentHashMapJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/ConcurrentHashMapJUnitTest.java
@@ -677,8 +677,9 @@ public class ConcurrentHashMapJUnitTest extends JSR166TestCase { // TODO: reform
     // Adapted from a bug report by Eric Zoerner
     CustomEntryConcurrentHashMap map = new CustomEntryConcurrentHashMap(2, 5.0f, 1);
     assertTrue(map.isEmpty());
-    for (int i = 0; i < 20; i++)
+    for (int i = 0; i < 20; i++) {
       map.put(new Integer(i), new Integer(i));
+    }
     assertFalse(map.isEmpty());
     Map.Entry entry1 = (Map.Entry) map.entrySet().iterator().next();
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/CountedMapLoopsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/CountedMapLoopsJUnitTest.java
index 69f7d26..61ded4b 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/CountedMapLoopsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/CountedMapLoopsJUnitTest.java
@@ -63,23 +63,29 @@ public class CountedMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       } catch (ClassNotFoundException e) {
         throw new RuntimeException("Class " + args[0] + " not found.");
       }
-    } else
+    } else {
       mapClass = MAP_CLASS;
+    }
 
-    if (args.length > 1)
+    if (args.length > 1) {
       maxThreads = Integer.parseInt(args[1]);
+    }
 
-    if (args.length > 2)
+    if (args.length > 2) {
       nkeys = Integer.parseInt(args[2]);
+    }
 
-    if (args.length > 3)
+    if (args.length > 3) {
       pinsert = Integer.parseInt(args[3]);
+    }
 
-    if (args.length > 4)
+    if (args.length > 4) {
       premove = Integer.parseInt(args[4]);
+    }
 
-    if (args.length > 5)
+    if (args.length > 5) {
       nops = Integer.parseInt(args[5]);
+    }
 
     // normalize probabilities wrt random number generator
     removesPerMaxRandom = (int) (((double) premove / 100.0 * 0x7FFFFFFFL));
@@ -95,8 +101,9 @@ public class CountedMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
 
     final LoopHelpers.SimpleRandom rng = new LoopHelpers.SimpleRandom();
     Integer[] key = new Integer[nkeys];
-    for (int i = 0; i < key.length; ++i)
+    for (int i = 0; i < key.length; ++i) {
       key[i] = new Integer(rng.next());
+    }
 
     AtomicInteger counter;
     // warmup
@@ -108,8 +115,9 @@ public class CountedMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       CyclicBarrier barrier = new CyclicBarrier(1, timer);
       new Runner(map, key, barrier, counter).run();
       int size = map.size();
-      if (size != counter.get())
+      if (size != counter.get()) {
         throw new Error();
+      }
       map.clear();
       map = null;
       Thread.sleep(100);
@@ -123,8 +131,9 @@ public class CountedMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       counter = new AtomicInteger(0);
       LoopHelpers.BarrierTimer timer = new LoopHelpers.BarrierTimer();
       CyclicBarrier barrier = new CyclicBarrier(i + 1, timer);
-      for (int t = 0; t < i; ++t)
+      for (int t = 0; t < i; ++t) {
         pool.execute(new Runner(map, key, barrier, counter));
+      }
       barrier.await();
       barrier.await();
       long time = timer.getTime();
@@ -133,8 +142,9 @@ public class CountedMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       double secs = (double) (time) / 1000000000.0;
       System.out.println("\t " + secs + "s run time");
       int size = map.size();
-      if (size != counter.get())
+      if (size != counter.get()) {
         throw new Error();
+      }
       map.clear();
       map = null;
       // System.gc();
@@ -142,8 +152,9 @@ public class CountedMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       if (i == k) {
         k = i << 1;
         i = i + (i >>> 1);
-      } else
+      } else {
         i = k;
+      }
     }
     pool.shutdown();
   }
@@ -169,10 +180,12 @@ public class CountedMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       // random-walk around key positions, bunching accesses
       int r = rng.next();
       position += (r & 7) - 3;
-      while (position >= key.length)
+      while (position >= key.length) {
         position -= key.length;
-      while (position < 0)
+      }
+      while (position < 0) {
         position += key.length;
+      }
 
       Integer k = key[position];
       Integer x = (Integer) map.get(k);
@@ -189,8 +202,9 @@ public class CountedMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
           }
         }
       } else if (r < insertsPerMaxRandom) {
-        if (map.put(k, k) == null)
+        if (map.put(k, k) == null) {
           counter.getAndIncrement();
+        }
         return 2;
       }
 
@@ -204,8 +218,9 @@ public class CountedMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       try {
         barrier.await();
         int ops = nops;
-        while (ops > 0)
+        while (ops > 0) {
           ops -= step();
+        }
         barrier.await();
       } catch (Exception ex) {
         ex.printStackTrace();
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/IntMapCheckJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/IntMapCheckJUnitTest.java
index 6be6665..aac893a 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/IntMapCheckJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/IntMapCheckJUnitTest.java
@@ -50,8 +50,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
   static TestTimer timer = new TestTimer();
 
   static void reallyAssert(boolean b) {
-    if (!b)
+    if (!b) {
       throw new Error("Failed Assertion");
+    }
   }
 
   @Test
@@ -73,27 +74,32 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     }
 
 
-    if (args.length > 1)
+    if (args.length > 1) {
       numTests = Integer.parseInt(args[1]);
+    }
 
-    if (args.length > 2)
+    if (args.length > 2) {
       size = Integer.parseInt(args[2]);
+    }
 
     boolean doSerializeTest = args.length > 3;
 
     System.out.println("Testing " + mapClass.getName() + " trials: " + numTests + " size: " + size);
 
     absentSize = 4;
-    while (absentSize <= size)
+    while (absentSize <= size) {
       absentSize <<= 1;
+    }
     absentMask = absentSize - 1;
     absent = new Integer[absentSize];
-    for (int i = 0; i < absentSize; ++i)
+    for (int i = 0; i < absentSize; ++i) {
       absent[i] = new Integer(2 * (i - 1) + 1);
+    }
 
     Integer[] key = new Integer[size];
-    for (int i = 0; i < size; ++i)
+    for (int i = 0; i < size; ++i) {
       key[i] = new Integer(2 * i);
+    }
 
     for (int rep = 0; rep < numTests; ++rep) {
       shuffle(absent);
@@ -103,8 +109,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     TestTimer.printStats();
 
 
-    if (doSerializeTest)
+    if (doSerializeTest) {
       stest(newMap(mapClass), size);
+    }
   }
 
   static Map newMap(Class cl) {
@@ -132,8 +139,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     timer.start(nm, n * iters);
     for (int j = 0; j < iters; ++j) {
       for (int i = 0; i < n; i++) {
-        if (s.get(key[i]) != null)
+        if (s.get(key[i]) != null) {
           ++sum;
+        }
       }
     }
     timer.finish();
@@ -144,8 +152,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n);
     for (int i = 0; i < n; i++) {
-      if (s.remove(key[i]) != null)
+      if (s.remove(key[i]) != null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -157,8 +166,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     for (int i = 0; i < n; i++) {
       Integer k = key[i];
       Integer v = absent[i & absentMask];
-      if (s.put(k, v) == null)
+      if (s.put(k, v) == null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -168,8 +178,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n);
     for (int i = 0; i < n; i++) {
-      if (s.containsKey(key[i]))
+      if (s.containsKey(key[i])) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -179,8 +190,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n / 2);
     for (int i = n - 2; i >= 0; i -= 2) {
-      if (s.remove(key[i]) != null)
+      if (s.remove(key[i]) != null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -190,10 +202,12 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n * 2);
     for (int i = 0; i < n; i++) {
-      if (s.get(k1[i]) != null)
+      if (s.get(k1[i]) != null) {
         ++sum;
-      if (s.get(k2[i & absentMask]) != null)
+      }
+      if (s.get(k2[i & absentMask]) != null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == n);
@@ -203,10 +217,12 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n * 2);
     for (int i = 0; i < n; i++) {
-      if (s.containsKey(k1[i]))
+      if (s.containsKey(k1[i])) {
         ++sum;
-      if (s.containsKey(k2[i & absentMask]))
+      }
+      if (s.containsKey(k2[i & absentMask])) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == n);
@@ -216,8 +232,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n);
     for (int i = 0; i < n; i++) {
-      if (s.get(key[i]) != null)
+      if (s.get(key[i]) != null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -229,9 +246,11 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int iters = 20;
     timer.start("ContainsValue (/n)     ", iters * s.size());
     int step = absentSize / iters;
-    for (int i = 0; i < absentSize; i += step)
-      if (s.containsValue(absent[i]))
+    for (int i = 0; i < absentSize; i += step) {
+      if (s.containsValue(absent[i])) {
         ++sum;
+      }
+    }
     timer.finish();
     reallyAssert(sum != 0);
   }
@@ -242,8 +261,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     Set ks = s.keySet();
     int sum = 0;
     for (int i = 0; i < size; i++) {
-      if (ks.contains(key[i]))
+      if (ks.contains(key[i])) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -254,8 +274,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start("Iter Key               ", size);
     for (Iterator it = s.keySet().iterator(); it.hasNext();) {
-      if (it.next() != MISSING)
+      if (it.next() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -265,8 +286,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start("Iter Value             ", size);
     for (Iterator it = s.values().iterator(); it.hasNext();) {
-      if (it.next() != MISSING)
+      if (it.next() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -276,8 +298,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start("Iter Entry             ", size);
     for (Iterator it = s.entrySet().iterator(); it.hasNext();) {
-      if (it.next() != MISSING)
+      if (it.next() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -296,8 +319,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
       k = (Integer) x.getKey();
       v = (Integer) x.getValue();
       seen.put(k, k);
-      if (v != MISSING)
+      if (v != MISSING) {
         ++sum;
+      }
     }
     reallyAssert(s.containsKey(k));
     it.remove();
@@ -306,8 +330,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
       Map.Entry x = (Map.Entry) (it.next());
       Integer k2 = (Integer) x.getKey();
       seen.put(k2, k2);
-      if (k2 != MISSING)
+      if (k2 != MISSING) {
         ++sum;
+      }
     }
 
     reallyAssert(s.size() == size - 1);
@@ -332,8 +357,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
 
     timer.start("Iter Enumeration Key   ", size);
     for (Enumeration en = ht.keys(); en.hasMoreElements();) {
-      if (en.nextElement() != MISSING)
+      if (en.nextElement() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -343,8 +369,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start("Iter Enumeration Value ", size);
     for (Enumeration en = ht.elements(); en.hasMoreElements();) {
-      if (en.nextElement() != MISSING)
+      if (en.nextElement() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -357,8 +384,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     timer.start("Iterf Enumeration Key  ", size);
     Enumeration en = ht.keys();
     for (int i = 0; i < size; ++i) {
-      if (en.nextElement() != MISSING)
+      if (en.nextElement() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -369,8 +397,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     timer.start("Iterf Enumeration Value", size);
     Enumeration en = ht.elements();
     for (int i = 0; i < size; ++i) {
-      if (en.nextElement() != MISSING)
+      if (en.nextElement() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -441,8 +470,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     for (Iterator i1 = s.entrySet().iterator(); i1.hasNext();) {
       Object entry = i1.next();
-      if (es2.contains(entry))
+      if (es2.contains(entry)) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -466,12 +496,14 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     timer.start("Remove (iterator)      ", size * 2);
     Iterator s2i = s2.entrySet().iterator();
     Set es = s.entrySet();
-    while (s2i.hasNext())
+    while (s2i.hasNext()) {
       reallyAssert(es.remove(s2i.next()));
+    }
     timer.finish();
 
-    if (!s.isEmpty())
+    if (!s.isEmpty()) {
       System.out.println(s);
+    }
     reallyAssert(s.isEmpty());
 
     timer.start("Clear                  ", size);
@@ -481,8 +513,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
   }
 
   static void stest(Map s, int size) throws Exception {
-    if (!(s instanceof Serializable))
+    if (!(s instanceof Serializable)) {
       return;
+    }
     System.out.print("Serialize              : ");
 
     for (int i = 0; i < size; i++) {
@@ -505,8 +538,9 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
 
     System.out.print(time + "ms");
 
-    if (s instanceof IdentityHashMap)
+    if (s instanceof IdentityHashMap) {
       return;
+    }
     reallyAssert(s.equals(m));
   }
 
@@ -552,10 +586,11 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
         Stats stats = ((Stats) (e.getValue()));
         long n = stats.number;
         double t;
-        if (n > 0)
+        if (n > 0) {
           t = stats.sum / n;
-        else
+        } else {
           t = stats.least;
+        }
         long nano = Math.round(1000000.0 * t);
         System.out.println(e.getKey() + ": " + nano);
       }
@@ -570,16 +605,17 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
 
 
     String classify() {
-      if (name.startsWith("Get"))
+      if (name.startsWith("Get")) {
         return "Get                    ";
-      else if (name.startsWith("Put"))
+      } else if (name.startsWith("Put")) {
         return "Put                    ";
-      else if (name.startsWith("Remove"))
+      } else if (name.startsWith("Remove")) {
         return "Remove                 ";
-      else if (name.startsWith("Iter"))
+      } else if (name.startsWith("Iter")) {
         return "Iter                   ";
-      else
+      } else {
         return null;
+      }
     }
 
     void finish() {
@@ -588,26 +624,28 @@ public class IntMapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
       double timePerOp = (((double) time) / numOps) / 1000000;
 
       Object st = accum.get(name);
-      if (st == null)
+      if (st == null) {
         accum.put(name, new Stats(timePerOp));
-      else {
+      } else {
         Stats stats = (Stats) st;
         stats.sum += timePerOp;
         stats.number++;
-        if (timePerOp < stats.least)
+        if (timePerOp < stats.least) {
           stats.least = timePerOp;
+        }
       }
 
       if (cname != null) {
         st = accum.get(cname);
-        if (st == null)
+        if (st == null) {
           accum.put(cname, new Stats(timePerOp));
-        else {
+        } else {
           Stats stats = (Stats) st;
           stats.sum += timePerOp;
           stats.number++;
-          if (timePerOp < stats.least)
+          if (timePerOp < stats.least) {
             stats.least = timePerOp;
+          }
         }
       }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/MapCheckJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/MapCheckJUnitTest.java
index 5a3de33..3158cd9 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/MapCheckJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/MapCheckJUnitTest.java
@@ -52,8 +52,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
   static TestTimer timer = new TestTimer();
 
   static void reallyAssert(boolean b) {
-    if (!b)
+    if (!b) {
       throw new Error("Failed Assertion");
+    }
   }
 
   @Test
@@ -75,22 +76,26 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     }
 
 
-    if (args.length > 1)
+    if (args.length > 1) {
       numTests = Integer.parseInt(args[1]);
+    }
 
-    if (args.length > 2)
+    if (args.length > 2) {
       size = Integer.parseInt(args[2]);
+    }
 
     boolean doSerializeTest = args.length > 3;
 
     System.out.println("Testing " + mapClass.getName() + " trials: " + numTests + " size: " + size);
 
-    for (int i = 0; i < absentSize; ++i)
+    for (int i = 0; i < absentSize; ++i) {
       absent[i] = new Object();
+    }
 
     Object[] key = new Object[size];
-    for (int i = 0; i < size; ++i)
+    for (int i = 0; i < size; ++i) {
       key[i] = new Object();
+    }
 
     forceMem(size * 8);
 
@@ -101,8 +106,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     TestTimer.printStats();
 
 
-    if (doSerializeTest)
+    if (doSerializeTest) {
       stest(newMap(mapClass), size);
+    }
   }
 
   static Map newMap(Class cl) {
@@ -126,13 +132,16 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
   static void forceMem(int n) {
     // force enough memory
     Long[] junk = new Long[n];
-    for (int i = 0; i < junk.length; ++i)
+    for (int i = 0; i < junk.length; ++i) {
       junk[i] = new Long(i);
+    }
     int sum = 0;
-    for (int i = 0; i < junk.length; ++i)
+    for (int i = 0; i < junk.length; ++i) {
       sum += (int) (junk[i].longValue() + i);
-    if (sum == 0)
+    }
+    if (sum == 0) {
       System.out.println("Useless number = " + sum);
+    }
     junk = null;
     // System.gc();
   }
@@ -144,8 +153,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     timer.start(nm, n * iters);
     for (int j = 0; j < iters; ++j) {
       for (int i = 0; i < n; i++) {
-        if (s.get(key[i]) != null)
+        if (s.get(key[i]) != null) {
           ++sum;
+        }
       }
     }
     timer.finish();
@@ -156,8 +166,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n);
     for (int i = 0; i < n; i++) {
-      if (s.remove(key[i]) != null)
+      if (s.remove(key[i]) != null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -167,8 +178,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n);
     for (int i = 0; i < n; i++) {
-      if (s.put(key[i], absent[i & absentMask]) == null)
+      if (s.put(key[i], absent[i & absentMask]) == null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -178,8 +190,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n);
     for (int i = 0; i < n; i++) {
-      if (s.containsKey(key[i]))
+      if (s.containsKey(key[i])) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -189,8 +202,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n / 2);
     for (int i = n - 2; i >= 0; i -= 2) {
-      if (s.remove(key[i]) != null)
+      if (s.remove(key[i]) != null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -200,10 +214,12 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n * 2);
     for (int i = 0; i < n; i++) {
-      if (s.get(k1[i]) != null)
+      if (s.get(k1[i]) != null) {
         ++sum;
-      if (s.get(k2[i & absentMask]) != null)
+      }
+      if (s.get(k2[i & absentMask]) != null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == n);
@@ -213,10 +229,12 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n * 2);
     for (int i = 0; i < n; i++) {
-      if (s.containsKey(k1[i]))
+      if (s.containsKey(k1[i])) {
         ++sum;
-      if (s.containsKey(k2[i & absentMask]))
+      }
+      if (s.containsKey(k2[i & absentMask])) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == n);
@@ -226,8 +244,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start(nm, n);
     for (int i = 0; i < n; i++) {
-      if (s.get(key[i]) != null)
+      if (s.get(key[i]) != null) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == expect);
@@ -239,9 +258,11 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int iters = 20;
     timer.start("ContainsValue (/n)     ", iters * s.size());
     int step = absentSize / iters;
-    for (int i = 0; i < absentSize; i += step)
-      if (s.containsValue(absent[i]))
+    for (int i = 0; i < absentSize; i += step) {
+      if (s.containsValue(absent[i])) {
         ++sum;
+      }
+    }
     timer.finish();
     reallyAssert(sum != 0);
   }
@@ -252,8 +273,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     Set ks = s.keySet();
     int sum = 0;
     for (int i = 0; i < size; i++) {
-      if (ks.contains(key[i]))
+      if (ks.contains(key[i])) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -264,8 +286,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start("Iter Key               ", size);
     for (Iterator it = s.keySet().iterator(); it.hasNext();) {
-      if (it.next() != MISSING)
+      if (it.next() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -275,8 +298,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start("Iter Value             ", size);
     for (Iterator it = s.values().iterator(); it.hasNext();) {
-      if (it.next() != MISSING)
+      if (it.next() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -313,8 +337,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
       k = x.getKey();
       v = x.getValue();
       seen.put(k, k);
-      if (x != MISSING)
+      if (x != MISSING) {
         ++sum;
+      }
     }
     reallyAssert(s.containsKey(k));
     it.remove();
@@ -323,8 +348,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
       Map.Entry x = (Map.Entry) (it.next());
       Object k2 = x.getKey();
       seen.put(k2, k2);
-      if (x != MISSING)
+      if (x != MISSING) {
         ++sum;
+      }
     }
 
     reallyAssert(s.size() == size - 1);
@@ -349,8 +375,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
 
     timer.start("Iter Enumeration Key   ", size);
     for (Enumeration en = ht.keys(); en.hasMoreElements();) {
-      if (en.nextElement() != MISSING)
+      if (en.nextElement() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -360,8 +387,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     timer.start("Iter Enumeration Value ", size);
     for (Enumeration en = ht.elements(); en.hasMoreElements();) {
-      if (en.nextElement() != MISSING)
+      if (en.nextElement() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -374,8 +402,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     timer.start("Iterf Enumeration Key  ", size);
     Enumeration en = ht.keys();
     for (int i = 0; i < size; ++i) {
-      if (en.nextElement() != MISSING)
+      if (en.nextElement() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -386,8 +415,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     timer.start("Iterf Enumeration Value", size);
     Enumeration en = ht.elements();
     for (int i = 0; i < size; ++i) {
-      if (en.nextElement() != MISSING)
+      if (en.nextElement() != MISSING) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -458,8 +488,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     int sum = 0;
     for (Iterator i1 = s.entrySet().iterator(); i1.hasNext();) {
       Object entry = i1.next();
-      if (es2.contains(entry))
+      if (es2.contains(entry)) {
         ++sum;
+      }
     }
     timer.finish();
     reallyAssert(sum == size);
@@ -483,8 +514,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
     timer.start("Remove (iterator)      ", size * 2);
     Iterator s2i = s2.entrySet().iterator();
     Set es = s.entrySet();
-    while (s2i.hasNext())
+    while (s2i.hasNext()) {
       es.remove(s2i.next());
+    }
     timer.finish();
 
     reallyAssert(s.isEmpty());
@@ -496,8 +528,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
   }
 
   static void stest(Map s, int size) throws Exception {
-    if (!(s instanceof Serializable))
+    if (!(s instanceof Serializable)) {
       return;
+    }
     System.out.print("Serialize              : ");
 
     for (int i = 0; i < size; i++) {
@@ -520,8 +553,9 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
 
     System.out.print(time + "ms");
 
-    if (s instanceof IdentityHashMap)
+    if (s instanceof IdentityHashMap) {
       return;
+    }
     reallyAssert(s.equals(m));
   }
 
@@ -567,10 +601,11 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
         Stats stats = ((Stats) (e.getValue()));
         int n = stats.number;
         double t;
-        if (n > 0)
+        if (n > 0) {
           t = stats.sum / n;
-        else
+        } else {
           t = stats.least;
+        }
         long nano = Math.round(1000000.0 * t);
         System.out.println(e.getKey() + ": " + nano);
       }
@@ -585,16 +620,17 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
 
 
     String classify() {
-      if (name.startsWith("Get"))
+      if (name.startsWith("Get")) {
         return "Get                    ";
-      else if (name.startsWith("Put"))
+      } else if (name.startsWith("Put")) {
         return "Put                    ";
-      else if (name.startsWith("Remove"))
+      } else if (name.startsWith("Remove")) {
         return "Remove                 ";
-      else if (name.startsWith("Iter"))
+      } else if (name.startsWith("Iter")) {
         return "Iter                   ";
-      else
+      } else {
         return null;
+      }
     }
 
     void finish() {
@@ -603,26 +639,28 @@ public class MapCheckJUnitTest extends JSR166TestCase { // TODO: reformat
       double timePerOp = ((double) time) / numOps;
 
       Object st = accum.get(name);
-      if (st == null)
+      if (st == null) {
         accum.put(name, new Stats(timePerOp));
-      else {
+      } else {
         Stats stats = (Stats) st;
         stats.sum += timePerOp;
         stats.number++;
-        if (timePerOp < stats.least)
+        if (timePerOp < stats.least) {
           stats.least = timePerOp;
+        }
       }
 
       if (cname != null) {
         st = accum.get(cname);
-        if (st == null)
+        if (st == null) {
           accum.put(cname, new Stats(timePerOp));
-        else {
+        } else {
           Stats stats = (Stats) st;
           stats.sum += timePerOp;
           stats.number++;
-          if (timePerOp < stats.least)
+          if (timePerOp < stats.least) {
             stats.least = timePerOp;
+          }
         }
       }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/MapLoopsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/MapLoopsJUnitTest.java
index cfad60a..4bea885 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/MapLoopsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/MapLoopsJUnitTest.java
@@ -63,23 +63,29 @@ public class MapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       } catch (ClassNotFoundException e) {
         throw new RuntimeException("Class " + args[0] + " not found.");
       }
-    } else
+    } else {
       mapClass = MAP_CLASS;
+    }
 
-    if (args.length > 1)
+    if (args.length > 1) {
       maxThreads = Integer.parseInt(args[1]);
+    }
 
-    if (args.length > 2)
+    if (args.length > 2) {
       nkeys = Integer.parseInt(args[2]);
+    }
 
-    if (args.length > 3)
+    if (args.length > 3) {
       pinsert = Integer.parseInt(args[3]);
+    }
 
-    if (args.length > 4)
+    if (args.length > 4) {
       premove = Integer.parseInt(args[4]);
+    }
 
-    if (args.length > 5)
+    if (args.length > 5) {
       nops = Integer.parseInt(args[5]);
+    }
 
     // normalize probabilities wrt random number generator
     removesPerMaxRandom = (int) (((double) premove / 100.0 * 0x7FFFFFFFL));
@@ -98,16 +104,17 @@ public class MapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
     for (int i = 1; i <= maxThreads;) {
       Thread.sleep(100);
       test(i, nkeys, mapClass);
-      if (warmups > 0)
+      if (warmups > 0) {
         --warmups;
-      else if (i == k) {
+      } else if (i == k) {
         k = i << 1;
         i = i + (i >>> 1);
       } else if (i == 1 && k == 2) {
         i = k;
         warmups = 1;
-      } else
+      } else {
         i = k;
+      }
     }
     pool.shutdown();
   }
@@ -115,8 +122,9 @@ public class MapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
   static Integer[] makeKeys(int n) {
     LoopHelpers.SimpleRandom rng = new LoopHelpers.SimpleRandom();
     Integer[] key = new Integer[n];
-    for (int i = 0; i < key.length; ++i)
+    for (int i = 0; i < key.length; ++i) {
       key[i] = new Integer(rng.next());
+    }
     return key;
   }
 
@@ -140,8 +148,9 @@ public class MapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
     shuffleKeys(key);
     LoopHelpers.BarrierTimer timer = new LoopHelpers.BarrierTimer();
     CyclicBarrier barrier = new CyclicBarrier(i + 1, timer);
-    for (int t = 0; t < i; ++t)
+    for (int t = 0; t < i; ++t) {
       pool.execute(new Runner(t, map, key, barrier));
+    }
     barrier.await();
     barrier.await();
     long time = timer.getTime();
@@ -173,17 +182,20 @@ public class MapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       // random-walk around key positions, bunching accesses
       int r = rng.next();
       position += (r & 7) - 3;
-      while (position >= key.length)
+      while (position >= key.length) {
         position -= key.length;
-      while (position < 0)
+      }
+      while (position < 0) {
         position += key.length;
+      }
 
       Integer k = key[position];
       Integer x = (Integer) map.get(k);
 
       if (x != null) {
-        if (x.intValue() != k.intValue())
+        if (x.intValue() != k.intValue()) {
           throw new Error("bad mapping: " + x + " to " + k);
+        }
 
         if (r < removesPerMaxRandom) {
           if (map.remove(k) != null) {
@@ -208,8 +220,9 @@ public class MapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       try {
         barrier.await();
         int ops = nops;
-        while (ops > 0)
+        while (ops > 0) {
           ops -= step();
+        }
         barrier.await();
       } catch (Exception ex) {
         ex.printStackTrace();
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/RLJBarJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/RLJBarJUnitTest.java
index a3f729c..6974238 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/RLJBarJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/RLJBarJUnitTest.java
@@ -66,8 +66,9 @@ public class RLJBarJUnitTest extends JSR166TestCase { // TODO: reformat
         System.out.println("Quiesce " + quiesce + " msecs");
       }
     }
-    for (int k = 0; k < ITERS; ++k)
+    for (int k = 0; k < ITERS; ++k) {
       oneRun();
+    }
   }
 
   public static void oneRun() {
@@ -85,8 +86,9 @@ public class RLJBarJUnitTest extends JSR166TestCase { // TODO: reformat
       try {
         End.lock();
         try {
-          while (nDead != nThreads)
+          while (nDead != nThreads) {
             EndCondition.await();
+          }
         } finally {
           End.unlock();
         }
@@ -130,8 +132,9 @@ class Producer extends Thread {
     final ReentrantLock bar = RLJBarJUnitTest.bar;
     final ReentrantLock end = RLJBarJUnitTest.End;
     final Condition endCondition = RLJBarJUnitTest.EndCondition;
-    if (RLJBarJUnitTest.OneKey)
+    if (RLJBarJUnitTest.OneKey) {
       key = new Integer(0); // per-thread v. per iteration
+    }
 
     // The barrier has a number of interesting effects:
     // 1. It enforces full LWP provisioning on T1.
@@ -169,8 +172,9 @@ class Producer extends Thread {
     // Main execution time ... the code being timed ...
     // HashTable.get() is highly contended (serial).
     for (int loop = 1; loop < 100000; loop++) {
-      if (!RLJBarJUnitTest.OneKey)
+      if (!RLJBarJUnitTest.OneKey) {
         key = new Integer(0);
+      }
       buddiesOnline.get(key);
     }
 
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/StringMapLoopsJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/StringMapLoopsJUnitTest.java
index 81ef512..a870f91 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/StringMapLoopsJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/internal/util/concurrent/cm/StringMapLoopsJUnitTest.java
@@ -63,23 +63,29 @@ public class StringMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       } catch (ClassNotFoundException e) {
         throw new RuntimeException("Class " + args[0] + " not found.");
       }
-    } else
+    } else {
       mapClass = MAP_CLASS;
+    }
 
-    if (args.length > 1)
+    if (args.length > 1) {
       maxThreads = Integer.parseInt(args[1]);
+    }
 
-    if (args.length > 2)
+    if (args.length > 2) {
       nkeys = Integer.parseInt(args[2]);
+    }
 
-    if (args.length > 3)
+    if (args.length > 3) {
       pinsert = Integer.parseInt(args[3]);
+    }
 
-    if (args.length > 4)
+    if (args.length > 4) {
       premove = Integer.parseInt(args[4]);
+    }
 
-    if (args.length > 5)
+    if (args.length > 5) {
       nops = Integer.parseInt(args[5]);
+    }
 
     // normalize probabilities wrt random number generator
     removesPerMaxRandom = (int) (((double) premove / 100.0 * 0x7FFFFFFFL));
@@ -101,16 +107,17 @@ public class StringMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       Thread.sleep(100);
       test(i, nkeys, key, mapClass);
       shuffleKeys(key);
-      if (warmups > 0)
+      if (warmups > 0) {
         --warmups;
-      else if (i == k) {
+      } else if (i == k) {
         k = i << 1;
         i = i + (i >>> 1);
       } else if (i == 1 && k == 2) {
         i = k;
         warmups = 1;
-      } else
+      } else {
         i = k;
+      }
     }
     pool.shutdown();
   }
@@ -155,8 +162,9 @@ public class StringMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
     // map.put(key[j], key[j]);
     LoopHelpers.BarrierTimer timer = new LoopHelpers.BarrierTimer();
     CyclicBarrier barrier = new CyclicBarrier(i + 1, timer);
-    for (int t = 0; t < i; ++t)
+    for (int t = 0; t < i; ++t) {
       pool.execute(new Runner(t, map, key, barrier));
+    }
     barrier.await();
     barrier.await();
     long time = timer.getTime();
@@ -188,10 +196,12 @@ public class StringMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       // random-walk around key positions, bunching accesses
       int r = rng.next();
       position += (r & 7) - 3;
-      while (position >= key.length)
+      while (position >= key.length) {
         position -= key.length;
-      while (position < 0)
+      }
+      while (position < 0) {
         position += key.length;
+      }
 
       String k = key[position];
       String x = (String) map.get(k);
@@ -218,8 +228,9 @@ public class StringMapLoopsJUnitTest extends JSR166TestCase { // TODO: reformat
       try {
         barrier.await();
         int ops = nops;
-        while (ops > 0)
+        while (ops > 0) {
           ops -= step();
+        }
         barrier.await();
       } catch (Exception ex) {
         ex.printStackTrace();
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/management/internal/security/CliCommandsSecurityTest.java b/geode-core/src/integrationTest/java/org/apache/geode/management/internal/security/CliCommandsSecurityTest.java
index 6910b6f..d0e4e3c 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/management/internal/security/CliCommandsSecurityTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/management/internal/security/CliCommandsSecurityTest.java
@@ -62,8 +62,9 @@ public class CliCommandsSecurityTest {
     SoftAssertions softly = new SoftAssertions();
     for (TestCommand command : commands) {
       // skip query commands since query commands are only available in client shell
-      if (command.getCommand().startsWith("query"))
+      if (command.getCommand().startsWith("query")) {
         continue;
+      }
       LogService.getLogger().info("processing: " + command.getCommand());
       // for those commands that requires a permission, we expect an exception to be thrown
       // This has the potential to become flaky for commands with more than one permission.
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/pdx/AutoSerializableJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/pdx/AutoSerializableJUnitTest.java
index cb8bfc2..babd737 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/pdx/AutoSerializableJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/pdx/AutoSerializableJUnitTest.java
@@ -256,15 +256,19 @@ public class AutoSerializableJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       MyExternalizable other = (MyExternalizable) obj;
-      if (v != other.v)
+      if (v != other.v) {
         return false;
+      }
       return true;
     }
   }
@@ -361,53 +365,72 @@ public class AutoSerializableJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       PrimitiveObjectHolder other = (PrimitiveObjectHolder) obj;
       if (b == null) {
-        if (other.b != null)
+        if (other.b != null) {
           return false;
-      } else if (!b.equals(other.b))
+        }
+      } else if (!b.equals(other.b)) {
         return false;
+      }
       if (bool == null) {
-        if (other.bool != null)
+        if (other.bool != null) {
           return false;
-      } else if (!bool.equals(other.bool))
+        }
+      } else if (!bool.equals(other.bool)) {
         return false;
+      }
       if (c == null) {
-        if (other.c != null)
+        if (other.c != null) {
           return false;
-      } else if (!c.equals(other.c))
+        }
+      } else if (!c.equals(other.c)) {
         return false;
+      }
       if (d == null) {
-        if (other.d != null)
+        if (other.d != null) {
           return false;
-      } else if (!d.equals(other.d))
+        }
+      } else if (!d.equals(other.d)) {
         return false;
+      }
       if (f == null) {
-        if (other.f != null)
+        if (other.f != null) {
           return false;
-      } else if (!f.equals(other.f))
+        }
+      } else if (!f.equals(other.f)) {
         return false;
+      }
       if (i == null) {
-        if (other.i != null)
+        if (other.i != null) {
           return false;
-      } else if (!i.equals(other.i))
+        }
+      } else if (!i.equals(other.i)) {
         return false;
+      }
       if (l == null) {
-        if (other.l != null)
+        if (other.l != null) {
           return false;
-      } else if (!l.equals(other.l))
+        }
+      } else if (!l.equals(other.l)) {
         return false;
+      }
       if (s == null) {
-        if (other.s != null)
+        if (other.s != null) {
           return false;
-      } else if (!s.equals(other.s))
+        }
+      } else if (!s.equals(other.s)) {
         return false;
+      }
       return true;
     }
 
@@ -439,23 +462,30 @@ public class AutoSerializableJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       BigHolder other = (BigHolder) obj;
       if (bd == null) {
-        if (other.bd != null)
+        if (other.bd != null) {
           return false;
-      } else if (!bd.equals(other.bd))
+        }
+      } else if (!bd.equals(other.bd)) {
         return false;
+      }
       if (bi == null) {
-        if (other.bi != null)
+        if (other.bi != null) {
           return false;
-      } else if (!bi.equals(other.bi))
+        }
+      } else if (!bi.equals(other.bi)) {
         return false;
+      }
       return true;
     }
   }
@@ -478,18 +508,23 @@ public class AutoSerializableJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       CHMHolder other = (CHMHolder) obj;
       if (chm == null) {
-        if (other.chm != null)
+        if (other.chm != null) {
           return false;
-      } else if (!chm.equals(other.chm))
+        }
+      } else if (!chm.equals(other.chm)) {
         return false;
+      }
       return true;
     }
   }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/pdx/PdxInstanceFactoryJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/pdx/PdxInstanceFactoryJUnitTest.java
index c1249f4..a65fd3d 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/pdx/PdxInstanceFactoryJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/pdx/PdxInstanceFactoryJUnitTest.java
@@ -291,15 +291,19 @@ public class PdxInstanceFactoryJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       MyDS other = (MyDS) obj;
-      if (!Arrays.equals(longArray, other.longArray))
+      if (!Arrays.equals(longArray, other.longArray)) {
         return false;
+      }
       return true;
     }
   }
diff --git a/geode-core/src/integrationTest/java/org/apache/geode/pdx/PdxSerializableJUnitTest.java b/geode-core/src/integrationTest/java/org/apache/geode/pdx/PdxSerializableJUnitTest.java
index 85a0c5f..e8be567 100644
--- a/geode-core/src/integrationTest/java/org/apache/geode/pdx/PdxSerializableJUnitTest.java
+++ b/geode-core/src/integrationTest/java/org/apache/geode/pdx/PdxSerializableJUnitTest.java
@@ -1334,15 +1334,19 @@ public class PdxSerializableJUnitTest {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       LongFieldHolder other = (LongFieldHolder) obj;
-      if (v != other.v)
+      if (v != other.v) {
         return false;
+      }
       return true;
     }
 
@@ -2247,10 +2251,12 @@ public class PdxSerializableJUnitTest {
     }
 
     public boolean equals(Object obj) {
-      if (obj == null)
+      if (obj == null) {
         return false;
-      if (!(obj instanceof POS))
+      }
+      if (!(obj instanceof POS)) {
         return false;
+      }
       POS other = (POS) obj;
       return this.f == other.f;
     }
diff --git a/geode-core/src/main/java/org/apache/geode/CopyHelper.java b/geode-core/src/main/java/org/apache/geode/CopyHelper.java
index cfd0b9b..87070da 100644
--- a/geode-core/src/main/java/org/apache/geode/CopyHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/CopyHelper.java
@@ -87,32 +87,42 @@ public final class CopyHelper {
       return true;
     }
     if (o instanceof Number) {
-      if (o instanceof Integer)
+      if (o instanceof Integer) {
         return true;
-      if (o instanceof Long)
+      }
+      if (o instanceof Long) {
         return true;
-      if (o instanceof Byte)
+      }
+      if (o instanceof Byte) {
         return true;
-      if (o instanceof Short)
+      }
+      if (o instanceof Short) {
         return true;
-      if (o instanceof Float)
+      }
+      if (o instanceof Float) {
         return true;
-      if (o instanceof Double)
+      }
+      if (o instanceof Double) {
         return true;
+      }
       // subclasses of non-final classes may be mutable
-      if (o.getClass().equals(BigInteger.class))
+      if (o.getClass().equals(BigInteger.class)) {
         return true;
-      if (o.getClass().equals(BigDecimal.class))
+      }
+      if (o.getClass().equals(BigDecimal.class)) {
         return true;
+      }
     }
     if (o instanceof PdxInstance && !(o instanceof WritablePdxInstance)) {
       // no need to copy since it is immutable
       return true;
     }
-    if (o instanceof Character)
+    if (o instanceof Character) {
       return true;
-    if (o instanceof UUID)
+    }
+    if (o instanceof UUID) {
       return true;
+    }
     return false;
   }
 
@@ -155,8 +165,9 @@ public final class CopyHelper {
       } else if (o instanceof Token) {
         return o;
       } else {
-        if (isWellKnownImmutableInstance(o))
+        if (isWellKnownImmutableInstance(o)) {
           return o;
+        }
         if (o instanceof Cloneable) {
           try {
             // Note that Object.clone is protected so we need to use reflection
diff --git a/geode-core/src/main/java/org/apache/geode/GemFireCheckedException.java b/geode-core/src/main/java/org/apache/geode/GemFireCheckedException.java
index 88ae2c2..46f3329 100644
--- a/geode-core/src/main/java/org/apache/geode/GemFireCheckedException.java
+++ b/geode-core/src/main/java/org/apache/geode/GemFireCheckedException.java
@@ -66,8 +66,9 @@ public abstract class GemFireCheckedException extends Exception {
    * cause is nonexistent or unknown.
    */
   public Throwable getRootCause() {
-    if (this.getCause() == null)
+    if (this.getCause() == null) {
       return null;
+    }
     Throwable root = this.getCause();
     while (root != null) {
       if (root.getCause() == null) {
diff --git a/geode-core/src/main/java/org/apache/geode/InternalGemFireError.java b/geode-core/src/main/java/org/apache/geode/InternalGemFireError.java
index 9114c4b..ff576eb 100644
--- a/geode-core/src/main/java/org/apache/geode/InternalGemFireError.java
+++ b/geode-core/src/main/java/org/apache/geode/InternalGemFireError.java
@@ -55,8 +55,9 @@ public class InternalGemFireError extends Error {
    */
   public InternalGemFireError(Object detailMessage) {
     this("" + detailMessage);
-    if (detailMessage instanceof Throwable)
+    if (detailMessage instanceof Throwable) {
       initCause((Throwable) detailMessage);
+    }
   }
 
   /**
diff --git a/geode-core/src/main/java/org/apache/geode/SystemFailure.java b/geode-core/src/main/java/org/apache/geode/SystemFailure.java
index e04f594..ae89f19 100644
--- a/geode-core/src/main/java/org/apache/geode/SystemFailure.java
+++ b/geode-core/src/main/java/org/apache/geode/SystemFailure.java
@@ -747,8 +747,9 @@ public final class SystemFailure {
    *
    */
   private static void throwFailure() throws Error {
-    if (failure != null)
+    if (failure != null) {
       throw failure;
+    }
   }
 
   /**
diff --git a/geode-core/src/main/java/org/apache/geode/admin/AlertLevel.java b/geode-core/src/main/java/org/apache/geode/admin/AlertLevel.java
index c4a28ac..589d0b4 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/AlertLevel.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/AlertLevel.java
@@ -136,18 +136,23 @@ public class AlertLevel implements java.io.Serializable {
    */
   @Override
   public boolean equals(Object other) {
-    if (other == this)
+    if (other == this) {
       return true;
-    if (other == null)
+    }
+    if (other == null) {
       return false;
-    if (!(other instanceof AlertLevel))
+    }
+    if (!(other instanceof AlertLevel)) {
       return false;
+    }
     final AlertLevel that = (AlertLevel) other;
 
-    if (this.severity != that.severity)
+    if (this.severity != that.severity) {
       return false;
-    if (this.name != null && !this.name.equals(that.name))
+    }
+    if (this.name != null && !this.name.equals(that.name)) {
       return false;
+    }
 
     return true;
   }
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberType.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberType.java
index 1aa9e92..666e36c 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberType.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberType.java
@@ -126,15 +126,19 @@ public class SystemMemberType implements java.io.Serializable {
    */
   @Override
   public boolean equals(Object other) {
-    if (other == this)
+    if (other == this) {
       return true;
-    if (other == null)
+    }
+    if (other == null) {
       return false;
-    if (!(other instanceof SystemMemberType))
+    }
+    if (!(other instanceof SystemMemberType)) {
       return false;
+    }
     final SystemMemberType that = (SystemMemberType) other;
-    if (this.ordinal != that.ordinal)
+    if (this.ordinal != that.ordinal) {
       return false;
+    }
     return true;
   }
 
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/AdminDistributedSystemImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/AdminDistributedSystemImpl.java
index 5536bbe..87cc7dd 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/AdminDistributedSystemImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/AdminDistributedSystemImpl.java
@@ -484,13 +484,15 @@ public class AdminDistributedSystemImpl implements org.apache.geode.admin.AdminD
    */
   @Override
   public boolean isRunning() {
-    if (this.gfManagerAgent == null)
+    if (this.gfManagerAgent == null) {
       return false;
+    }
     // is there a better way??
     // this.gfManagerAgent.isConnected() ... this.gfManagerAgent.isListening()
 
-    if (isAnyMemberRunning())
+    if (isAnyMemberRunning()) {
       return true;
+    }
     return false;
   }
 
@@ -912,8 +914,9 @@ public class AdminDistributedSystemImpl implements org.apache.geode.admin.AdminD
   @Override
   public boolean waitToBeConnected(long timeout) throws InterruptedException {
 
-    if (Thread.interrupted())
+    if (Thread.interrupted()) {
       throw new InterruptedException();
+    }
 
     checkConnectCalled();
 
@@ -1555,8 +1558,9 @@ public class AdminDistributedSystemImpl implements org.apache.geode.admin.AdminD
    * @return the system member that was removed; null if no match was found
    */
   protected SystemMember removeSystemMember(InternalDistributedMember internalId) {
-    if (internalId == null)
+    if (internalId == null) {
       return null;
+    }
 
     boolean found = false;
     SystemMemberImpl member = null;
@@ -1962,8 +1966,9 @@ public class AdminDistributedSystemImpl implements org.apache.geode.admin.AdminD
   @Override
   public CacheVm[] getCacheVms() throws AdminException {
     Collection coll = getCacheVmsCollection();
-    if (coll == null)
+    if (coll == null) {
       return null;
+    }
     CacheVm[] array = new CacheVm[coll.size()];
     coll.toArray(array);
     return array;
@@ -1972,8 +1977,9 @@ public class AdminDistributedSystemImpl implements org.apache.geode.admin.AdminD
   @Override
   public CacheServer[] getCacheServers() throws AdminException {
     Collection coll = getCacheVmsCollection();
-    if (coll == null)
+    if (coll == null) {
       return null;
+    }
     CacheServer[] array = new CacheServer[coll.size()];
     coll.toArray(array);
     return array;
@@ -2044,8 +2050,9 @@ public class AdminDistributedSystemImpl implements org.apache.geode.admin.AdminD
   @Override
   public SystemMember lookupSystemMember(DistributedMember distributedMember)
       throws AdminException {
-    if (distributedMember == null)
+    if (distributedMember == null) {
       return null;
+    }
     SystemMember[] members = getSystemMemberApplications();
     for (int i = 0; i < members.length; i++) {
       if (distributedMember.equals(members[i].getDistributedMember())) {
@@ -2179,8 +2186,9 @@ public class AdminDistributedSystemImpl implements org.apache.geode.admin.AdminD
     @Override
     public Object get() throws InterruptedException, ExecutionException {
 
-      if (Thread.interrupted())
+      if (Thread.interrupted()) {
         throw new InterruptedException();
+      }
       try {
         return super.get();
 
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemConfigImpl.java
index 3dcf91d..2e859ca 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemConfigImpl.java
@@ -836,8 +836,9 @@ public class DistributedSystemConfigImpl implements DistributedSystemConfig {
   private void addCacheServerConfig(CacheServerConfig managerConfig) {
     checkReadOnly();
 
-    if (managerConfig == null)
+    if (managerConfig == null) {
       return;
+    }
     for (Iterator iter = this.cacheServerConfigs.iterator(); iter.hasNext();) {
       CacheServerConfigImpl impl = (CacheServerConfigImpl) iter.next();
       if (impl.equals(managerConfig)) {
@@ -1189,8 +1190,9 @@ public class DistributedSystemConfigImpl implements DistributedSystemConfig {
   public String toString() {
     StringBuffer buf = new StringBuffer(1000);
     String lf = System.getProperty("line.separator");
-    if (lf == null)
+    if (lf == null) {
       lf = ",";
+    }
 
     buf.append("DistributedSystemConfig(");
     buf.append(lf);
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthEvaluator.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthEvaluator.java
index d3934da..34d4660 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthEvaluator.java
@@ -146,8 +146,9 @@ class DistributedSystemHealthEvaluator extends AbstractHealthEvaluator
   @Override
   public void memberDeparted(DistributionManager distributionManager, InternalDistributedMember id,
       boolean crashed) {
-    if (!crashed)
+    if (!crashed) {
       return;
+    }
     synchronized (this) {
       int kind = id.getVmKind();
       switch (kind) {
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorImpl.java
index 419cf60..ec62028 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorImpl.java
@@ -143,8 +143,9 @@ public class DistributionLocatorImpl implements DistributionLocator, InternalMan
   @Override
   public boolean waitToStart(long timeout) throws InterruptedException {
 
-    if (Thread.interrupted())
+    if (Thread.interrupted()) {
       throw new InterruptedException();
+    }
 
     long start = System.currentTimeMillis();
     while (System.currentTimeMillis() - start < timeout) {
@@ -166,8 +167,9 @@ public class DistributionLocatorImpl implements DistributionLocator, InternalMan
   @Override
   public boolean waitToStop(long timeout) throws InterruptedException {
 
-    if (Thread.interrupted())
+    if (Thread.interrupted()) {
       throw new InterruptedException();
+    }
 
     long start = System.currentTimeMillis();
     while (System.currentTimeMillis() - start < timeout) {
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/EnabledManagedEntityController.java b/geode-core/src/main/java/org/apache/geode/admin/internal/EnabledManagedEntityController.java
index 9bf7265..47aa5ca 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/EnabledManagedEntityController.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/EnabledManagedEntityController.java
@@ -83,13 +83,15 @@ class EnabledManagedEntityController implements ManagedEntityController {
    * Returns <code>true</code> if the <code>output</code> string contains a known error message.
    */
   private boolean outputIsError(String output) {
-    if (output == null)
+    if (output == null) {
       return false;
+    }
     boolean error = false;
     for (int i = 0; i < ERROR_OUTPUTS.length; i++) {
       error = output.indexOf(ERROR_OUTPUTS[i]) > -1;
-      if (error)
+      if (error) {
         return error;
+      }
     }
     return error;
   }
@@ -257,8 +259,9 @@ class EnabledManagedEntityController implements ManagedEntityController {
   @Override
   public String buildSSLArguments(DistributedSystemConfig config) {
     Properties sslProps = buildSSLProperties(config, true);
-    if (sslProps == null)
+    if (sslProps == null) {
       return null;
+    }
 
     StringBuffer sb = new StringBuffer();
     for (Iterator iter = sslProps.keySet().iterator(); iter.hasNext();) {
@@ -278,12 +281,14 @@ class EnabledManagedEntityController implements ManagedEntityController {
    *        prepended so the argument will become -Dgemfire.xxxx
    */
   private Properties buildSSLProperties(DistributedSystemConfig config, boolean forCommandLine) {
-    if (!config.isSSLEnabled())
+    if (!config.isSSLEnabled()) {
       return null;
+    }
 
     String prefix = "";
-    if (forCommandLine)
+    if (forCommandLine) {
       prefix = GeodeGlossary.GEMFIRE_PREFIX;
+    }
 
     Properties sslProps = (Properties) config.getSSLProperties().clone();
     // add ssl-enabled, etc...
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedSystemMemberImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedSystemMemberImpl.java
index 310359b..112627a 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedSystemMemberImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedSystemMemberImpl.java
@@ -168,8 +168,9 @@ public abstract class ManagedSystemMemberImpl extends SystemMemberImpl
   @Override
   public boolean waitToStart(long timeout) throws InterruptedException {
 
-    if (Thread.interrupted())
+    if (Thread.interrupted()) {
       throw new InterruptedException();
+    }
 
     long start = System.currentTimeMillis();
     while (System.currentTimeMillis() - start < timeout) {
@@ -194,8 +195,9 @@ public abstract class ManagedSystemMemberImpl extends SystemMemberImpl
   @Override
   public boolean waitToStop(long timeout) throws InterruptedException {
 
-    if (Thread.interrupted())
+    if (Thread.interrupted()) {
       throw new InterruptedException();
+    }
     long start = System.currentTimeMillis();
     while (System.currentTimeMillis() - start < timeout) {
       synchronized (this.stateChange) {
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberImpl.java
index 52d7f2d..1ddd5b4 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberImpl.java
@@ -185,10 +185,12 @@ public class SystemMemberImpl implements org.apache.geode.admin.SystemMember,
     GemFireVM vm = getGemFireVM();
     if (vm != null) {
       String[] log = vm.getSystemLogs();
-      if (log != null && log.length > 0)
+      if (log != null && log.length > 0) {
         mainTail = log[0];
-      if (log != null && log.length > 1)
+      }
+      if (log != null && log.length > 1) {
         childTail = log[1];
+      }
     }
 
     if (childTail == null && mainTail == null) {
@@ -210,16 +212,18 @@ public class SystemMemberImpl implements org.apache.geode.admin.SystemMember,
   @Override
   public java.util.Properties getLicense() {
     GemFireVM vm = getGemFireVM();
-    if (vm == null)
+    if (vm == null) {
       return null;
+    }
     return new Properties();
   }
 
   @Override
   public String getVersion() {
     GemFireVM vm = getGemFireVM();
-    if (vm == null)
+    if (vm == null) {
       return null;
+    }
     return vm.getVersionInfo();
   }
 
@@ -256,8 +260,9 @@ public class SystemMemberImpl implements org.apache.geode.admin.SystemMember,
   @Override
   public SystemMemberCache getCache() throws org.apache.geode.admin.AdminException {
     GemFireVM vm = getGemFireVM(); // fix for bug 33505
-    if (vm == null)
+    if (vm == null) {
       return null;
+    }
     try {
       return createSystemMemberCache(vm);
 
@@ -272,8 +277,9 @@ public class SystemMemberImpl implements org.apache.geode.admin.SystemMember,
   @Override
   public void refreshConfig() throws org.apache.geode.admin.AdminException {
     GemFireVM vm = getGemFireVM();
-    if (vm == null)
+    if (vm == null) {
       return;
+    }
     refreshConfig(vm.getConfig());
   }
 
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AdminDistributedSystemJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AdminDistributedSystemJmxImpl.java
index 931ba18..5e18dca 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AdminDistributedSystemJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AdminDistributedSystemJmxImpl.java
@@ -739,8 +739,9 @@ public class AdminDistributedSystemJmxImpl extends AdminDistributedSystemImpl
   @Override
   public boolean waitToBeConnected(long timeout) throws InterruptedException {
 
-    if (Thread.interrupted())
+    if (Thread.interrupted()) {
       throw new InterruptedException();
+    }
     try {
       return super.waitToBeConnected(timeout);
     } catch (java.lang.RuntimeException e) {
@@ -958,8 +959,9 @@ public class AdminDistributedSystemJmxImpl extends AdminDistributedSystemImpl
       throws AdminException, MalformedObjectNameException {
     try {
       SystemMember member = lookupSystemMember(distributedMember);
-      if (member == null)
+      if (member == null) {
         return null;
+      }
       SystemMemberJmxImpl jmx = (SystemMemberJmxImpl) member;
       ObjectName oname = new ObjectName(jmx.getMBeanName());
       return oname;
@@ -1624,18 +1626,20 @@ public class AdminDistributedSystemJmxImpl extends AdminDistributedSystemImpl
           new Object[] {ex.getClass().getName(), statAlertDefnSerFile}),
           ex);
     } finally {
-      if (foStr != null)
+      if (foStr != null) {
         try {
           foStr.close();
         } catch (IOException ex) {
           ;
         }
-      if (ooStr != null)
+      }
+      if (ooStr != null) {
         try {
           ooStr.close();
         } catch (IOException ex) {
           ;
         }
+      }
     }
   }
 
@@ -1984,8 +1988,9 @@ public class AdminDistributedSystemJmxImpl extends AdminDistributedSystemImpl
     for (int i = 0; i < alerts.length; i++) {
       alert = alerts[i];
 
-      if (getAlertDefinition(alert.getDefinitionId()) == null)
+      if (getAlertDefinition(alert.getDefinitionId()) == null) {
         continue; // Ignore any removed AlertDefns
+      }
 
       /*
        * 1. check if it's system-wide. 2. if system-wide keep, it in a collection (that should get
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentImpl.java
index eeb1cb8..d4d93c9 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentImpl.java
@@ -902,8 +902,9 @@ public class AgentImpl implements org.apache.geode.admin.jmx.Agent,
    * Stops the HttpAdaptor and its XsltProcessor. Unregisters the associated MBeans.
    */
   private void stopHttpAdaptor() {
-    if (!this.agentConfig.isHttpEnabled())
+    if (!this.agentConfig.isHttpEnabled()) {
       return;
+    }
 
     // stop the adaptor...
     try {
@@ -922,8 +923,9 @@ public class AgentImpl implements org.apache.geode.admin.jmx.Agent,
 
   /** Stops the RMIConnectorServer and unregisters its MBean. */
   private void stopRMIConnectorServer() {
-    if (!this.agentConfig.isRmiEnabled())
+    if (!this.agentConfig.isRmiEnabled()) {
       return;
+    }
 
     // stop the RMI Connector server...
     try {
@@ -962,8 +964,9 @@ public class AgentImpl implements org.apache.geode.admin.jmx.Agent,
 
   /** Stops the SnmpAdaptor and unregisters its MBean. */
   private void stopSnmpAdaptor() {
-    if (!this.agentConfig.isSnmpEnabled())
+    if (!this.agentConfig.isSnmpEnabled()) {
       return;
+    }
 
     // stop the SnmpAdaptor...
     try {
@@ -1103,8 +1106,9 @@ public class AgentImpl implements org.apache.geode.admin.jmx.Agent,
    * If {@link AgentConfig#isRmiEnabled} returns false, then this adaptor will not be started.
    */
   private void startRMIConnectorServer() {
-    if (!this.agentConfig.isRmiEnabled())
+    if (!this.agentConfig.isRmiEnabled()) {
       return;
+    }
 
     String rmiBindAddress = this.agentConfig.getRmiBindAddress();
 
@@ -1213,8 +1217,9 @@ public class AgentImpl implements org.apache.geode.admin.jmx.Agent,
    * If {@link AgentConfig#isSnmpEnabled} returns false, then this adaptor will not be started.
    */
   private void startSnmpAdaptor() {
-    if (!this.agentConfig.isSnmpEnabled())
+    if (!this.agentConfig.isSnmpEnabled()) {
       return;
+    }
     try {
       ObjectName objName = getSnmpAdaptorName();
 
@@ -1276,8 +1281,9 @@ public class AgentImpl implements org.apache.geode.admin.jmx.Agent,
    * If {@link AgentConfig#isHttpEnabled} returns false, then this adaptor will not be started.
    */
   private void startHttpAdaptor() {
-    if (!this.agentConfig.isHttpEnabled())
+    if (!this.agentConfig.isHttpEnabled()) {
       return;
+    }
     try {
       ObjectName objName = getHttpAdaptorName();
 
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/CacheServerJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/CacheServerJmxImpl.java
index 32aa992..5f0522d 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/CacheServerJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/CacheServerJmxImpl.java
@@ -114,8 +114,9 @@ public class CacheServerJmxImpl extends CacheServerImpl
 
     // Refresh Interval
     AdminDistributedSystemJmxImpl sysJmx = (AdminDistributedSystemJmxImpl) system;
-    if (sysJmx.getRefreshInterval() > 0)
+    if (sysJmx.getRefreshInterval() > 0) {
       this.refreshInterval = sysJmx.getRefreshInterval();
+    }
   }
 
   @Override
@@ -275,8 +276,9 @@ public class CacheServerJmxImpl extends CacheServerImpl
     boolean isRegistered = MBeanUtil.isRefreshNotificationRegistered(this,
         RefreshNotificationType.SYSTEM_MEMBER_CONFIG);
 
-    if (isRegistered && (getRefreshInterval() == refreshInterval))
+    if (isRegistered && (getRefreshInterval() == refreshInterval)) {
       return;
+    }
 
     this.refreshInterval = Helper.setAndReturnRefreshInterval(this, refreshInterval);
   }
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
index 63eb64d..932e231 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
@@ -704,8 +704,9 @@ public class MBeanUtil {
             ObjectName objectName = serverNotification.getMBeanName();
             synchronized (MBeanUtil.managedResources) {
               Object entry = MBeanUtil.managedResources.get(objectName);
-              if (entry == null)
+              if (entry == null) {
                 return;
+              }
               if (!(entry instanceof ManagedResource)) {
                 throw new ClassCastException(String.format("%s is not a ManagedResource",
                     new Object[] {entry.getClass().getName()}));
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JModelMBean.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JModelMBean.java
index 04b457a..0d86675 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JModelMBean.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JModelMBean.java
@@ -94,11 +94,12 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   }
 
   public MX4JModelMBean(ModelMBeanInfo info) throws MBeanException, RuntimeOperationsException {
-    if (info == null)
+    if (info == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "ModelMBeanInfo parameter cannot be null."));
-    else
+    } else {
       setModelMBeanInfo(info);
+    }
   }
 
   private Logger getLogger() {
@@ -118,8 +119,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
 
   @Override
   public void postRegister(Boolean registrationDone) {
-    if (!registrationDone.booleanValue())
+    if (!registrationDone.booleanValue()) {
       clear();
+    }
   }
 
   @Override
@@ -142,25 +144,29 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   @Override
   public void setModelMBeanInfo(ModelMBeanInfo modelMBeanInfo)
       throws MBeanException, RuntimeOperationsException {
-    if (modelMBeanInfo == null)
+    if (modelMBeanInfo == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "ModelMBeanInfo cannot be null."));
-    if (!isModelMBeanInfoValid(modelMBeanInfo))
+    }
+    if (!isModelMBeanInfoValid(modelMBeanInfo)) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "ModelMBeanInfo is invalid."));
+    }
 
     m_modelMBeanInfo = (ModelMBeanInfo) modelMBeanInfo.clone();
 
     Logger logger = getLogger();
-    if (logger.isEnabledFor(Logger.DEBUG))
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("ModelMBeanInfo successfully set to: " + m_modelMBeanInfo);
+    }
     // Only now the MBean can be registered in the MBeanServer
     m_canBeRegistered = true;
   }
 
   private boolean isModelMBeanInfoValid(ModelMBeanInfo info) {
-    if (info == null || info.getClassName() == null)
+    if (info == null || info.getClassName() == null) {
       return false;
+    }
     // PENDING: maybe more checks are needed
     return true;
   }
@@ -168,15 +174,18 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   @Override
   public void setManagedResource(Object resource, String resourceType) throws MBeanException,
       RuntimeOperationsException, InstanceNotFoundException, InvalidTargetObjectTypeException {
-    if (resource == null)
+    if (resource == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Managed resource cannot be null."));
-    if (!isResourceTypeSupported(resourceType))
+    }
+    if (!isResourceTypeSupported(resourceType)) {
       throw new InvalidTargetObjectTypeException(resourceType);
+    }
 
     Logger logger = getLogger();
-    if (logger.isEnabledFor(Logger.DEBUG))
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Setting managed resource to be: " + resource);
+    }
     m_managedResource = resource;
   }
 
@@ -198,9 +207,10 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   public void addAttributeChangeNotificationListener(NotificationListener listener,
       String attributeName, Object handback)
       throws MBeanException, RuntimeOperationsException, IllegalArgumentException {
-    if (listener == null)
+    if (listener == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Listener cannot be null."));
+    }
     AttributeChangeNotificationFilter filter = new AttributeChangeNotificationFilter();
     if (attributeName != null) {
       filter.enableAttribute(attributeName);
@@ -215,9 +225,10 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     getAttributeChangeBroadcaster().addNotificationListener(listener, filter, handback);
 
     Logger logger = getLogger();
-    if (logger.isEnabledFor(Logger.DEBUG))
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Listener " + listener + " for attribute " + attributeName
           + " added successfully, handback is " + handback);
+    }
   }
 
   @Override
@@ -245,9 +256,10 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   private void removeAttributeChangeNotificationListener(NotificationListener listener,
       String attributeName, Object handback)
       throws MBeanException, RuntimeOperationsException, ListenerNotFoundException {
-    if (listener == null)
+    if (listener == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Listener cannot be null."));
+    }
     AttributeChangeNotificationFilter filter = new AttributeChangeNotificationFilter();
     if (attributeName != null) {
       filter.enableAttribute(attributeName);
@@ -262,9 +274,10 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     getAttributeChangeBroadcaster().removeNotificationListener(listener, filter, handback);
 
     Logger logger = getLogger();
-    if (logger.isEnabledFor(Logger.DEBUG))
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Listener " + listener + " for attribute " + attributeName
           + " removed successfully, handback is " + handback);
+    }
   }
 
   @Override
@@ -282,12 +295,14 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   @Override
   public void sendAttributeChangeNotification(Attribute oldAttribute, Attribute newAttribute)
       throws MBeanException, RuntimeOperationsException {
-    if (oldAttribute == null || newAttribute == null)
+    if (oldAttribute == null || newAttribute == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Attribute cannot be null."));
-    if (!oldAttribute.getName().equals(newAttribute.getName()))
+    }
+    if (!oldAttribute.getName().equals(newAttribute.getName())) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Attribute names cannot be different."));
+    }
 
     // TODO: the source must be the object name of the MBean if the listener was registered through
     // MBeanServer
@@ -301,20 +316,24 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   @Override
   public void sendAttributeChangeNotification(AttributeChangeNotification notification)
       throws MBeanException, RuntimeOperationsException {
-    if (notification == null)
+    if (notification == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Notification cannot be null."));
+    }
 
     getAttributeChangeBroadcaster().sendNotification(notification);
 
     Logger modelMBeanLogger = getModelMBeanLogger(notification.getType());
-    if (modelMBeanLogger != null)
-      if (modelMBeanLogger.isEnabledFor(Logger.DEBUG))
+    if (modelMBeanLogger != null) {
+      if (modelMBeanLogger.isEnabledFor(Logger.DEBUG)) {
         modelMBeanLogger.debug("ModelMBean log: " + new Date() + " - " + notification);
+      }
+    }
 
     Logger logger = getLogger();
-    if (logger.isEnabledFor(Logger.DEBUG))
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Attribute change notification " + notification + " sent");
+    }
   }
 
   @Override
@@ -333,9 +352,10 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
 
   @Override
   public AttributeList getAttributes(String[] attributes) {
-    if (attributes == null)
+    if (attributes == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Attribute names cannot be null."));
+    }
 
     Logger logger = getLogger();
 
@@ -348,8 +368,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
         attribute = new Attribute(attrName, value);
         list.add(attribute);
       } catch (Exception x) {
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("getAttribute for attribute " + attrName + " failed", x);
+        }
         // And go on with the next attribute
       }
     }
@@ -359,48 +380,58 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   @Override
   public Object getAttribute(String attribute)
       throws AttributeNotFoundException, MBeanException, ReflectionException {
-    if (attribute == null)
+    if (attribute == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Attribute name cannot be null."));
+    }
 
     Logger logger = getLogger();
 
     // I want the real info, not its clone
     ModelMBeanInfo info = getModelMBeanInfo();
-    if (info == null)
+    if (info == null) {
       throw new AttributeNotFoundException(
           "ModelMBeanInfo is null");
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("ModelMBeanInfo is: " + info);
+    }
 
     // This is a clone, we use it read only
     ModelMBeanAttributeInfo attrInfo = info.getAttribute(attribute);
-    if (attrInfo == null)
+    if (attrInfo == null) {
       throw new AttributeNotFoundException(
           String.format("Cannot find ModelMBeanAttributeInfo for attribute %s",
               attribute));
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Attribute info is: " + attrInfo);
-    if (!attrInfo.isReadable())
+    }
+    if (!attrInfo.isReadable()) {
       throw new AttributeNotFoundException(
           String.format("Attribute %s is not readable", attribute));
+    }
 
     // This returns a clone of the mbean descriptor, we use it read only
     Descriptor mbeanDescriptor = info.getMBeanDescriptor();
-    if (mbeanDescriptor == null)
+    if (mbeanDescriptor == null) {
       throw new AttributeNotFoundException(
           "MBean descriptor cannot be null");
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("MBean descriptor is: " + mbeanDescriptor);
+    }
 
     // This descriptor is a clone
     Descriptor attributeDescriptor = attrInfo.getDescriptor();
-    if (attributeDescriptor == null)
+    if (attributeDescriptor == null) {
       throw new AttributeNotFoundException(
           String.format("Attribute descriptor for attribute %s cannot be null",
               attribute));
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Attribute descriptor is: " + attributeDescriptor);
+    }
 
     Object returnValue = null;
 
@@ -409,12 +440,14 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     int staleness = getStaleness(attributeDescriptor, mbeanDescriptor, lastUpdateField);
 
     if (staleness == ALWAYS_STALE || staleness == STALE) {
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("Value is stale");
+      }
 
       String getter = (String) attributeDescriptor.getFieldValue("getMethod");
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("getMethod field is: " + getter);
+      }
       if (getter == null) {
         // No getter, use default value
         returnValue = attributeDescriptor.getFieldValue("default");
@@ -428,17 +461,20 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
           checkAssignability(returned, declared);
         }
 
-        if (logger.isEnabledFor(Logger.DEBUG))
+        if (logger.isEnabledFor(Logger.DEBUG)) {
           logger.debug(
               "getAttribute for attribute " + attribute + " returns default value: " + returnValue);
+        }
       } else {
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Invoking attribute getter...");
+        }
         // As an extension, allow attributes to be called on target objects also
         Object target = resolveTargetObject(attributeDescriptor);
         returnValue = invokeMethod(target, getter, new Class[0], new Object[0]);
-        if (logger.isEnabledFor(Logger.DEBUG))
+        if (logger.isEnabledFor(Logger.DEBUG)) {
           logger.debug("Returned value is: " + returnValue);
+        }
 
         if (returnValue != null) {
           // Check if the return type is of the same type
@@ -453,16 +489,18 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
         if (staleness != ALWAYS_STALE) {
           attributeDescriptor.setField("value", returnValue);
           attributeDescriptor.setField(lastUpdateField, Long.valueOf(System.currentTimeMillis()));
-          if (logger.isEnabledFor(Logger.TRACE))
+          if (logger.isEnabledFor(Logger.TRACE)) {
             logger.trace("Returned value has been cached");
+          }
 
           // And now replace the descriptor with the updated clone
           info.setDescriptor(attributeDescriptor, "attribute");
         }
 
-        if (logger.isEnabledFor(Logger.DEBUG))
+        if (logger.isEnabledFor(Logger.DEBUG)) {
           logger.debug(
               "getAttribute for attribute " + attribute + " returns invoked value: " + returnValue);
+        }
       }
     } else {
       // Return cached value
@@ -477,9 +515,10 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
         checkAssignability(returned, declared);
       }
 
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug(
             "getAttribute for attribute " + attribute + " returns cached value: " + returnValue);
+      }
     }
 
     // Puff, everything went ok
@@ -488,9 +527,10 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
 
   @Override
   public AttributeList setAttributes(AttributeList attributes) {
-    if (attributes == null)
+    if (attributes == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Attribute list cannot be null."));
+    }
 
     Logger logger = getLogger();
 
@@ -502,8 +542,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
         setAttribute(attribute);
         list.add(attribute);
       } catch (Exception x) {
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("setAttribute for attribute " + name + " failed", x);
+        }
         // And go on with the next one
       }
     }
@@ -513,70 +554,83 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   @Override
   public void setAttribute(Attribute attribute) throws AttributeNotFoundException,
       InvalidAttributeValueException, MBeanException, ReflectionException {
-    if (attribute == null)
+    if (attribute == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Attribute cannot be null."));
+    }
 
     Logger logger = getLogger();
 
     // No need to synchronize: I work mostly on clones
     // I want the real info, not its clone
     ModelMBeanInfo info = getModelMBeanInfo();
-    if (info == null)
+    if (info == null) {
       throw new AttributeNotFoundException(
           "ModelMBeanInfo is null");
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("ModelMBeanInfo is: " + info);
+    }
 
     String attrName = attribute.getName();
     Object attrValue = attribute.getValue();
 
     // This is a clone, we use it read only
     ModelMBeanAttributeInfo attrInfo = info.getAttribute(attrName);
-    if (attrInfo == null)
+    if (attrInfo == null) {
       throw new AttributeNotFoundException(
           String.format("Cannot find ModelMBeanAttributeInfo for attribute %s",
               attrName));
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Attribute info is: " + attrInfo);
+    }
 
-    if (!attrInfo.isWritable())
+    if (!attrInfo.isWritable()) {
       throw new AttributeNotFoundException(
           String.format("Attribute %s is not writable", attrName));
+    }
 
     // This returns a clone of the mbean descriptor, we use it read only
     Descriptor mbeanDescriptor = info.getMBeanDescriptor();
-    if (mbeanDescriptor == null)
+    if (mbeanDescriptor == null) {
       throw new AttributeNotFoundException(
           "MBean descriptor cannot be null");
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("MBean descriptor is: " + mbeanDescriptor);
+    }
 
     // This descriptor is a clone
     Descriptor attributeDescriptor = attrInfo.getDescriptor();
-    if (attributeDescriptor == null)
+    if (attributeDescriptor == null) {
       throw new AttributeNotFoundException(
           String.format("Attribute descriptor for attribute %s cannot be null",
               attrName));
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Attribute descriptor is: " + attributeDescriptor);
+    }
 
     String lastUpdateField = "lastUpdatedTimeStamp";
 
     Object oldValue = null;
     try {
       oldValue = getAttribute(attrName);
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("Previous value of attribute " + attrName + ": " + oldValue);
+      }
     } catch (Exception x) {
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("Cannot get previous value of attribute " + attrName, x);
+      }
     }
 
     // Check if setMethod is present
     String method = (String) attributeDescriptor.getFieldValue("setMethod");
-    if (logger.isEnabledFor(Logger.DEBUG))
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("setMethod field is: " + method);
+    }
     if (method != null) {
       Class declared = loadClassWithContextClassLoader(attrInfo.getType());
       if (attrValue != null) {
@@ -593,11 +647,13 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
       if (staleness != ALWAYS_STALE) {
         attributeDescriptor.setField("value", attrValue);
         attributeDescriptor.setField(lastUpdateField, Long.valueOf(System.currentTimeMillis()));
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Attribute's value has been cached");
+        }
       } else {
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Always stale, avoiding to cache attribute's value");
+        }
       }
     } else {
       if (attrValue != null) {
@@ -615,25 +671,29 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     info.setDescriptor(attributeDescriptor, "attribute");
 
     // Send notifications to listeners
-    if (logger.isEnabledFor(Logger.TRACE))
+    if (logger.isEnabledFor(Logger.TRACE)) {
       logger.trace("Sending attribute change notifications");
+    }
     sendAttributeChangeNotification(new Attribute(attrName, oldValue), attribute);
 
     // Persist this ModelMBean
     boolean persistNow = shouldPersistNow(attributeDescriptor, mbeanDescriptor, lastUpdateField);
     if (persistNow) {
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("Persisting this ModelMBean...");
+      }
       try {
         store();
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("ModelMBean persisted successfully");
+        }
       } catch (Exception x) {
         logger.error("Cannot store ModelMBean after setAttribute", x);
-        if (x instanceof MBeanException)
+        if (x instanceof MBeanException) {
           throw (MBeanException) x;
-        else
+        } else {
           throw new MBeanException(x);
+        }
       }
     }
   }
@@ -641,54 +701,66 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   @Override
   public Object invoke(String method, Object[] arguments, String[] params)
       throws MBeanException, ReflectionException {
-    if (method == null)
+    if (method == null) {
       throw new RuntimeOperationsException(new IllegalArgumentException(
           "Method name cannot be null."));
-    if (arguments == null)
+    }
+    if (arguments == null) {
       arguments = new Object[0];
-    if (params == null)
+    }
+    if (params == null) {
       params = new String[0];
+    }
 
     Logger logger = getLogger();
 
     // Find operation descriptor
     ModelMBeanInfo info = getModelMBeanInfo();
-    if (info == null)
+    if (info == null) {
       throw new MBeanException(new ServiceNotFoundException(
           "ModelMBeanInfo is null"));
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("ModelMBeanInfo is: " + info);
+    }
 
     // This is a clone, we use it read only
     ModelMBeanOperationInfo operInfo = info.getOperation(method);
-    if (operInfo == null)
+    if (operInfo == null) {
       throw new MBeanException(new ServiceNotFoundException(
           String.format("Cannot find ModelMBeanOperationInfo for operation %s",
               method)));
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Operation info is: " + operInfo);
+    }
 
     // This descriptor is a clone
     Descriptor operationDescriptor = operInfo.getDescriptor();
-    if (operationDescriptor == null)
+    if (operationDescriptor == null) {
       throw new MBeanException(new ServiceNotFoundException(
           String.format("Operation descriptor for operation %s cannot be null",
               method)));
+    }
     String role = (String) operationDescriptor.getFieldValue("role");
-    if (role == null || !role.equals("operation"))
+    if (role == null || !role.equals("operation")) {
       throw new MBeanException(new ServiceNotFoundException(
           String.format("Operation descriptor field 'role' must be 'operation', not %s",
               role)));
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Operation descriptor is: " + operationDescriptor);
+    }
 
     // This returns a clone of the mbean descriptor, we use it read only
     Descriptor mbeanDescriptor = info.getMBeanDescriptor();
-    if (mbeanDescriptor == null)
+    if (mbeanDescriptor == null) {
       throw new MBeanException(new ServiceNotFoundException(
           "MBean descriptor cannot be null"));
-    if (logger.isEnabledFor(Logger.DEBUG))
+    }
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("MBean descriptor is: " + mbeanDescriptor);
+    }
 
     Object returnValue = null;
 
@@ -698,8 +770,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     int staleness = getStaleness(operationDescriptor, mbeanDescriptor, lastUpdateField);
 
     if (staleness == ALWAYS_STALE || staleness == STALE) {
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("Value is stale");
+      }
 
       // Find parameters classes
       Class[] parameters = null;
@@ -710,15 +783,17 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
         throw new ReflectionException(x);
       }
 
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("Invoking operation...");
+      }
 
       // Find target object
       Object target = resolveTargetObject(operationDescriptor);
       returnValue = invokeMethod(target, method, parameters, arguments);
 
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("Returned value is: " + returnValue);
+      }
 
       if (returnValue != null) {
         Class parameter = returnValue.getClass();
@@ -739,8 +814,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
         info.setDescriptor(operationDescriptor, "operation");
       }
 
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("invoke for operation " + method + " returns invoked value: " + returnValue);
+      }
     } else {
       // Return cached value
       returnValue = operationDescriptor.getFieldValue("lastReturnedValue");
@@ -752,8 +828,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
         checkAssignability(parameter, declared);
       }
 
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("invoke for operation " + method + " returns cached value: " + returnValue);
+      }
     }
 
     // As an extension, persist this model mbean also after operation invocation, but using only
@@ -762,19 +839,22 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     boolean persistNow = shouldPersistNow(operationDescriptor, null, lastUpdateField);
     int impact = operInfo.getImpact();
     if (persistNow && impact != MBeanOperationInfo.INFO) {
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("Persisting this ModelMBean...");
+      }
       try {
         store();
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("ModelMBean persisted successfully");
+        }
       } catch (Exception x) {
         logger.error(
             "Cannot store ModelMBean after operation invocation", x);
-        if (x instanceof MBeanException)
+        if (x instanceof MBeanException) {
           throw (MBeanException) x;
-        else
+        } else {
           throw new MBeanException(x);
+        }
       }
     }
 
@@ -784,21 +864,24 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   private Object resolveTargetObject(Descriptor descriptor) throws MBeanException {
     Logger logger = getLogger();
     Object target = descriptor.getFieldValue("targetObject");
-    if (logger.isEnabledFor(Logger.TRACE))
+    if (logger.isEnabledFor(Logger.TRACE)) {
       logger.trace("targetObject is: " + target);
+    }
     if (target == null) {
       target = getManagedResource();
     } else {
       String targetObjectType = (String) descriptor.getFieldValue("targetObjectType");
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("targetObjectType is: " + targetObjectType);
+      }
       if (targetObjectType == null) {
         // Not defined, assume object reference
         targetObjectType = OBJECT_RESOURCE_TYPE;
       }
 
-      if (!isResourceTypeSupported(targetObjectType))
+      if (!isResourceTypeSupported(targetObjectType)) {
         throw new MBeanException(new InvalidTargetObjectTypeException(targetObjectType));
+      }
     }
     return target;
   }
@@ -823,10 +906,11 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
   }
 
   protected ClassLoaderRepository getClassLoaderRepository() {
-    if (m_mbeanServer != null)
+    if (m_mbeanServer != null) {
       return m_mbeanServer.getClassLoaderRepository();
-    else
+    } else {
       return null;
+    }
   }
 
 
@@ -836,10 +920,11 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
       Long period = getFieldTimeValue(attribute, mbean, "persistPeriod");
       long now = System.currentTimeMillis();
       Long lastUpdate = (Long) attribute.getFieldValue(lastUpdateField);
-      if (now - lastUpdate.longValue() < period.longValue())
+      if (now - lastUpdate.longValue() < period.longValue()) {
         return false;
-      else
+      } else {
         return true;
+      }
     } else if (persist == PERSIST_NEVER) {
       return false;
     } else if (persist == PERSIST_ON_TIMER) {
@@ -856,24 +941,29 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     Logger logger = getLogger();
 
     String persist = (String) descriptor.getFieldValue("persistPolicy");
-    if (persist == null && mbean != null)
+    if (persist == null && mbean != null) {
       persist = (String) mbean.getFieldValue("persistPolicy");
+    }
     if (persist == null) {
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("No persist policy defined, assuming Never");
+      }
       return PERSIST_NEVER;
     } else {
       if (persist.equals("Never")) {
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Persist never");
+        }
         return PERSIST_NEVER;
       } else if (persist.equals("OnUpdate")) {
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Persist on update");
+        }
         return PERSIST_ON_UPDATE;
       } else if (persist.equals("OnTimer")) {
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Persist on update");
+        }
         return PERSIST_ON_TIMER;
       } else if (persist.equals("NoMoreOftenThan")) {
         if (logger.isEnabledFor(Logger.TRACE)) {
@@ -883,8 +973,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
         return PERSIST_NO_MORE_OFTEN_THAN;
       } else {
         // Garbage, assuming Never
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Invalid persist policy, assuming persist never");
+        }
         return PERSIST_NEVER;
       }
     }
@@ -896,51 +987,60 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     Long currencyTimeLimit = getFieldTimeValue(attribute, mbean, "currencyTimeLimit");
     if (currencyTimeLimit == null) {
       // No time limit defined
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("No currencyTimeLimit defined, assuming always stale");
+      }
       return ALWAYS_STALE;
     } else {
       long ctl = currencyTimeLimit.longValue() * 1000;
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("currencyTimeLimit is (ms): " + ctl);
+      }
 
       if (ctl == 0) {
         // Never stale
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Never stale");
+        }
         return NEVER_STALE;
       } else if (ctl < 0) // this should be == -1 but the other cases are in the air
       {
         // Always stale
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Always stale");
+        }
         return ALWAYS_STALE;
       } else {
         Long timestamp = (Long) attribute.getFieldValue(lastUpdateField);
         long luts = 0;
 
-        if (timestamp != null)
+        if (timestamp != null) {
           luts = timestamp.longValue();
-        if (logger.isEnabledFor(Logger.DEBUG))
+        }
+        if (logger.isEnabledFor(Logger.DEBUG)) {
           logger.debug(lastUpdateField + " is: " + luts);
+        }
 
         long now = System.currentTimeMillis();
         if (now < luts + ctl) {
           // Seems to be not stale, but has been set at least once ?
           if (timestamp == null) {
             // Return stale to call it the first time
-            if (logger.isEnabledFor(Logger.TRACE))
+            if (logger.isEnabledFor(Logger.TRACE)) {
               logger.trace("Stale since was never set");
+            }
             return STALE;
           } else {
-            if (logger.isEnabledFor(Logger.TRACE))
+            if (logger.isEnabledFor(Logger.TRACE)) {
               logger.trace("Not stale");
+            }
             return NOT_STALE;
           }
         } else {
           // Stale
-          if (logger.isEnabledFor(Logger.TRACE))
+          if (logger.isEnabledFor(Logger.TRACE)) {
             logger.trace("Stale");
+          }
           return STALE;
         }
       }
@@ -951,19 +1051,23 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     Logger logger = getLogger();
 
     Object value = descriptor.getFieldValue(field);
-    if (logger.isEnabledFor(Logger.DEBUG))
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Descriptor's " + field + " field: " + value);
+    }
 
     if (value == null && mbean != null) {
       value = mbean.getFieldValue(field);
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("MBean's " + field + " field: " + value);
-      if (value == null)
+      }
+      if (value == null) {
         return null;
+      }
     }
 
-    if (value instanceof Number)
+    if (value instanceof Number) {
       return Long.valueOf(((Number) value).longValue());
+    }
 
     if (value instanceof String) {
       try {
@@ -988,9 +1092,10 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
       realTarget = target;
     }
 
-    if (realTarget == null)
+    if (realTarget == null) {
       throw new MBeanException(new ServiceNotFoundException(
           "Could not find target"));
+    }
 
     if (method == null) {
       try {
@@ -1003,8 +1108,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     try {
       Object value = method.invoke(realTarget, args);
       Logger logger = getLogger();
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("Method invocation returned value: " + value);
+      }
       return value;
     } catch (IllegalAccessException x) {
       throw new ReflectionException(x);
@@ -1012,10 +1118,11 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
       throw new MBeanException(x);
     } catch (InvocationTargetException x) {
       Throwable t = x.getTargetException();
-      if (t instanceof Error)
+      if (t instanceof Error) {
         throw new MBeanException(new RuntimeErrorException((Error) t));
-      else
+      } else {
         throw new MBeanException((Exception) t);
+      }
     }
   }
 
@@ -1034,8 +1141,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     if (modelMBeanLogger == null) {
       descriptor = info.getMBeanDescriptor();
       modelMBeanLogger = findLogger(descriptor);
-      if (modelMBeanLogger != null)
+      if (modelMBeanLogger != null) {
         return modelMBeanLogger;
+      }
     }
 
     return null;
@@ -1045,32 +1153,37 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     Logger logger = getLogger();
 
     if (descriptor == null) {
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("Can't find MBean logger, descriptor is null");
+      }
       return null;
     }
 
     String log = (String) descriptor.getFieldValue("log");
     String location = (String) descriptor.getFieldValue("logFile");
 
-    if (logger.isEnabledFor(Logger.DEBUG))
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Log fields: log=" + log + ", file=" + location);
+    }
 
     if (log == null || !Boolean.valueOf(log).booleanValue()) {
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("Logging is not supported by this ModelMBean");
+      }
       return null;
     }
     // Logger is supported, where log to ?
     if (location == null) {
       // As an extension, see if the field logMBean has been defined
       location = (String) descriptor.getFieldValue("logMBean");
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("Log fields: mbean=" + location);
+      }
 
       if (location == null) {
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Logging is not supported by this ModelMBean");
+        }
         return null;
       }
 
@@ -1078,32 +1191,37 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
       try {
         ObjectName objectName = new ObjectName(location);
         MBeanServer server = getMBeanServer();
-        if (server == null)
+        if (server == null) {
           throw new MBeanException(new IllegalStateException(
               "MX4JModelMBean is not registered."));
+        }
         if (server.isRegistered(objectName)) {
           MBeanLogger l = new MBeanLogger(server, objectName);
-          if (logger.isEnabledFor(Logger.DEBUG))
+          if (logger.isEnabledFor(Logger.DEBUG)) {
             logger.debug("ModelMBean log supported by delegating to this MBean: " + objectName);
+          }
           return l;
         }
 
         return null;
       } catch (MalformedObjectNameException x) {
         // Ah, was not a correct object name
-        if (logger.isEnabledFor(Logger.DEBUG))
+        if (logger.isEnabledFor(Logger.DEBUG)) {
           logger.debug("Specified logMBean field does not contain a valid ObjectName: " + location);
+        }
         return null;
       } catch (MBeanException x) {
-        if (logger.isEnabledFor(Logger.DEBUG))
+        if (logger.isEnabledFor(Logger.DEBUG)) {
           logger.debug("logMBean field does not specify an MBean that supports logging delegation",
               x);
+        }
         return null;
       }
     } else {
       // User decided to log to a file
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("ModelMBean log supported on file system");
+      }
       return new FileLogger(location);
     }
   }
@@ -1127,27 +1245,31 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
     ModelMBeanInfo info = getModelMBeanInfo();
     if (info == null) {
       // Not yet initialized
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("Can't find persister, ModelMBeanInfo is null");
+      }
       return null;
     }
     Descriptor mbeanDescriptor = info.getMBeanDescriptor();
     if (mbeanDescriptor == null) {
       // This is normally should not happen if ModelMBeanInfoSupport is used
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("Can't find persister, MBean descriptor is null");
+      }
       return null;
     }
 
     String location = (String) mbeanDescriptor.getFieldValue("persistLocation");
     String name = (String) mbeanDescriptor.getFieldValue("persistName");
     String mbeanName = (String) mbeanDescriptor.getFieldValue("name");
-    if (logger.isEnabledFor(Logger.DEBUG))
+    if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("Persistence fields: location=" + location + ", name=" + name);
+    }
 
     if (mbeanName == null && name == null) {
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("Persistence is not supported by this ModelMBean");
+      }
       return null;
     }
 
@@ -1157,36 +1279,41 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
         ObjectName objectName = new ObjectName(name.trim());
         // OK, a valid object name
         MBeanServer server = getMBeanServer();
-        if (server == null)
+        if (server == null) {
           throw new MBeanException(new IllegalStateException(
               "MX4JModelMBean is not registered."));
+        }
 
         if (server.isRegistered(objectName)
             && server.isInstanceOf(objectName, PersisterMBean.class.getName())) {
           // OK, the given mbean is registered with this mbean server
           PersisterMBean persister = new MBeanPersister(server, objectName);
-          if (logger.isEnabledFor(Logger.DEBUG))
+          if (logger.isEnabledFor(Logger.DEBUG)) {
             logger.debug("Persistence is delegated to this MBean: " + objectName);
+          }
           return persister;
         } else {
           throw new InstanceNotFoundException(objectName.toString());
         }
       } catch (MalformedObjectNameException ignored) {
         // It does not delegates to another mbean, use default
-        if (logger.isEnabledFor(Logger.TRACE))
+        if (logger.isEnabledFor(Logger.TRACE)) {
           logger.trace("Persistence is not delegated to another MBean");
+        }
       }
 
       // Default is serialization to file
       FilePersister persister = new FilePersister(location, name);
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("Persistence is realized through file system in " + persister.getFileName());
+      }
       return persister;
     } else {
       // Only location given, use MBean name
       FilePersister persister = new FilePersister(location, mbeanName);
-      if (logger.isEnabledFor(Logger.DEBUG))
+      if (logger.isEnabledFor(Logger.DEBUG)) {
         logger.debug("Persistence is realized through file system in " + persister.getFileName());
+      }
       return persister;
     }
   }
@@ -1196,8 +1323,9 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
       return Utils.loadClass(Thread.currentThread().getContextClassLoader(), name);
     } catch (ClassNotFoundException x) {
       Logger logger = getLogger();
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace("Cannot find attribute's declared return class", x);
+      }
       return null;
     }
   }
@@ -1207,41 +1335,45 @@ public class MX4JModelMBean implements ModelMBean, MBeanRegistration, Notificati
 
     if (logger.isEnabledFor(Logger.DEBUG)) {
       logger.debug("The class of the parameter is: " + parameter);
-      if (parameter != null)
+      if (parameter != null) {
         logger.debug("The classloder of the parameter's class is: " + parameter.getClassLoader());
+      }
       logger.debug("The class declared as type of the attribute is: " + declared);
-      if (declared != null)
+      if (declared != null) {
         logger.debug(
             "The classloader of the declared parameter's class is: " + declared.getClassLoader());
+      }
     }
 
     boolean assignable = false;
 
-    if (declared == null || parameter == null)
+    if (declared == null || parameter == null) {
       assignable = false;
-    else if (declared == boolean.class && parameter == Boolean.class)
+    } else if (declared == boolean.class && parameter == Boolean.class) {
       assignable = true;
-    else if (declared == byte.class && parameter == Byte.class)
+    } else if (declared == byte.class && parameter == Byte.class) {
       assignable = true;
-    else if (declared == char.class && parameter == Character.class)
+    } else if (declared == char.class && parameter == Character.class) {
       assignable = true;
-    else if (declared == short.class && parameter == Short.class)
+    } else if (declared == short.class && parameter == Short.class) {
       assignable = true;
-    else if (declared == int.class && parameter == Integer.class)
+    } else if (declared == int.class && parameter == Integer.class) {
       assignable = true;
-    else if (declared == long.class && parameter == Long.class)
+    } else if (declared == long.class && parameter == Long.class) {
       assignable = true;
-    else if (declared == float.class && parameter == Float.class)
+    } else if (declared == float.class && parameter == Float.class) {
       assignable = true;
-    else if (declared == double.class && parameter == Double.class)
+    } else if (declared == double.class && parameter == Double.class) {
       assignable = true;
-    else
+    } else {
       assignable = declared.isAssignableFrom(parameter);
+    }
 
     if (!assignable) {
-      if (logger.isEnabledFor(Logger.TRACE))
+      if (logger.isEnabledFor(Logger.TRACE)) {
         logger.trace(
             "Parameter value's class and attribute's declared return class are not assignable");
+      }
       throw new MBeanException(new InvalidAttributeValueException(
           "Returned type and declared type are not assignable."));
     }
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResourceType.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResourceType.java
index 131826f..cc8e6b3 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResourceType.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResourceType.java
@@ -182,18 +182,23 @@ public class ManagedResourceType implements java.io.Serializable {
    */
   @Override
   public boolean equals(Object other) {
-    if (other == this)
+    if (other == this) {
       return true;
-    if (other == null)
+    }
+    if (other == null) {
       return false;
-    if (!(other instanceof ManagedResourceType))
+    }
+    if (!(other instanceof ManagedResourceType)) {
       return false;
+    }
     final ManagedResourceType that = (ManagedResourceType) other;
 
-    if (!StringUtils.equals(this.name, that.name))
+    if (!StringUtils.equals(this.name, that.name)) {
       return false;
-    if (this.clazz != that.clazz && !(this.clazz != null && this.clazz.equals(that.clazz)))
+    }
+    if (this.clazz != that.clazz && !(this.clazz != null && this.clazz.equals(that.clazz))) {
       return false;
+    }
 
     return true;
   }
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RefreshNotificationType.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RefreshNotificationType.java
index 4ba6530..237fa02 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RefreshNotificationType.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RefreshNotificationType.java
@@ -94,18 +94,23 @@ public class RefreshNotificationType implements java.io.Serializable {
    */
   @Override
   public boolean equals(Object other) {
-    if (other == this)
+    if (other == this) {
       return true;
-    if (other == null)
+    }
+    if (other == null) {
       return false;
-    if (!(other instanceof RefreshNotificationType))
+    }
+    if (!(other instanceof RefreshNotificationType)) {
       return false;
+    }
     final RefreshNotificationType that = (RefreshNotificationType) other;
 
-    if (!StringUtils.equals(this.type, that.type))
+    if (!StringUtils.equals(this.type, that.type)) {
       return false;
-    if (!StringUtils.equals(this.msg, that.msg))
+    }
+    if (!StringUtils.equals(this.msg, that.msg)) {
       return false;
+    }
 
     return true;
   }
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticResourceJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticResourceJmxImpl.java
index 1445448..07098fa 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticResourceJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticResourceJmxImpl.java
@@ -84,8 +84,9 @@ public class StatisticResourceJmxImpl extends org.apache.geode.admin.internal.St
     // Refresh Interval
     AdminDistributedSystemJmxImpl sysJmx =
         (AdminDistributedSystemJmxImpl) this.member.getDistributedSystem();
-    if (sysJmx.getRefreshInterval() > 0)
+    if (sysJmx.getRefreshInterval() > 0) {
       this.refreshInterval = sysJmx.getRefreshInterval();
+    }
   }
 
   // -------------------------------------------------------------------------
@@ -111,8 +112,9 @@ public class StatisticResourceJmxImpl extends org.apache.geode.admin.internal.St
     boolean isRegistered = MBeanUtil.isRefreshNotificationRegistered(this,
         RefreshNotificationType.STATISTIC_RESOURCE_STATISTICS);
 
-    if (isRegistered && (getRefreshInterval() == refreshInterval))
+    if (isRegistered && (getRefreshInterval() == refreshInterval)) {
       return;
+    }
 
     try {
       MBeanUtil.registerRefreshNotification(this, // NotificationListener
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmx.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmx.java
index b621d6f..c6246e2 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmx.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmx.java
@@ -310,9 +310,9 @@ public interface SystemMemberJmx extends SystemMember, NotificationListener {
         throws AdminException, MalformedObjectNameException {
       try {
         StatisticResource[] stats = member.getStat(statisticsTypeName);
-        if (stats == null)
+        if (stats == null) {
           return null;
-        else {
+        } else {
           ObjectName[] statNames = new ObjectName[stats.length];
           for (int i = 0; i < stats.length; i++) {
             StatisticResourceJmxImpl statJMX = (StatisticResourceJmxImpl) stats[i];
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmxImpl.java
index fadd955..b50f3fd 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmxImpl.java
@@ -121,8 +121,9 @@ public class SystemMemberJmxImpl extends org.apache.geode.admin.internal.SystemM
 
     // Refresh Interval
     AdminDistributedSystemJmxImpl sysJmx = (AdminDistributedSystemJmxImpl) system;
-    if (sysJmx.getRefreshInterval() > 0)
+    if (sysJmx.getRefreshInterval() > 0) {
       this.refreshInterval = sysJmx.getRefreshInterval();
+    }
   }
 
   // -------------------------------------------------------------------------
@@ -166,8 +167,9 @@ public class SystemMemberJmxImpl extends org.apache.geode.admin.internal.SystemM
     boolean isRegistered = MBeanUtil.isRefreshNotificationRegistered(this,
         RefreshNotificationType.SYSTEM_MEMBER_CONFIG);
 
-    if (isRegistered && (getRefreshInterval() == refreshInterval))
+    if (isRegistered && (getRefreshInterval() == refreshInterval)) {
       return;
+    }
 
     this.refreshInterval = Helper.setAndReturnRefreshInterval(this, refreshInterval);
   }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java b/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
index 5ee9b09..d0e0194 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
@@ -710,9 +710,10 @@ public class AttributesFactory<K, V> {
    * @throws IllegalArgumentException if {@code keyConstraint} is a class denoting a primitive type
    */
   public void setKeyConstraint(Class<K> keyConstraint) {
-    if (keyConstraint != null && keyConstraint.isPrimitive())
+    if (keyConstraint != null && keyConstraint.isPrimitive()) {
       throw new IllegalArgumentException(
           "keyConstraint must not be a primitive type");
+    }
     this.regionAttributes.keyConstraint = keyConstraint;
     this.regionAttributes.setHasKeyConstraint(true);
   }
@@ -727,9 +728,10 @@ public class AttributesFactory<K, V> {
    *         type
    */
   public void setValueConstraint(Class<V> valueConstraint) {
-    if (valueConstraint != null && valueConstraint.isPrimitive())
+    if (valueConstraint != null && valueConstraint.isPrimitive()) {
       throw new IllegalArgumentException(
           "valueConstraint must not be a primitive type");
+    }
     this.regionAttributes.valueConstraint = valueConstraint;
     this.regionAttributes.setHasValueConstraint(true);
   }
@@ -746,9 +748,10 @@ public class AttributesFactory<K, V> {
    * @see java.util.HashMap
    */
   public void setInitialCapacity(int initialCapacity) {
-    if (initialCapacity < 0)
+    if (initialCapacity < 0) {
       throw new IllegalArgumentException(
           "initialCapacity must be >= 0");
+    }
     this.regionAttributes.initialCapacity = initialCapacity;
     this.regionAttributes.setHasInitialCapacity(true);
   }
@@ -762,10 +765,11 @@ public class AttributesFactory<K, V> {
    * @see java.util.HashMap
    */
   public void setLoadFactor(float loadFactor) {
-    if (loadFactor <= 0)
+    if (loadFactor <= 0) {
       throw new IllegalArgumentException(
           String.format("loadFactor must be > 0, value is %s",
               new Float(loadFactor)));
+    }
     this.regionAttributes.loadFactor = loadFactor;
     this.regionAttributes.setHasLoadFactor(true);
   }
@@ -778,9 +782,10 @@ public class AttributesFactory<K, V> {
    * @throws IllegalArgumentException if concurrencyLevel is nonpositive
    */
   public void setConcurrencyLevel(int concurrencyLevel) {
-    if (concurrencyLevel <= 0)
+    if (concurrencyLevel <= 0) {
       throw new IllegalArgumentException(
           "concurrencyLevel must be > 0");
+    }
     this.regionAttributes.concurrencyLevel = concurrencyLevel;
     this.regionAttributes.setHasConcurrencyLevel(true);
   }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java b/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
index 6219bd5..1cf3338 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
@@ -314,8 +314,9 @@ public class DataPolicy implements java.io.Serializable {
       }
     }
 
-    if (valueIndex != -1)
+    if (valueIndex != -1) {
       return VALUES[valueIndex];
+    }
 
     return null;
   }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionFactory.java b/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionFactory.java
index c145a37..c9464c1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionFactory.java
@@ -216,10 +216,11 @@ public abstract class DynamicRegionFactory {
    * Returns the configuration for this factory. Returns null if the factory is closed;
    */
   public Config getConfig() {
-    if (this.config == null)
+    if (this.config == null) {
       return null;
-    else
+    } else {
       return new Config(this.config);
+    }
   }
 
   public static boolean regionIsDynamicRegionList(String regionPath) {
@@ -287,8 +288,9 @@ public abstract class DynamicRegionFactory {
           }
 
           for (GatewaySender gs : this.cache.getGatewaySenders()) {
-            if (!gs.isParallel())
+            if (!gs.isParallel()) {
               af.addGatewaySenderId(gs.getId());
+            }
           }
           ira.setInternalMetaRegion(new DistributedMetaRegion(af.create())); // bug fix 35432
         }
@@ -753,27 +755,36 @@ public abstract class DynamicRegionFactory {
 
     @Override
     public boolean equals(Object obj) {
-      if (this == obj)
+      if (this == obj) {
         return true;
-      if (obj == null)
+      }
+      if (obj == null) {
         return false;
-      if (getClass() != obj.getClass())
+      }
+      if (getClass() != obj.getClass()) {
         return false;
+      }
       Config other = (Config) obj;
       if (diskDir == null) {
-        if (other.diskDir != null)
+        if (other.diskDir != null) {
           return false;
-      } else if (!diskDir.equals(other.diskDir))
+        }
+      } else if (!diskDir.equals(other.diskDir)) {
         return false;
-      if (persistBackup != other.persistBackup)
+      }
+      if (persistBackup != other.persistBackup) {
         return false;
+      }
       if (poolName == null) {
-        if (other.poolName != null)
+        if (other.poolName != null) {
           return false;
-      } else if (!poolName.equals(other.poolName))
+        }
+      } else if (!poolName.equals(other.poolName)) {
         return false;
-      if (registerInterest != other.registerInterest)
+      }
+      if (registerInterest != other.registerInterest) {
         return false;
+      }
       return true;
     }
 
@@ -820,13 +831,15 @@ public abstract class DynamicRegionFactory {
   }
 
   protected void buildDynamicRegion(EntryEvent event) {
-    if (!DynamicRegionFactory.this.isOpen())
+    if (!DynamicRegionFactory.this.isOpen()) {
       return;
+    }
 
     // Ignore the callback if it originated in this process (because the region
     // will already have been created) and the event is not a client event
-    if (!event.isOriginRemote() && !event.hasClientOrigin())
+    if (!event.isOriginRemote() && !event.hasClientOrigin()) {
       return;
+    }
     //
     DynamicRegionAttributes dra = (DynamicRegionAttributes) event.getNewValue();
     String parentRegionName = dra.rootRegionName;
@@ -845,8 +858,9 @@ public abstract class DynamicRegionFactory {
   }
 
   protected void razeDynamicRegion(EntryEvent event) {
-    if (!DynamicRegionFactory.this.isOpen())
+    if (!DynamicRegionFactory.this.isOpen()) {
       return;
+    }
 
     // Because CacheClientUpdater calls localDestroy we need to allow
     // "local" events. If this is a true local then c.getRegion will return
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java b/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
index 4bb3cf5..1d99d7f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
@@ -109,10 +109,12 @@ public final class EvictionAction extends EnumSyntax implements Serializable {
    *         returned.
    */
   public static EvictionAction parseAction(String s) {
-    if (s == null)
+    if (s == null) {
       return NONE;
-    if (s.length() < 1)
+    }
+    if (s.length() < 1) {
       return NONE;
+    }
     for (int i = 0; i < stringTable.length; ++i) {
       if (s.equals(stringTable[i])) {
         return enumValueTable[i];
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EvictionAlgorithm.java b/geode-core/src/main/java/org/apache/geode/cache/EvictionAlgorithm.java
index be78f01..14322e5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EvictionAlgorithm.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EvictionAlgorithm.java
@@ -111,10 +111,12 @@ public final class EvictionAlgorithm extends EnumSyntax implements Serializable
   }
 
   public static EvictionAlgorithm parseAction(String s) {
-    if (s == null)
+    if (s == null) {
       return null;
-    if (s.length() < 1)
+    }
+    if (s.length() < 1) {
       return null;
+    }
     for (int i = 0; i < stringTable.length; ++i) {
       if (s.equals(stringTable[i])) {
         return enumValueTable[i];
diff --git a/geode-core/src/main/java/org/apache/geode/cache/MembershipAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/MembershipAttributes.java
index e7c908f..26dc3fe 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/MembershipAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/MembershipAttributes.java
@@ -167,23 +167,30 @@ public class MembershipAttributes implements DataSerializable, Externalizable {
    */
   @Override
   public boolean equals(Object other) {
-    if (other == this)
+    if (other == this) {
       return true;
-    if (other == null)
+    }
+    if (other == null) {
       return false;
-    if (!(other instanceof MembershipAttributes))
+    }
+    if (!(other instanceof MembershipAttributes)) {
       return false;
+    }
     final MembershipAttributes that = (MembershipAttributes) other;
 
     if (this.requiredRoles != that.requiredRoles
-        && !(this.requiredRoles != null && this.requiredRoles.equals(that.requiredRoles)))
+        && !(this.requiredRoles != null && this.requiredRoles.equals(that.requiredRoles))) {
       return false;
+    }
     if (this.lossAction != that.lossAction
-        && !(this.lossAction != null && this.lossAction.equals(that.lossAction)))
+        && !(this.lossAction != null && this.lossAction.equals(that.lossAction))) {
       return false;
+    }
     if (this.resumptionAction != that.resumptionAction
-        && !(this.resumptionAction != null && this.resumptionAction.equals(that.resumptionAction)))
+        && !(this.resumptionAction != null
+            && this.resumptionAction.equals(that.resumptionAction))) {
       return false;
+    }
 
     return true;
   }
@@ -220,8 +227,9 @@ public class MembershipAttributes implements DataSerializable, Externalizable {
       sb.append("RequiredRoles(");
       boolean comma = false;
       for (Iterator<Role> iter = this.requiredRoles.iterator(); iter.hasNext();) {
-        if (comma)
+        if (comma) {
           sb.append(",");
+        }
         Role role = iter.next();
         sb.append(role.getName());
         comma = true;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/SubscriptionAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/SubscriptionAttributes.java
index e956c90..a622bb9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/SubscriptionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/SubscriptionAttributes.java
@@ -66,17 +66,21 @@ public class SubscriptionAttributes implements DataSerializable, Externalizable
 
   @Override
   public boolean equals(Object other) {
-    if (other == this)
+    if (other == this) {
       return true;
-    if (other == null)
+    }
+    if (other == null) {
       return false;
-    if (!(other instanceof SubscriptionAttributes))
+    }
+    if (!(other instanceof SubscriptionAttributes)) {
       return false;
+    }
     final SubscriptionAttributes that = (SubscriptionAttributes) other;
 
     if (this.interestPolicy != that.interestPolicy
-        && !(this.interestPolicy != null && this.interestPolicy.equals(that.interestPolicy)))
+        && !(this.interestPolicy != null && this.interestPolicy.equals(that.interestPolicy))) {
       return false;
+    }
 
     return true;
   }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
index 9b45bca..7755c81 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
@@ -288,8 +288,9 @@ public class AutoConnectionSourceImpl implements ConnectionSource {
   }
 
   private void updateLocatorList(LocatorListResponse response) {
-    if (response == null)
+    if (response == null) {
       return;
+    }
     isBalanced = response.isBalanced();
     List<ServerLocation> locatorResponse = response.getLocators();
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientPartitionAdvisor.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientPartitionAdvisor.java
index 8c554cd..1cad42d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientPartitionAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientPartitionAdvisor.java
@@ -125,8 +125,9 @@ public class ClientPartitionAdvisor {
           this.bucketServerLocationsMap.get(bucketList.get(random.nextInt(size)));
       if (locations != null) {
         List<BucketServerLocation66> serverList = new ArrayList<BucketServerLocation66>(locations);
-        if (serverList.size() == 0)
+        if (serverList.size() == 0) {
           return null;
+        }
         return serverList.get(0);
       }
     }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
index 16401f3..925979f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
@@ -88,10 +88,11 @@ public class ExecuteFunctionNoAckOp {
                 + op.getMessage() + " to server using pool: " + pool,
             ex);
       }
-      if (ex.getMessage() != null)
+      if (ex.getMessage() != null) {
         throw new FunctionException(ex.getMessage(), ex);
-      else
+      } else {
         throw new FunctionException("Unexpected exception during function execution:", ex);
+      }
     }
   }
 
@@ -129,10 +130,11 @@ public class ExecuteFunctionNoAckOp {
                 + op.getMessage() + " to server using pool: " + pool,
             ex);
       }
-      if (ex.getMessage() != null)
+      if (ex.getMessage() != null) {
         throw new FunctionException(ex.getMessage(), ex);
-      else
+      } else {
         throw new FunctionException("Unexpected exception during function execution:", ex);
+      }
     }
   }
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionNoAckOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionNoAckOp.java
index 682efcf..c0933cd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionNoAckOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionNoAckOp.java
@@ -70,10 +70,11 @@ public class ExecuteRegionFunctionNoAckOp {
             "ExecuteRegionFunctionNoAckOp#execute : Exception occurred while Sending Function Execution Message: {} to server using pool: {}",
             op.getMessage(), pool, ex);
       }
-      if (ex.getMessage() != null)
+      if (ex.getMessage() != null) {
         throw new FunctionException(ex.getMessage(), ex);
-      else
+      } else {
         throw new FunctionException("Unexpected exception during function execution:", ex);
+      }
     }
   }
 
@@ -95,10 +96,11 @@ public class ExecuteRegionFunctionNoAckOp {
             "ExecuteRegionFunctionNoAckOp#execute : Exception occurred while Sending Function Execution Message: {} to server using pool: {}",
             op.getMessage(), pool, ex);
       }
-      if (ex.getMessage() != null)
+      if (ex.getMessage() != null) {
         throw new FunctionException(ex.getMessage(), ex);
-      else
+      } else {
         throw new FunctionException("Unexpected exception during function execution:", ex);
+      }
     }
   }
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionSingleHopOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionSingleHopOp.java
index 2d5abf1..a34769f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionSingleHopOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionSingleHopOp.java
@@ -296,8 +296,9 @@ public class ExecuteRegionFunctionSingleHopOp {
                       (InternalFunctionInvocationTargetException) ex.getCause();
                   failedNodes.addAll(ifite.getFailedNodeSet());
                 }
-                if (!ex.getMessage().equals("Buckets are null"))
+                if (!ex.getMessage().equals("Buckets are null")) {
                   exception = ex;
+                }
               } else if (result instanceof BucketMovedException) {
                 FunctionInvocationTargetException fite =
                     new InternalFunctionInvocationTargetException(
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetOp.java
index 71056d8..426f802 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetOp.java
@@ -83,8 +83,9 @@ public class GetOp {
           }
           cms.removeBucketServerLocation(server);
         } catch (CacheLoaderException e) {
-          if (e.getCause() instanceof ServerConnectivityException)
+          if (e.getCause() instanceof ServerConnectivityException) {
             cms.removeBucketServerLocation(server);
+          }
         }
       }
     }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
index 862209b..98b2286 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
@@ -285,8 +285,9 @@ public class PoolImpl implements InternalPool {
    * @since GemFire 6.5
    */
   public boolean isCompatible(Pool p) {
-    if (p == null)
+    if (p == null) {
       return false;
+    }
     return getFreeConnectionTimeout() == p.getFreeConnectionTimeout()
         && getSocketConnectTimeout() == p.getSocketConnectTimeout()
         && getLoadConditioningInterval() == p.getLoadConditioningInterval()
@@ -309,8 +310,9 @@ public class PoolImpl implements InternalPool {
   }
 
   private void start() {
-    if (startDisabled)
+    if (startDisabled) {
       return;
+    }
 
     final boolean isDebugEnabled = logger.isDebugEnabled();
     if (isDebugEnabled) {
@@ -941,10 +943,12 @@ public class PoolImpl implements InternalPool {
    * Test hook that returns the ThreadIdToSequenceIdMap
    */
   public Map getThreadIdToSequenceIdMap() {
-    if (queueManager == null)
+    if (queueManager == null) {
       return Collections.emptyMap();
-    if (queueManager.getState() == null)
+    }
+    if (queueManager.getState() == null) {
       return Collections.emptyMap();
+    }
     return queueManager.getState().getThreadIdToSequenceIdMap();
   }
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
index 6d8ba97..6d5e5cd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
@@ -202,10 +202,12 @@ public class PutOp {
       getMessage().addStringPart(regionName, true);
       getMessage().addBytePart(op.ordinal);
       int flags = 0;
-      if (requireOldValue)
+      if (requireOldValue) {
         flags |= 0x01;
-      if (expectedOldValue != null)
+      }
+      if (expectedOldValue != null) {
         flags |= 0x02;
+      }
       getMessage().addIntPart(flags);
       if (expectedOldValue != null) {
         getMessage().addObjPart(expectedOldValue);
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManagerImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManagerImpl.java
index 12b7d99..47249de 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManagerImpl.java
@@ -393,8 +393,9 @@ public class QueueManagerImpl implements QueueManager {
     QueueConnectionImpl deadConnection;
 
     synchronized (lock) {
-      if (shuttingDown)
+      if (shuttingDown) {
         return;
+      }
       // if same client updater then only remove as we don't know whether it has created new
       // updater/connection on same endpoint or not..
       deadConnection = queueConnections.getConnection(endpoint);
@@ -984,8 +985,9 @@ public class QueueManagerImpl implements QueueManager {
     boolean isBadConnection;
     synchronized (lock) {
       ClientUpdater cu = connection.getUpdater();
-      if (cu == null || (!cu.isAlive()) || (!cu.isProcessing()))
+      if (cu == null || (!cu.isAlive()) || (!cu.isProcessing())) {
         return false;// don't add
+      }
       // now still CCU can died but then it will execute Checkendpoint with lock it will remove
       // connection connection and it will reschedule it.
       if (connection.getEndpoint().isClosed() || shuttingDown
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
index f365676..656e007 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
@@ -311,8 +311,9 @@ public class QueueStateImpl implements QueueState {
               events);
           success = true;
         } catch (Exception ex) {
-          if (logger.isDebugEnabled())
+          if (logger.isDebugEnabled()) {
             logger.debug("Exception while sending an ack to the primary server: {}", ex);
+          }
         } finally {
           if (!success) {
             Iterator iter = events.iterator();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
index 3799d5d..f876cd5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
@@ -378,11 +378,12 @@ public class SingleHopClientExecutor {
 
   // Find out what exception to throw?
   private static RuntimeException executionThrowable(Throwable t) {
-    if (t instanceof RuntimeException)
+    if (t instanceof RuntimeException) {
       return (RuntimeException) t;
-    else if (t instanceof Error)
+    } else if (t instanceof Error) {
       throw (Error) t;
-    else
+    } else {
       throw new IllegalStateException("Don't know", t);
+    }
   }
 }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/PooledConnection.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/PooledConnection.java
index ae5df9d..d06e5bd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/PooledConnection.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/PooledConnection.java
@@ -181,8 +181,9 @@ public class PooledConnection implements Connection {
   public synchronized boolean switchConnection(Connection newCon) throws InterruptedException {
     Connection oldCon = null;
     synchronized (this) {
-      if (shouldDestroy())
+      if (shouldDestroy()) {
         return false;
+      }
 
       if (this.active && !shouldDestroy()) {
         this.waitingToSwitch = true;
@@ -195,8 +196,9 @@ public class PooledConnection implements Connection {
           notifyAll();
         }
       }
-      if (shouldDestroy())
+      if (shouldDestroy()) {
         return false;
+      }
       assert !this.active;
       final long now = System.nanoTime();
       oldCon = this.connection;
@@ -265,8 +267,9 @@ public class PooledConnection implements Connection {
    * is active we can't time it out now and a hint is returned as when we should check again.
    */
   public long doIdleTimeout(long now, long timeoutNanos) {
-    if (shouldDestroy())
+    if (shouldDestroy()) {
       return 0;
+    }
     synchronized (this) {
       if (isActive()) {
         // this is a reasonable value to return since odds are that
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractCompiledValue.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractCompiledValue.java
index 493c48d..f961dc8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractCompiledValue.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractCompiledValue.java
@@ -102,10 +102,11 @@ public abstract class AbstractCompiledValue implements CompiledValue, Filter, OQ
       // are also filterEvaluatable.
       planInfo = new PlanInfo();
       Object result = evaluate(context);
-      if (!(result instanceof Boolean))
+      if (!(result instanceof Boolean)) {
         throw new TypeMismatchException(
             String.format("boolean value expected, not type ' %s '",
                 result.getClass().getName()));
+      }
       boolean b = ((Boolean) result).booleanValue();
       planInfo.evalAsFilter = !b;
       return planInfo;
@@ -225,13 +226,15 @@ public abstract class AbstractCompiledValue implements CompiledValue, Filter, OQ
     // then this method as well as protGetPlanInfo must be overridden
     Support.Assert(!isDependentOnCurrentScope(context));
     Object result = evaluate(context);
-    if (result == null || result == QueryService.UNDEFINED)
+    if (result == null || result == QueryService.UNDEFINED) {
       return new ResultsBag(intermediateResults.getCollectionType().getElementType(), 0,
           context.getCachePerfStats());
-    if (!(result instanceof Boolean))
+    }
+    if (!(result instanceof Boolean)) {
       throw new TypeMismatchException(
           String.format("boolean value expected, not type ' %s '",
               result.getClass().getName()));
+    }
     boolean b = ((Boolean) result).booleanValue();
     // Asif : Boolean true, means the cartesian of all the RuntimeIterators
     // indicated by null value. A false means an empty ResultSet
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
index 4d77d36..7cbbdd7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
@@ -363,11 +363,14 @@ public abstract class AbstractGroupOrRangeJunction extends AbstractCompiledValue
     // using auxFilterEvaluate ,meaning no need to do iterations below )
     // but it can never be null. As null itself signifies that the junction
     // cannot be evaluated as a filter.
-    if (intermediateResults == null)
+    if (intermediateResults == null) {
       throw new RuntimeException(
           "intermediateResults can not be null");
+    }
     if (intermediateResults.isEmpty()) // short circuit
+    {
       return intermediateResults;
+    }
     List currentIters = (this.completeExpansion) ? context.getCurrentIterators()
         : QueryUtils.getDependentItrChainForIndpndntItrs(this.indpndntItr, context);
     SelectResults resultSet = null;
@@ -404,9 +407,10 @@ public abstract class AbstractGroupOrRangeJunction extends AbstractCompiledValue
           if (((Boolean) result).booleanValue()) {
             resultSet.add(tuple);
           }
-        } else if (result != null && result != QueryService.UNDEFINED)
+        } else if (result != null && result != QueryService.UNDEFINED) {
           throw new TypeMismatchException("AND/OR operands must be of type boolean, not type '"
               + result.getClass().getName() + "'");
+        }
       }
     } finally {
       observer.endIteration(resultSet);
@@ -459,8 +463,9 @@ public abstract class AbstractGroupOrRangeJunction extends AbstractCompiledValue
       result.isSingleFilter = true;
     } else {
       CompiledValue[] newOperands = new CompiledValue[indexCount];
-      for (int i = 0; i < indexCount; i++)
+      for (int i = 0; i < indexCount; i++) {
         newOperands[i] = (CompiledValue) evalOperands.get(i);
+      }
       filterOperands = new GroupJunction(getOperator(), getIndependentIteratorForGroup(),
           getExpansionFlag(), newOperands);
     }
@@ -478,12 +483,13 @@ public abstract class AbstractGroupOrRangeJunction extends AbstractCompiledValue
... 24222 lines suppressed ...