You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by kl...@apache.org on 2016/02/05 01:16:39 UTC

[33/33] incubator-geode git commit: Cleanup

Cleanup


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

Branch: refs/heads/feature/GEODE-773-2
Commit: c05f6798d70b478a08df1819d6f5f7d1d3fc9ffe
Parents: b17027b
Author: Kirk Lund <kl...@pivotal.io>
Authored: Thu Feb 4 16:15:25 2016 -0800
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Thu Feb 4 16:15:25 2016 -0800

----------------------------------------------------------------------
 .../cache/CacheRegionClearStatsDUnitTest.java   |   6 +-
 .../cache/ClientServerTimeSyncDUnitTest.java    |  20 +-
 .../cache/ConnectionPoolAndLoaderDUnitTest.java |  10 +-
 .../internal/AutoConnectionSourceDUnitTest.java |  40 +--
 .../internal/LocatorLoadBalancingDUnitTest.java |  44 +--
 .../cache/client/internal/LocatorTestBase.java  |  10 +-
 .../pooling/ConnectionManagerJUnitTest.java     |   6 +-
 .../management/MemoryThresholdsDUnitTest.java   |  24 +-
 .../MemoryThresholdsOffHeapDUnitTest.java       |  14 +-
 .../mapInterface/PutAllGlobalLockJUnitTest.java |   4 +-
 .../PartitionRegionHelperDUnitTest.java         |  12 +-
 .../query/dunit/CompactRangeIndexDUnitTest.java |   4 +-
 .../cache/query/dunit/HashIndexDUnitTest.java   |   4 +-
 .../cache/query/dunit/HelperTestCase.java       |   4 +-
 .../query/dunit/PdxStringQueryDUnitTest.java    | 204 ++++++------
 .../dunit/QueryDataInconsistencyDUnitTest.java  |  18 +-
 .../dunit/QueryIndexUsingXMLDUnitTest.java      |  46 +--
 .../QueryParamsAuthorizationDUnitTest.java      |   4 +-
 .../QueryUsingFunctionContextDUnitTest.java     |   8 +-
 .../query/dunit/QueryUsingPoolDUnitTest.java    | 112 +++----
 .../cache/query/dunit/RemoteQueryDUnitTest.java |  44 +--
 ...esourceManagerWithQueryMonitorDUnitTest.java |  15 +-
 .../query/dunit/SelectStarQueryDUnitTest.java   |  50 +--
 .../IndexCreationDeadLockJUnitTest.java         |   6 +-
 .../functional/LikePredicateJUnitTest.java      |   4 +-
 .../internal/ExecutionContextJUnitTest.java     |   4 +-
 .../index/AsynchIndexMaintenanceJUnitTest.java  |   4 +-
 ...rrentIndexInitOnOverflowRegionDUnitTest.java |  29 +-
 ...ndexOperationsOnOverflowRegionDUnitTest.java |  48 ++-
 ...pdateWithInplaceObjectModFalseDUnitTest.java |  30 +-
 ...ConcurrentIndexUpdateWithoutWLDUnitTest.java |  38 +--
 .../index/CopyOnReadIndexDUnitTest.java         |   8 +-
 .../index/IndexCreationInternalsJUnitTest.java  |   6 +-
 .../index/IndexMaintainceJUnitTest.java         |   4 +-
 .../IndexTrackingQueryObserverDUnitTest.java    |   4 +-
 ...itializeIndexEntryDestroyQueryDUnitTest.java |  18 +-
 .../index/MultiIndexCreationDUnitTest.java      |  14 +-
 .../index/PutAllWithIndexPerfDUnitTest.java     |   8 +-
 .../PRBasicIndexCreationDUnitTest.java          | 104 +++---
 .../PRBasicIndexCreationDeadlockDUnitTest.java  |   4 +-
 .../PRBasicMultiIndexCreationDUnitTest.java     |  86 ++---
 .../partitioned/PRBasicQueryDUnitTest.java      |  34 +-
 .../PRBasicRemoveIndexDUnitTest.java            |   8 +-
 .../PRColocatedEquiJoinDUnitTest.java           | 300 ++++++++---------
 .../partitioned/PRInvalidQueryDUnitTest.java    |  18 +-
 .../partitioned/PRQueryCacheCloseDUnitTest.java |  68 ++--
 .../PRQueryCacheClosedJUnitTest.java            |   6 +-
 .../query/partitioned/PRQueryDUnitHelper.java   | 144 ++++-----
 .../query/partitioned/PRQueryDUnitTest.java     | 154 ++++-----
 .../query/partitioned/PRQueryPerfDUnitTest.java |  10 +-
 .../PRQueryRegionCloseDUnitTest.java            |  34 +-
 .../PRQueryRegionDestroyedDUnitTest.java        |  36 +--
 .../PRQueryRegionDestroyedJUnitTest.java        |   6 +-
 .../PRQueryRemoteNodeExceptionDUnitTest.java    | 136 ++++----
 .../snapshot/SnapshotByteArrayDUnitTest.java    |   8 +-
 .../snapshot/SnapshotPerformanceDUnitTest.java  |  18 +-
 .../gemfire/cache30/Bug35214DUnitTest.java      |   8 +-
 .../gemfire/cache30/Bug38741DUnitTest.java      |   4 +-
 .../gemfire/cache30/CacheMapTxnDUnitTest.java   |   7 +-
 ...cheRegionsReliablityStatsCheckDUnitTest.java |   4 +-
 .../gemstone/gemfire/cache30/CacheTestCase.java |   4 +-
 .../gemfire/cache30/CacheXml30DUnitTest.java    |   4 +-
 .../gemfire/cache30/CacheXml57DUnitTest.java    |   4 +-
 .../cache30/ClearMultiVmCallBkDUnitTest.java    |  14 +-
 .../gemfire/cache30/ClearMultiVmDUnitTest.java  |   9 +-
 .../cache30/ClientMembershipDUnitTest.java      | 132 ++++----
 .../ClientRegisterInterestDUnitTest.java        |  42 +--
 .../cache30/ClientServerCCEDUnitTest.java       |  44 +--
 .../gemfire/cache30/ClientServerTestCase.java   |   4 +-
 .../ConcurrentLeaveDuringGIIDUnitTest.java      |   4 +-
 .../gemfire/cache30/DiskRegionDUnitTest.java    |  16 +-
 .../cache30/DistAckMapMethodsDUnitTest.java     |   6 +-
 .../cache30/DistributedAckRegionDUnitTest.java  |   4 +-
 .../DistributedNoAckRegionCCEDUnitTest.java     |  10 +-
 .../DistributedNoAckRegionDUnitTest.java        |  32 +-
 .../gemfire/cache30/DynamicRegionDUnitTest.java |  16 +-
 .../gemfire/cache30/GlobalLockingDUnitTest.java |   8 +-
 .../gemfire/cache30/GlobalRegionDUnitTest.java  |  14 +-
 .../cache30/LRUEvictionControllerDUnitTest.java |   4 +-
 .../gemfire/cache30/MultiVMRegionTestCase.java  | 134 ++++----
 .../PRBucketSynchronizationDUnitTest.java       |  20 +-
 .../cache30/PartitionedRegionDUnitTest.java     |   2 +-
 .../cache30/PutAllCallBkRemoteVMDUnitTest.java  |  24 +-
 .../cache30/PutAllCallBkSingleVMDUnitTest.java  |  20 +-
 .../cache30/RRSynchronizationDUnitTest.java     |  20 +-
 .../gemfire/cache30/ReconnectDUnitTest.java     | 106 +++---
 .../cache30/RegionExpirationDUnitTest.java      |  10 +-
 .../RegionMembershipListenerDUnitTest.java      |  16 +-
 .../cache30/RegionReliabilityTestCase.java      |   5 +-
 .../gemfire/cache30/RegionTestCase.java         |  10 +-
 .../gemfire/cache30/RequiredRolesDUnitTest.java |  14 +-
 .../cache30/RolePerformanceDUnitTest.java       |   6 +-
 .../gemfire/cache30/SearchAndLoadDUnitTest.java |  12 +-
 .../gemfire/cache30/SlowRecDUnitTest.java       | 102 +++---
 .../gemfire/cache30/TXDistributedDUnitTest.java |   4 +-
 .../gemfire/cache30/TXOrderDUnitTest.java       |   6 +-
 .../distributed/DistributedSystemDUnitTest.java |  14 +-
 .../gemfire/distributed/LocatorDUnitTest.java   | 132 ++++----
 .../distributed/SystemAdminDUnitTest.java       |   8 +-
 .../ConsoleDistributionManagerDUnitTest.java    |  12 +-
 .../internal/DistributionManagerDUnitTest.java  |  14 +-
 .../GemFireDeadlockDetectorDUnitTest.java       |   6 +-
 .../internal/locks/CollaborationJUnitTest.java  |  18 +-
 .../gemfire/disttx/DistTXDebugDUnitTest.java    | 110 +++----
 .../disttx/DistTXPersistentDebugDUnitTest.java  |  10 +-
 .../disttx/DistributedTransactionDUnitTest.java |  12 +-
 .../ClassNotFoundExceptionDUnitTest.java        |   4 +-
 .../gemfire/internal/JSSESocketJUnitTest.java   |   4 +-
 .../internal/PdxDeleteFieldDUnitTest.java       |   4 +-
 .../gemfire/internal/PdxRenameDUnitTest.java    |   4 +-
 .../gemfire/internal/cache/BackupDUnitTest.java |  46 +--
 .../internal/cache/Bug33359DUnitTest.java       |   8 +-
 .../internal/cache/Bug37241DUnitTest.java       |  10 +-
 .../internal/cache/Bug37377DUnitTest.java       |   5 +-
 .../internal/cache/Bug39079DUnitTest.java       |   4 +-
 .../internal/cache/Bug41091DUnitTest.java       |  12 +-
 .../internal/cache/Bug41957DUnitTest.java       |   8 +-
 .../internal/cache/Bug45164DUnitTest.java       |   4 +-
 .../internal/cache/Bug47667DUnitTest.java       |   4 +-
 .../internal/cache/ClearDAckDUnitTest.java      |  24 +-
 .../internal/cache/ClearGlobalDUnitTest.java    |  12 +-
 .../cache/ClientServerGetAllDUnitTest.java      |  24 +-
 ...ServerInvalidAndDestroyedEntryDUnitTest.java |  24 +-
 .../ClientServerTransactionCCEDUnitTest.java    |   4 +-
 .../cache/ClientServerTransactionDUnitTest.java |  54 ++--
 .../cache/ConcurrentMapOpsDUnitTest.java        |   4 +-
 .../ConcurrentRegionOperationsJUnitTest.java    |  18 +-
 ...rentRollingAndRegionOperationsJUnitTest.java |   4 +-
 .../cache/ConnectDisconnectDUnitTest.java       |  10 +-
 .../cache/DeltaPropagationDUnitTest.java        |   2 +-
 .../cache/DeltaPropagationStatsDUnitTest.java   |  10 +-
 .../internal/cache/DeltaSizingDUnitTest.java    |   6 +-
 .../cache/DiskRegionClearJUnitTest.java         |   4 +-
 .../internal/cache/DiskRegionJUnitTest.java     |  38 +--
 .../cache/DistributedCacheTestCase.java         |  12 +-
 .../internal/cache/EventTrackerDUnitTest.java   |   8 +-
 .../internal/cache/EvictionDUnitTest.java       |  10 +-
 .../cache/EvictionObjectSizerDUnitTest.java     |  18 +-
 .../internal/cache/EvictionStatsDUnitTest.java  |  18 +-
 .../internal/cache/EvictionTestBase.java        |  20 +-
 .../cache/FixedPRSinglehopDUnitTest.java        |  14 +-
 .../internal/cache/GIIDeltaDUnitTest.java       |  22 +-
 .../internal/cache/GridAdvisorDUnitTest.java    |  26 +-
 .../internal/cache/HABug36773DUnitTest.java     |  10 +-
 .../HAOverflowMemObjectSizerDUnitTest.java      |   6 +-
 .../cache/IncrementalBackupDUnitTest.java       |   6 +-
 .../internal/cache/MapClearGIIDUnitTest.java    |  14 +-
 .../internal/cache/MapInterface2JUnitTest.java  |   6 +-
 .../cache/NetSearchMessagingDUnitTest.java      |  10 +-
 .../cache/OffHeapEvictionDUnitTest.java         |  10 +-
 .../cache/OffHeapEvictionStatsDUnitTest.java    |  10 +-
 .../gemfire/internal/cache/OplogJUnitTest.java  |  10 +-
 .../cache/PartitionedRegionAPIDUnitTest.java    |  24 +-
 ...gionBucketCreationDistributionDUnitTest.java |  88 ++---
 .../PartitionedRegionCacheCloseDUnitTest.java   |  10 +-
 .../PartitionedRegionCreationDUnitTest.java     |  52 +--
 .../cache/PartitionedRegionDUnitTestCase.java   |   4 +-
 .../PartitionedRegionDestroyDUnitTest.java      |  18 +-
 .../cache/PartitionedRegionHADUnitTest.java     |  18 +-
 ...onedRegionHAFailureAndRecoveryDUnitTest.java |  42 +--
 ...artitionedRegionLocalMaxMemoryDUnitTest.java |   6 +-
 .../PartitionedRegionMultipleDUnitTest.java     |  58 ++--
 .../cache/PartitionedRegionPRIDDUnitTest.java   |  18 +-
 .../cache/PartitionedRegionQueryDUnitTest.java  |  12 +-
 ...tionedRegionSerializableObjectJUnitTest.java |   4 +-
 .../PartitionedRegionSingleHopDUnitTest.java    |  78 ++---
 ...RegionSingleHopWithServerGroupDUnitTest.java | 104 +++---
 .../cache/PartitionedRegionSizeDUnitTest.java   |  18 +-
 .../PartitionedRegionTestUtilsDUnitTest.java    |  10 +-
 .../PartitionedRegionWithSameNameDUnitTest.java |  44 +--
 .../internal/cache/PutAllDAckDUnitTest.java     |   6 +-
 .../internal/cache/PutAllGlobalDUnitTest.java   |  28 +-
 .../cache/RemoteTransactionDUnitTest.java       |  14 +-
 .../internal/cache/RemoveAllDAckDUnitTest.java  |   6 +-
 .../internal/cache/RemoveDAckDUnitTest.java     |   4 +-
 .../internal/cache/RemoveGlobalDUnitTest.java   |  10 +-
 .../cache/SimpleDiskRegionJUnitTest.java        |  12 +-
 .../internal/cache/SingleHopStatsDUnitTest.java |  24 +-
 .../internal/cache/SystemFailureDUnitTest.java  |  20 +-
 .../cache/TXReservationMgrJUnitTest.java        |   4 +-
 .../cache/TransactionsWithDeltaDUnitTest.java   |  12 +-
 .../control/RebalanceOperationDUnitTest.java    |  12 +-
 ...ltiThreadedOplogPerJUnitPerformanceTest.java |   4 +-
 .../cache/execute/Bug51193DUnitTest.java        |   4 +-
 .../ClientServerFunctionExecutionDUnitTest.java |  66 ++--
 .../execute/ColocationFailoverDUnitTest.java    |  10 +-
 ...ributedRegionFunctionExecutionDUnitTest.java |  24 +-
 .../execute/FunctionServiceStatsDUnitTest.java  |  26 +-
 .../cache/execute/LocalDataSetDUnitTest.java    |  10 +-
 .../LocalFunctionExecutionDUnitTest.java        |   6 +-
 .../MemberFunctionExecutionDUnitTest.java       |  22 +-
 .../OnGroupsFunctionExecutionDUnitTest.java     |  44 +--
 ...ntServerFunctionExecutionNoAckDUnitTest.java |  36 +--
 ...tServerRegionFunctionExecutionDUnitTest.java |  46 +--
 ...egionFunctionExecutionFailoverDUnitTest.java |  36 +--
 ...onFunctionExecutionNoSingleHopDUnitTest.java |  40 +--
 ...onExecutionSelectorNoSingleHopDUnitTest.java |  40 +--
 ...gionFunctionExecutionSingleHopDUnitTest.java |  40 +--
 .../cache/execute/PRClientServerTestBase.java   |  30 +-
 .../cache/execute/PRColocationDUnitTest.java    |  82 ++---
 .../execute/PRCustomPartitioningDUnitTest.java  |   6 +-
 .../execute/PRFunctionExecutionDUnitTest.java   |  24 +-
 ...ctionExecutionWithResultSenderDUnitTest.java |   4 +-
 .../execute/PRPerformanceTestDUnitTest.java     |  10 +-
 .../cache/execute/PRTransactionDUnitTest.java   |  30 +-
 .../ha/BlockingHARQAddOperationJUnitTest.java   |   8 +-
 .../cache/ha/BlockingHARegionJUnitTest.java     |  42 +--
 .../cache/ha/Bug36853EventsExpiryDUnitTest.java |  18 +-
 .../internal/cache/ha/Bug48571DUnitTest.java    |   4 +-
 .../cache/ha/EventIdOptimizationDUnitTest.java  |  18 +-
 .../internal/cache/ha/FailoverDUnitTest.java    |   4 +-
 .../internal/cache/ha/HABugInPutDUnitTest.java  |   6 +-
 .../internal/cache/ha/HAClearDUnitTest.java     |  18 +-
 .../cache/ha/HAConflationDUnitTest.java         |   4 +-
 .../internal/cache/ha/HADuplicateDUnitTest.java |   4 +-
 .../cache/ha/HAEventIdPropagationDUnitTest.java |  16 +-
 .../internal/cache/ha/HAGIIBugDUnitTest.java    |  20 +-
 .../internal/cache/ha/HAGIIDUnitTest.java       |   4 +-
 .../cache/ha/HARQAddOperationJUnitTest.java     |  24 +-
 .../cache/ha/HARQueueNewImplDUnitTest.java      |  78 ++---
 .../cache/ha/HARegionQueueDUnitTest.java        |   8 +-
 .../cache/ha/HARegionQueueJUnitTest.java        |  26 +-
 .../cache/ha/HASlowReceiverDUnitTest.java       |   4 +-
 .../ha/OperationsPropagationDUnitTest.java      |   4 +-
 .../internal/cache/ha/PutAllDUnitTest.java      |  12 +-
 .../internal/cache/ha/StatsBugDUnitTest.java    |  20 +-
 .../cache/locks/TXLockServiceDUnitTest.java     |  42 +--
 .../cache/partitioned/Bug39356DUnitTest.java    |   2 +-
 .../cache/partitioned/Bug43684DUnitTest.java    |   4 +-
 .../cache/partitioned/Bug51400DUnitTest.java    |   8 +-
 .../partitioned/PersistPRKRFDUnitTest.java      |   9 +-
 .../PersistentPartitionedRegionDUnitTest.java   |  12 +-
 .../PersistentPartitionedRegionTestBase.java    |   8 +-
 ...rtitionedRegionWithTransactionDUnitTest.java |   8 +-
 .../fixed/FixedPartitioningTestBase.java        |  50 +--
 .../PersistentRVVRecoveryDUnitTest.java         |   8 +-
 .../PersistentRecoveryOrderDUnitTest.java       |  92 +++---
 ...mpatibilityHigherVersionClientDUnitTest.java |   4 +-
 .../cache/tier/sockets/Bug36269DUnitTest.java   |   6 +-
 .../cache/tier/sockets/Bug36457DUnitTest.java   |  10 +-
 .../cache/tier/sockets/Bug36805DUnitTest.java   |   6 +-
 .../cache/tier/sockets/Bug36829DUnitTest.java   |   4 +-
 .../cache/tier/sockets/Bug36995DUnitTest.java   |   8 +-
 .../cache/tier/sockets/Bug37210DUnitTest.java   |  12 +-
 .../cache/tier/sockets/Bug37805DUnitTest.java   |   4 +-
 .../cache/tier/sockets/CacheServerTestUtil.java |  18 +-
 .../CacheServerTransactionsDUnitTest.java       |  48 +--
 .../tier/sockets/ClearPropagationDUnitTest.java |  14 +-
 .../tier/sockets/ClientConflationDUnitTest.java |  10 +-
 .../sockets/ClientInterestNotifyDUnitTest.java  |  14 +-
 .../tier/sockets/ClientServerMiscDUnitTest.java |  34 +-
 .../cache/tier/sockets/ConflationDUnitTest.java |  32 +-
 .../DataSerializerPropogationDUnitTest.java     |  43 +--
 .../DestroyEntryPropagationDUnitTest.java       |  16 +-
 .../sockets/DurableClientBug39997DUnitTest.java |   4 +-
 .../DurableClientQueueSizeDUnitTest.java        |   4 +-
 .../DurableClientReconnectAutoDUnitTest.java    |   6 +-
 .../DurableClientReconnectDUnitTest.java        |  56 ++--
 .../sockets/DurableClientStatsDUnitTest.java    |  10 +-
 .../sockets/DurableRegistrationDUnitTest.java   |  22 +-
 .../sockets/DurableResponseMatrixDUnitTest.java |   4 +-
 .../sockets/EventIDVerificationDUnitTest.java   |   4 +-
 .../ForceInvalidateEvictionDUnitTest.java       |   4 +-
 .../cache/tier/sockets/HABug36738DUnitTest.java |   8 +-
 .../tier/sockets/HAInterestPart1DUnitTest.java  |  18 +-
 .../tier/sockets/HAInterestPart2DUnitTest.java  |  18 +-
 .../cache/tier/sockets/HAInterestTestCase.java  |   5 +-
 .../sockets/HAStartupAndFailoverDUnitTest.java  |  20 +-
 .../InstantiatorPropagationDUnitTest.java       |  36 +--
 .../tier/sockets/InterestListDUnitTest.java     |  46 +--
 .../sockets/InterestListEndpointDUnitTest.java  |   4 +-
 .../sockets/InterestListFailoverDUnitTest.java  |   6 +-
 .../sockets/InterestListRecoveryDUnitTest.java  |   8 +-
 .../sockets/InterestRegrListenerDUnitTest.java  |  48 +--
 .../sockets/InterestResultPolicyDUnitTest.java  |  10 +-
 .../sockets/RedundancyLevelPart1DUnitTest.java  |  26 +-
 .../sockets/RedundancyLevelPart2DUnitTest.java  |  24 +-
 .../sockets/RedundancyLevelPart3DUnitTest.java  |   8 +-
 .../tier/sockets/RedundancyLevelTestBase.java   |   4 +-
 .../tier/sockets/RegionCloseDUnitTest.java      |   4 +-
 ...erInterestBeforeRegionCreationDUnitTest.java |   6 +-
 .../sockets/RegisterInterestKeysDUnitTest.java  |  10 +-
 .../sockets/ReliableMessagingDUnitTest.java     |  22 +-
 .../sockets/UnregisterInterestDUnitTest.java    |   4 +-
 .../sockets/UpdatePropagationDUnitTest.java     |  10 +-
 ...UpdatesFromNonInterestEndPointDUnitTest.java |   4 +-
 .../versions/RegionVersionVectorJUnitTest.java  |   4 +-
 .../cache/wan/AsyncEventQueueTestBase.java      |  20 +-
 .../asyncqueue/AsyncEventListenerDUnitTest.java |  42 +--
 .../CompressionCacheConfigDUnitTest.java        |   8 +-
 .../CompressionRegionConfigDUnitTest.java       |  14 +-
 .../internal/jta/dunit/ExceptionsDUnitTest.java |  12 +-
 .../jta/dunit/IdleTimeOutDUnitTest.java         |  50 +--
 .../jta/dunit/LoginTimeOutDUnitTest.java        |   7 +-
 .../jta/dunit/MaxPoolSizeDUnitTest.java         |  36 +--
 .../jta/dunit/TransactionTimeOutDUnitTest.java  |  14 +-
 .../dunit/TxnManagerMultiThreadDUnitTest.java   |  70 ++--
 .../internal/jta/dunit/TxnTimeOutDUnitTest.java |  26 +-
 .../logging/MergeLogFilesJUnitTest.java         |   4 +-
 .../management/CacheManagementDUnitTest.java    |  14 +-
 .../management/ClientHealthStatsDUnitTest.java  |  14 +-
 .../management/DLockManagementDUnitTest.java    |  12 +-
 .../management/DiskManagementDUnitTest.java     |  28 +-
 .../management/DistributedSystemDUnitTest.java  |  20 +-
 .../management/LocatorManagementDUnitTest.java  |  12 +-
 .../gemstone/gemfire/management/MBeanUtil.java  |   4 +-
 .../gemfire/management/ManagementTestBase.java  |  12 +-
 .../MemberMBeanAttributesDUnitTest.java         |   4 +-
 .../gemfire/management/QueryDataDUnitTest.java  |  18 +-
 .../management/RegionManagementDUnitTest.java   |  44 +--
 ...ersalMembershipListenerAdapterDUnitTest.java | 140 ++++----
 .../internal/cli/CliUtilDUnitTest.java          |  26 +-
 .../cli/commands/CliCommandTestBase.java        |  10 +-
 .../cli/commands/ConfigCommandsDUnitTest.java   |  26 +-
 ...eateAlterDestroyRegionCommandsDUnitTest.java |  34 +-
 .../commands/DiskStoreCommandsDUnitTest.java    |  24 +-
 .../cli/commands/FunctionCommandsDUnitTest.java |  52 +--
 .../commands/GemfireDataCommandsDUnitTest.java  | 168 +++++-----
 ...WithCacheLoaderDuringCacheMissDUnitTest.java |   4 +-
 .../cli/commands/IndexCommandsDUnitTest.java    |   6 +-
 ...stAndDescribeDiskStoreCommandsDUnitTest.java |   8 +-
 .../ListAndDescribeRegionDUnitTest.java         |  30 +-
 .../cli/commands/ListIndexCommandDUnitTest.java |  16 +-
 .../cli/commands/MemberCommandsDUnitTest.java   |  14 +-
 .../MiscellaneousCommandsDUnitTest.java         |  22 +-
 ...laneousCommandsExportLogsPart1DUnitTest.java |  10 +-
 ...laneousCommandsExportLogsPart2DUnitTest.java |  10 +-
 ...laneousCommandsExportLogsPart3DUnitTest.java |  10 +-
 ...laneousCommandsExportLogsPart4DUnitTest.java |  10 +-
 .../cli/commands/QueueCommandsDUnitTest.java    |   4 +-
 .../SharedConfigurationCommandsDUnitTest.java   |  14 +-
 .../cli/commands/ShellCommandsDUnitTest.java    |  16 +-
 .../cli/commands/ShowDeadlockDUnitTest.java     |   6 +-
 .../cli/commands/ShowMetricsDUnitTest.java      |  24 +-
 .../cli/commands/ShowStackTraceDUnitTest.java   |  22 +-
 .../internal/pulse/TestClientIdsDUnitTest.java  |  12 +-
 .../internal/pulse/TestFunctionsDUnitTest.java  |   4 +-
 .../internal/pulse/TestHeapDUnitTest.java       |   4 +-
 .../internal/pulse/TestLocatorsDUnitTest.java   |   4 +-
 .../pulse/TestSubscriptionsDUnitTest.java       |  10 +-
 .../ClientsWithVersioningRetryDUnitTest.java    |  16 +-
 .../pdx/JSONPdxClientServerDUnitTest.java       |   6 +-
 .../gemfire/pdx/PdxClientServerDUnitTest.java   |  12 +-
 .../gemfire/pdx/PdxTypeExportDUnitTest.java     |   4 +-
 .../gemfire/pdx/VersionClassLoader.java         |  10 +-
 .../gemfire/redis/RedisDistDUnitTest.java       |   8 +-
 .../security/ClientAuthenticationDUnitTest.java |  90 +++---
 .../security/ClientAuthorizationDUnitTest.java  |  56 ++--
 .../security/ClientAuthorizationTestBase.java   |  22 +-
 .../security/ClientMultiUserAuthzDUnitTest.java |  36 +--
 .../DeltaClientAuthorizationDUnitTest.java      |  36 +--
 .../DeltaClientPostAuthorizationDUnitTest.java  |  18 +-
 .../security/P2PAuthenticationDUnitTest.java    |  32 +-
 .../gemfire/security/SecurityTestUtil.java      | 188 +++++------
 .../com/gemstone/gemfire/test/dunit/Assert.java |  32 +-
 .../gemfire/test/dunit/AsyncInvocation.java     |  17 +-
 .../gemstone/gemfire/test/dunit/DUnitEnv.java   |   1 -
 .../gemfire/test/dunit/DebuggerSupport.java     |  33 --
 .../gemfire/test/dunit/DebuggerUtils.java       |  52 +++
 .../test/dunit/DistributedSystemSupport.java    |  82 -----
 .../gemfire/test/dunit/DistributedTestCase.java |  15 +-
 .../test/dunit/DistributedTestSupport.java      | 106 ------
 .../test/dunit/DistributedTestUtils.java        | 169 ++++++++++
 .../com/gemstone/gemfire/test/dunit/Host.java   |   5 +-
 .../gemfire/test/dunit/IgnoredException.java    | 178 +++++-----
 .../com/gemstone/gemfire/test/dunit/Invoke.java | 102 +++---
 .../gemfire/test/dunit/LogWriterSupport.java    |  72 -----
 .../gemfire/test/dunit/LogWriterUtils.java      |  95 ++++++
 .../gemfire/test/dunit/NetworkSupport.java      |  48 ---
 .../gemfire/test/dunit/NetworkUtils.java        |  69 ++++
 .../gemfire/test/dunit/RMIException.java        |   2 +-
 .../gemfire/test/dunit/RepeatableRunnable.java  |   4 +-
 .../test/dunit/SerializableCallableIF.java      |   4 +-
 .../test/dunit/SerializableRunnable.java        |   3 +-
 .../test/dunit/SerializableRunnableIF.java      |   4 +-
 .../test/dunit/StoppableWaitCriterion.java      |  12 +-
 .../gemfire/test/dunit/ThreadUtils.java         | 155 +++++++++
 .../gemstone/gemfire/test/dunit/Threads.java    | 138 --------
 .../com/gemstone/gemfire/test/dunit/VM.java     |  50 +--
 .../com/gemstone/gemfire/test/dunit/Wait.java   | 246 +++++++-------
 .../gemfire/test/dunit/WaitCriterion.java       |  13 +-
 .../cache/query/cq/dunit/CqDataDUnitTest.java   |  62 ++--
 .../cq/dunit/CqDataUsingPoolDUnitTest.java      |  54 ++--
 .../cache/query/cq/dunit/CqPerfDUnitTest.java   |  44 +--
 .../cq/dunit/CqPerfUsingPoolDUnitTest.java      |  42 +--
 .../cache/query/cq/dunit/CqQueryDUnitTest.java  | 206 ++++++------
 .../dunit/CqQueryOptimizedExecuteDUnitTest.java |  14 +-
 .../cq/dunit/CqQueryUsingPoolDUnitTest.java     | 166 +++++-----
 .../cq/dunit/CqResultSetUsingPoolDUnitTest.java |  56 ++--
 ...ltSetUsingPoolOptimizedExecuteDUnitTest.java |  14 +-
 .../cache/query/cq/dunit/CqStateDUnitTest.java  |   9 +-
 .../cache/query/cq/dunit/CqStatsDUnitTest.java  |  12 +-
 .../cq/dunit/CqStatsUsingPoolDUnitTest.java     |  12 +-
 .../PartitionedRegionCqQueryDUnitTest.java      |  58 ++--
 ...dRegionCqQueryOptimizedExecuteDUnitTest.java |  12 +-
 .../query/cq/dunit/PrCqUsingPoolDUnitTest.java  |  56 ++--
 .../cache/query/dunit/PdxQueryCQDUnitTest.java  |  32 +-
 .../cache/query/dunit/PdxQueryCQTestBase.java   |  18 +-
 .../dunit/QueryIndexUpdateRIDUnitTest.java      |  46 +--
 .../query/dunit/QueryMonitorDUnitTest.java      |  38 +--
 .../cache/snapshot/ClientSnapshotDUnitTest.java |   8 +-
 .../cache/PRDeltaPropagationDUnitTest.java      |   4 +-
 .../internal/cache/PutAllCSDUnitTest.java       | 324 +++++++++----------
 .../cache/RemoteCQTransactionDUnitTest.java     |   4 +-
 .../internal/cache/ha/CQListGIIDUnitTest.java   |  30 +-
 .../cache/ha/HADispatcherDUnitTest.java         |  12 +-
 .../sockets/ClientToServerDeltaDUnitTest.java   |  20 +-
 .../DeltaPropagationWithCQDUnitTest.java        |  10 +-
 ...ToRegionRelationCQRegistrationDUnitTest.java |  20 +-
 .../sockets/DurableClientSimpleDUnitTest.java   |  54 ++--
 .../tier/sockets/DurableClientTestCase.java     |  56 ++--
 .../CacheServerManagementDUnitTest.java         |  28 +-
 .../cli/commands/ClientCommandsDUnitTest.java   |  14 +-
 .../DurableClientCommandsDUnitTest.java         |  12 +-
 .../internal/pulse/TestCQDUnitTest.java         |  10 +-
 .../internal/pulse/TestClientsDUnitTest.java    |   8 +-
 .../internal/pulse/TestServerDUnitTest.java     |   4 +-
 .../security/ClientAuthzObjectModDUnitTest.java |  10 +-
 .../ClientCQPostAuthorizationDUnitTest.java     |  28 +-
 .../ClientPostAuthorizationDUnitTest.java       |  16 +-
 .../gemfire/security/MultiuserAPIDUnitTest.java |  12 +-
 .../MultiuserDurableCQAuthzDUnitTest.java       |  20 +-
 .../internal/cache/UpdateVersionDUnitTest.java  |  10 +-
 .../gemfire/internal/cache/wan/WANTestBase.java |  68 ++--
 ...oncurrentParallelGatewaySenderDUnitTest.java |   4 +-
 ...allelGatewaySenderOperation_1_DUnitTest.java |  36 +--
 ...allelGatewaySenderOperation_2_DUnitTest.java |  12 +-
 .../ConcurrentWANPropogation_1_DUnitTest.java   |   4 +-
 .../cache/wan/disttx/DistTXWANDUnitTest.java    |   4 +-
 .../CommonParallelGatewaySenderDUnitTest.java   |  20 +-
 ...wWANConcurrencyCheckForDestroyDUnitTest.java |  14 +-
 ...dRegion_ParallelWANPersistenceDUnitTest.java |  50 +--
 ...dRegion_ParallelWANPropogationDUnitTest.java |  12 +-
 ...downAllPersistentGatewaySenderDUnitTest.java |   4 +-
 .../wan/misc/WANLocatorServerDUnitTest.java     |   4 +-
 .../wan/misc/WanAutoDiscoveryDUnitTest.java     |   4 +-
 ...arallelGatewaySenderOperationsDUnitTest.java |  28 +-
 ...llelGatewaySenderQueueOverflowDUnitTest.java |  18 +-
 ...ersistenceEnabledGatewaySenderDUnitTest.java | 180 +++++------
 .../ParallelWANPropagationDUnitTest.java        |   4 +-
 .../SerialGatewaySenderOperationsDUnitTest.java |  14 +-
 ...ersistenceEnabledGatewaySenderDUnitTest.java |  62 ++--
 .../serial/SerialWANPropogationDUnitTest.java   |  40 +--
 .../management/WANManagementDUnitTest.java      |   4 +-
 .../ClusterConfigurationDUnitTest.java          |   4 +-
 .../pulse/TestRemoteClusterDUnitTest.java       |   4 +-
 446 files changed, 6265 insertions(+), 6123 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java
index 8908abc..17a3dc8 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java
@@ -28,7 +28,7 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.VM;
 /**
  * verifies the count of clear operation
@@ -153,7 +153,7 @@ public class CacheRegionClearStatsDUnitTest extends DistributedTestCase {
 
     client1.invoke(CacheRegionClearStatsDUnitTest.class,
         "createClientCache", new Object[] {
-            NetworkSupport.getServerHostName(server1.getHost()), port1 });
+            NetworkUtils.getServerHostName(server1.getHost()), port1 });
     client1.invoke(CacheRegionClearStatsDUnitTest.class, "put");
     
     try{
@@ -178,7 +178,7 @@ public class CacheRegionClearStatsDUnitTest extends DistributedTestCase {
 
     client1.invoke(CacheRegionClearStatsDUnitTest.class,
         "createClientCacheDisk", new Object[] {
-            NetworkSupport.getServerHostName(server1.getHost()), port1 });
+            NetworkUtils.getServerHostName(server1.getHost()), port1 });
     client1.invoke(CacheRegionClearStatsDUnitTest.class, "put");
     
     try{

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
index 7e21875..8166318 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
@@ -31,8 +31,8 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.dunit.LogWriterSupport;
-import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.test.dunit.Wait;
@@ -63,7 +63,7 @@ public class ClientServerTimeSyncDUnitTest extends CacheTestCase {
         public Object call() {
           Cache cache = getCache();
           cache.createRegionFactory(RegionShortcut.REPLICATE).create(regionName);
-          LogWriterSupport.getLogWriter().info("Done creating region, now creating CacheServer");
+          LogWriterUtils.getLogWriter().info("Done creating region, now creating CacheServer");
           CacheServer server = null;
           try {
             server = cache.addCacheServer();
@@ -76,12 +76,12 @@ public class ClientServerTimeSyncDUnitTest extends CacheTestCase {
           // now set an artificial time offset for the test
           system.getClock().setCacheTimeOffset(null, TEST_OFFSET, true);
           
-          LogWriterSupport.getLogWriter().info("Done creating and starting CacheServer on port " + server.getPort());
+          LogWriterUtils.getLogWriter().info("Done creating and starting CacheServer on port " + server.getPort());
           return server.getPort();
         }
       });
       
-      final String hostName = NetworkSupport.getServerHostName(vm0.getHost());
+      final String hostName = NetworkUtils.getServerHostName(vm0.getHost());
   
       // Start client with proxy region and register interest
         
@@ -103,7 +103,7 @@ public class ClientServerTimeSyncDUnitTest extends CacheTestCase {
       WaitCriterion wc = new WaitCriterion() {
         public boolean done() {
           long clientTimeOffset = clock.getCacheTimeOffset();
-          LogWriterSupport.getLogWriter().info("Client node's new time offset is: " + clientTimeOffset);
+          LogWriterUtils.getLogWriter().info("Client node's new time offset is: " + clientTimeOffset);
           return clientTimeOffset >= TEST_OFFSET;
         }
         public String description() {
@@ -140,7 +140,7 @@ public class ClientServerTimeSyncDUnitTest extends CacheTestCase {
         public Object call() {
           Cache cache = getCache();
           cache.createRegionFactory(RegionShortcut.REPLICATE).create(regionName);
-          LogWriterSupport.getLogWriter().info("Done creating region, now creating CacheServer");
+          LogWriterUtils.getLogWriter().info("Done creating region, now creating CacheServer");
           CacheServer server = null;
           try {
             server = cache.addCacheServer();
@@ -153,14 +153,14 @@ public class ClientServerTimeSyncDUnitTest extends CacheTestCase {
           // now set an artificial time offset for the test
           system.getClock().setCacheTimeOffset(null, -TEST_OFFSET, true);
           
-          LogWriterSupport.getLogWriter().info("Done creating and starting CacheServer on port " + server.getPort());
+          LogWriterUtils.getLogWriter().info("Done creating and starting CacheServer on port " + server.getPort());
           return server.getPort();
         }
       });
       
       Wait.pause((int)TEST_OFFSET);  // let cacheTimeMillis consume the time offset
       
-      final String hostName = NetworkSupport.getServerHostName(vm0.getHost());
+      final String hostName = NetworkUtils.getServerHostName(vm0.getHost());
   
       // Start client with proxy region and register interest
         
@@ -182,7 +182,7 @@ public class ClientServerTimeSyncDUnitTest extends CacheTestCase {
       WaitCriterion wc = new WaitCriterion() {
         public boolean done() {
           long clientTimeOffset = clock.getCacheTimeOffset();
-          LogWriterSupport.getLogWriter().info("Client node's new time offset is: " + clientTimeOffset);
+          LogWriterUtils.getLogWriter().info("Client node's new time offset is: " + clientTimeOffset);
           if (clientTimeOffset >= 0) {
             return false;
           }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java
index ba6412a..ee382ab 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java
@@ -28,7 +28,7 @@ import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -94,7 +94,7 @@ public class ConnectionPoolAndLoaderDUnitTest  extends CacheTestCase {
       public Object call() {
         Cache cache = getCache();
         PoolFactory factory = PoolManager.createFactory();
-        factory.addServer(NetworkSupport.getServerHostName(host), serverPort);
+        factory.addServer(NetworkUtils.getServerHostName(host), serverPort);
         factory.create("pool1");
         
         AttributesFactory af = new AttributesFactory();
@@ -173,7 +173,7 @@ public class ConnectionPoolAndLoaderDUnitTest  extends CacheTestCase {
       public Object call() {
         Cache cache = getCache();
         PoolFactory factory = PoolManager.createFactory();
-        factory.addServer(NetworkSupport.getServerHostName(host), serverPort);
+        factory.addServer(NetworkUtils.getServerHostName(host), serverPort);
         factory.create("pool1");
         
         AttributesFactory af = new AttributesFactory();
@@ -283,7 +283,7 @@ public class ConnectionPoolAndLoaderDUnitTest  extends CacheTestCase {
         Cache cache = getCache();
         useLocator = false;
         PoolFactory factory = PoolManager.createFactory();
-        factory.addServer(NetworkSupport.getServerHostName(host), serverPort);
+        factory.addServer(NetworkUtils.getServerHostName(host), serverPort);
         factory.create("pool1");
         AttributesFactory af = new AttributesFactory();
         af.setDataPolicy(DataPolicy.NORMAL);
@@ -305,7 +305,7 @@ public class ConnectionPoolAndLoaderDUnitTest  extends CacheTestCase {
         Cache cache = getCache();
         useLocator = false;
         PoolFactory factory = PoolManager.createFactory();
-        factory.addServer(NetworkSupport.getServerHostName(host), serverPort);
+        factory.addServer(NetworkUtils.getServerHostName(host), serverPort);
         factory.create("pool1");
         AttributesFactory af = new AttributesFactory();
         af.setDataPolicy(DataPolicy.NORMAL);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
index 374950d..b0f3b59 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
@@ -38,7 +38,7 @@ import com.gemstone.gemfire.management.membership.ClientMembershipEvent;
 import com.gemstone.gemfire.management.membership.ClientMembershipListenerAdapter;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.IgnoredException;
-import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -74,11 +74,11 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     int locatorPort = AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET);
     startLocatorInVM(vm0, locatorPort, "");
     
-    String locators = NetworkSupport.getServerHostName(vm0.getHost())+ "[" + locatorPort + "]";
+    String locators = NetworkUtils.getServerHostName(vm0.getHost())+ "[" + locatorPort + "]";
     
     startBridgeServerInVM(vm1, null, locators);
 
-    startBridgeClientInVM(vm2, null, NetworkSupport.getServerHostName(vm0.getHost()), locatorPort);
+    startBridgeClientInVM(vm2, null, NetworkUtils.getServerHostName(vm0.getHost()), locatorPort);
 
     putAndWaitForSuccess(vm2, REGION_NAME, "key", "value");
     
@@ -91,7 +91,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     VM vm0 = host.getVM(0);
     
     try {
-      startBridgeClientInVM(vm0, null, NetworkSupport.getServerHostName(vm0.getHost()), AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET));
+      startBridgeClientInVM(vm0, null, NetworkUtils.getServerHostName(vm0.getHost()), AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET));
       putInVM(vm0, "key", "value");
       fail("Client cache should not have been able to start");
     } catch(Exception e) {
@@ -107,7 +107,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     int locatorPort = AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET);
     startLocatorInVM(vm0, locatorPort, "");
     try { 
-      startBridgeClientInVM(vm1, null, NetworkSupport.getServerHostName(vm0.getHost()), locatorPort);
+      startBridgeClientInVM(vm1, null, NetworkUtils.getServerHostName(vm0.getHost()), locatorPort);
       putInVM(vm0, "key", "value");
       fail("Client cache should not have been able to start");
     } catch(Exception e) {
@@ -125,11 +125,11 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     int locatorPort = AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET);
     startLocatorInVM(vm0, locatorPort, "");
     
-    String locators = NetworkSupport.getServerHostName(vm0.getHost()) + "[" + locatorPort + "]";
+    String locators = NetworkUtils.getServerHostName(vm0.getHost()) + "[" + locatorPort + "]";
     
     startBridgeServerInVM(vm1, null, locators);
     
-    startBridgeClientInVM(vm2, null, NetworkSupport.getServerHostName(vm0.getHost()), locatorPort);
+    startBridgeClientInVM(vm2, null, NetworkUtils.getServerHostName(vm0.getHost()), locatorPort);
     
     putAndWaitForSuccess(vm2, REGION_NAME, "key", "value");
     
@@ -144,7 +144,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
   
   public void testDynamicallyFindLocators() throws Exception {
     final Host host = Host.getHost(0);
-    final String hostName = NetworkSupport.getServerHostName(host);
+    final String hostName = NetworkUtils.getServerHostName(host);
     VM vm0 = host.getVM(0);
     VM vm1 = host.getVM(1);
     VM vm2 = host.getVM(2);
@@ -159,7 +159,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     startLocatorInVM(vm0, locatorPort0, locators);
     
     startLocatorInVM(vm1, locatorPort1, locators);
-    startBridgeClientInVM(vm2, null, NetworkSupport.getServerHostName(vm0.getHost()), locatorPort0);
+    startBridgeClientInVM(vm2, null, NetworkUtils.getServerHostName(vm0.getHost()), locatorPort0);
     
     InetSocketAddress locatorToWaitFor= new InetSocketAddress(hostName, locatorPort1);
     waitForLocatorDiscovery(vm2, locatorToWaitFor);
@@ -190,11 +190,11 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     
     int locatorPort = AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET);
     
-    String locators = NetworkSupport.getServerHostName(vm0.getHost()) + "[" + locatorPort + "]";
+    String locators = NetworkUtils.getServerHostName(vm0.getHost()) + "[" + locatorPort + "]";
     
     startBridgeServerWithEmbeddedLocator(vm0, null, locators, new String[] {REGION_NAME}, CacheServer.DEFAULT_LOAD_PROBE);
     
-    startBridgeClientInVM(vm2, null, NetworkSupport.getServerHostName(vm0.getHost()), locatorPort);
+    startBridgeClientInVM(vm2, null, NetworkUtils.getServerHostName(vm0.getHost()), locatorPort);
     
     putAndWaitForSuccess(vm2, REGION_NAME, "key", "value");
     
@@ -226,13 +226,13 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     int locatorPort = AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET);
     startLocatorInVM(vm0, locatorPort, "");
     
-    String locators = NetworkSupport.getServerHostName(vm0.getHost()) + "[" + locatorPort + "]";
+    String locators = NetworkUtils.getServerHostName(vm0.getHost()) + "[" + locatorPort + "]";
     
     startBridgeServerInVM(vm1, new String[] {"group1", "group2"} , locators, new String[] {"A", "B"});
     startBridgeServerInVM(vm2, new String[] {"group2", "group3"}, locators, new String[] {"B", "C"});
 
     
-    startBridgeClientInVM(vm3, "group1", NetworkSupport.getServerHostName(vm0.getHost()), locatorPort, new String [] {"A", "B", "C"});
+    startBridgeClientInVM(vm3, "group1", NetworkUtils.getServerHostName(vm0.getHost()), locatorPort, new String [] {"A", "B", "C"});
     putAndWaitForSuccess(vm3, "A", "key", "value");
     Assert.assertEquals("value", getInVM(vm1, "A", "key"));
     try {
@@ -242,7 +242,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     
     stopBridgeMemberVM(vm3);
     
-    startBridgeClientInVM(vm3, "group3", NetworkSupport.getServerHostName(vm0.getHost()), locatorPort, new String [] {"A", "B", "C"});
+    startBridgeClientInVM(vm3, "group3", NetworkUtils.getServerHostName(vm0.getHost()), locatorPort, new String [] {"A", "B", "C"});
     try {
       putInVM(vm3, "A", "key3", "value");
       fail("Should not have been able to find Region A on the server");
@@ -252,7 +252,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     
     stopBridgeMemberVM(vm3);
     
-    startBridgeClientInVM(vm3, "group2", NetworkSupport.getServerHostName(vm0.getHost()), locatorPort, new String [] {"A", "B", "C"});
+    startBridgeClientInVM(vm3, "group2", NetworkUtils.getServerHostName(vm0.getHost()), locatorPort, new String [] {"A", "B", "C"});
     putInVM(vm3, "B", "key5", "value");
     Assert.assertEquals("value", getInVM(vm1, "B", "key5"));
     Assert.assertEquals("value", getInVM(vm2, "B", "key5"));
@@ -278,18 +278,18 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     
     startLocatorInVM(vm0, locatorPort, "");
     
-    final String locators = NetworkSupport.getServerHostName(vm0.getHost()) + "[" + locatorPort + "]";
+    final String locators = NetworkUtils.getServerHostName(vm0.getHost()) + "[" + locatorPort + "]";
     
     final int serverPort1 =startBridgeServerInVM(vm1, new String[] {"group1"}, locators);
     final int serverPort2 =addCacheServerInVM(vm1, new String[] {"group2"});
     
-    startBridgeClientInVM(vm2, "group2", NetworkSupport.getServerHostName(vm0.getHost()), locatorPort);
+    startBridgeClientInVM(vm2, "group2", NetworkUtils.getServerHostName(vm0.getHost()), locatorPort);
     
     checkEndpoints(vm2, new int[] {serverPort2});
     
     stopBridgeMemberVM(vm2);
 
-    startBridgeClientInVM(vm2, "group1", NetworkSupport.getServerHostName(vm0.getHost()), locatorPort);
+    startBridgeClientInVM(vm2, "group1", NetworkUtils.getServerHostName(vm0.getHost()), locatorPort);
     
     checkEndpoints(vm2, new int[] {serverPort1});
   }
@@ -302,7 +302,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
     VM clientVM = host.getVM(3);
     int locatorPort = AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET);
     startLocatorInVM(locatorVM, locatorPort, "");
-    String locators = NetworkSupport.getServerHostName(locatorVM.getHost()) + "[" + locatorPort + "]";
+    String locators = NetworkUtils.getServerHostName(locatorVM.getHost()) + "[" + locatorPort + "]";
 
     //start a bridge server with a listener
     addBridgeListener(bridge1VM);
@@ -310,7 +310,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
 
     //start a bridge client with a listener
     addBridgeListener(clientVM);
-    startBridgeClientInVM(clientVM, null, NetworkSupport.getServerHostName(locatorVM.getHost()), locatorPort);
+    startBridgeClientInVM(clientVM, null, NetworkUtils.getServerHostName(locatorVM.getHost()), locatorPort);
     // wait for client to connect
     checkEndpoints(clientVM, new int[] {serverPort1});
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
index 8ed8baf..3c6a980 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
@@ -48,8 +48,8 @@ import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.internal.logging.LocalLogWriter;
 import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.dunit.LogWriterSupport;
-import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -101,7 +101,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     int serverPort = startBridgeServerInVM(vm1, new String[] {"a", "b"},  locators);
     
     ServerLoad expectedLoad = new ServerLoad(0f, 1 / 800.0f, 0f, 1f);
-    ServerLocation expectedLocation = new ServerLocation(NetworkSupport.getServerHostName(vm0
+    ServerLocation expectedLocation = new ServerLocation(NetworkUtils.getServerHostName(vm0
         .getHost()), serverPort);
     Map expected = new HashMap();
     expected.put(expectedLocation, expectedLoad);
@@ -110,7 +110,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     
     int serverPort2 = startBridgeServerInVM(vm2, new String[] {"a", "b"},  locators);
     
-    ServerLocation expectedLocation2 = new ServerLocation(NetworkSupport.getServerHostName(vm0
+    ServerLocation expectedLocation2 = new ServerLocation(NetworkUtils.getServerHostName(vm0
         .getHost()), serverPort2);
     
     expected.put(expectedLocation2, expectedLoad);
@@ -133,18 +133,18 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     int serverPort = startBridgeServerInVM(vm1, new String[] {"a", "b"},  locators);
     
     ServerLoad expectedLoad = new ServerLoad(2/800f, 1 / 800.0f, 0f, 1f);
-    ServerLocation expectedLocation = new ServerLocation(NetworkSupport.getServerHostName(host), serverPort);
+    ServerLocation expectedLocation = new ServerLocation(NetworkUtils.getServerHostName(host), serverPort);
     Map expected = new HashMap();
     expected.put(expectedLocation, expectedLoad);
     
     ClientConnectionResponse response;
     response = (ClientConnectionResponse) TcpClient.requestToServer(InetAddress
-        .getByName(NetworkSupport.getServerHostName(host)), locatorPort,
+        .getByName(NetworkUtils.getServerHostName(host)), locatorPort,
         new ClientConnectionRequest(Collections.EMPTY_SET, null), 10000);
     Assert.assertEquals(expectedLocation, response.getServer());
     
     response = (ClientConnectionResponse) TcpClient.requestToServer(InetAddress
-        .getByName(NetworkSupport.getServerHostName(host)), locatorPort,
+        .getByName(NetworkUtils.getServerHostName(host)), locatorPort,
         new ClientConnectionRequest(Collections.EMPTY_SET, null), 10000, true);
     Assert.assertEquals(expectedLocation, response.getServer());
     
@@ -153,13 +153,13 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     
     QueueConnectionResponse response2;
     response2 = (QueueConnectionResponse) TcpClient.requestToServer(InetAddress
-        .getByName(NetworkSupport.getServerHostName(host)), locatorPort,
+        .getByName(NetworkUtils.getServerHostName(host)), locatorPort,
         new QueueConnectionRequest(null, 2,
             Collections.EMPTY_SET, null, false), 10000, true);
     Assert.assertEquals(Collections.singletonList(expectedLocation), response2.getServers());
     
     response2 = (QueueConnectionResponse) TcpClient
-        .requestToServer(InetAddress.getByName(NetworkSupport.getServerHostName(host)),
+        .requestToServer(InetAddress.getByName(NetworkUtils.getServerHostName(host)),
             locatorPort, new QueueConnectionRequest(null, 5, Collections.EMPTY_SET, null,
                 false), 10000, true);
     
@@ -189,13 +189,13 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     
     //We expect 0 load
     Map expected = new HashMap();
-    ServerLocation expectedLocation = new ServerLocation(NetworkSupport.getServerHostName(host), serverPort);
+    ServerLocation expectedLocation = new ServerLocation(NetworkUtils.getServerHostName(host), serverPort);
     ServerLoad expectedLoad = new ServerLoad(0f, 1 / 800.0f, 0f, 1f);
     expected.put(expectedLocation, expectedLoad);
     checkLocatorLoad(vm0, expected);
     
     PoolFactoryImpl pf = new PoolFactoryImpl(null);
-    pf.addServer(NetworkSupport.getServerHostName(host), serverPort);
+    pf.addServer(NetworkUtils.getServerHostName(host), serverPort);
     pf.setMinConnections(8);
     pf.setMaxConnections(8);
     pf.setSubscriptionEnabled(true);
@@ -236,7 +236,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     startBridgeServerInVM(vm2, new String[] {"a", "b"},  locators);
     
     PoolFactoryImpl pf = new PoolFactoryImpl(null);
-    pf.addLocator(NetworkSupport.getServerHostName(host), locatorPort);
+    pf.addLocator(NetworkUtils.getServerHostName(host), locatorPort);
     pf.setMinConnections(80);
     pf.setMaxConnections(80);
     pf.setSubscriptionEnabled(false);
@@ -324,7 +324,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     startBridgeServerInVM(vm3, new String[] {"b"},  locators);
     
     PoolFactoryImpl pf = new PoolFactoryImpl(null);
-    pf.addLocator(NetworkSupport.getServerHostName(host), locatorPort);
+    pf.addLocator(NetworkUtils.getServerHostName(host), locatorPort);
     pf.setMinConnections(12);
     pf.setSubscriptionEnabled(false);
     pf.setServerGroup("a");
@@ -336,7 +336,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     checkConnectionCount(vm2, 6);
     checkConnectionCount(vm3, 0);
     
-    LogWriterSupport.getLogWriter().info("pool1 prefilled");
+    LogWriterUtils.getLogWriter().info("pool1 prefilled");
     
     PoolFactoryImpl pf2 = (PoolFactoryImpl) PoolManager.createFactory();
     pf2.init(pf.getPoolAttributes());
@@ -350,9 +350,9 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     checkConnectionCount(vm2, 9);
     checkConnectionCount(vm3, 9);
     
-    LogWriterSupport.getLogWriter().info("pool2 prefilled");
+    LogWriterUtils.getLogWriter().info("pool2 prefilled");
     
-    ServerLocation location1 = new ServerLocation(NetworkSupport.getServerHostName(host), serverPort1);
+    ServerLocation location1 = new ServerLocation(NetworkUtils.getServerHostName(host), serverPort1);
     PoolImpl pool1 = (PoolImpl) PoolManager.getAll().get(POOL_NAME);
     Assert.assertEquals("a", pool1.getServerGroup());
     
@@ -361,7 +361,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
       pool1.acquireConnection();
     }
     
-    LogWriterSupport.getLogWriter().info("aquired 15 connections in pool1");
+    LogWriterUtils.getLogWriter().info("aquired 15 connections in pool1");
     
     //now the load should be equal
     checkConnectionCount(vm1, 9);
@@ -373,7 +373,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
       pool2.acquireConnection();
     }
     
-    LogWriterSupport.getLogWriter().info("aquired 12 connections in pool2");
+    LogWriterUtils.getLogWriter().info("aquired 12 connections in pool2");
     
     //interleave creating connections in both pools
     for(int i = 0; i < 6; i++) {
@@ -381,7 +381,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
       pool2.acquireConnection();
     }
     
-    LogWriterSupport.getLogWriter().info("interleaved 6 connections from pool1 with 6 connections from pool2");
+    LogWriterUtils.getLogWriter().info("interleaved 6 connections from pool1 with 6 connections from pool2");
     
     //The load should still be balanced
     checkConnectionCount(vm1, 13);
@@ -407,8 +407,8 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     int serverPort2 = startBridgeServerInVM(vm2, null, locators, new String[] {REGION_NAME}, new MyLoadProbe(load2 ));
     
     HashMap expected = new HashMap();
-    ServerLocation l1 = new ServerLocation(NetworkSupport.getServerHostName(host), serverPort1);
-    ServerLocation l2 = new ServerLocation(NetworkSupport.getServerHostName(host), serverPort2);
+    ServerLocation l1 = new ServerLocation(NetworkUtils.getServerHostName(host), serverPort1);
+    ServerLocation l2 = new ServerLocation(NetworkUtils.getServerHostName(host), serverPort2);
     expected.put(l1, load1);
     expected.put(l2, load2);
     checkLocatorLoad(vm0, expected);
@@ -428,7 +428,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
     checkLocatorLoad(vm0, expected);
     
     PoolFactoryImpl pf = new PoolFactoryImpl(null);
-    pf.addLocator(NetworkSupport.getServerHostName(host), locatorPort);
+    pf.addLocator(NetworkUtils.getServerHostName(host), locatorPort);
     pf.setMinConnections(20);
     pf.setSubscriptionEnabled(true);
     pf.setIdleTimeout(-1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java
index fb2411d..88459bf 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java
@@ -46,8 +46,8 @@ import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.Invoke;
-import com.gemstone.gemfire.test.dunit.LogWriterSupport;
-import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -112,14 +112,14 @@ public abstract class LocatorTestBase  extends DistributedTestCase {
         Properties props = new Properties();
         props.setProperty(DistributionConfig.MCAST_PORT_NAME, String.valueOf(0));
         props.setProperty(DistributionConfig.LOCATORS_NAME, otherLocators);
-        props.setProperty(DistributionConfig.LOG_LEVEL_NAME, LogWriterSupport.getDUnitLogLevel());
+        props.setProperty(DistributionConfig.LOG_LEVEL_NAME, LogWriterUtils.getDUnitLogLevel());
         props.setProperty(DistributionConfig.ENABLE_CLUSTER_CONFIGURATION_NAME, "false");
         try {
           File logFile = new File(testName + "-locator" + locatorPort
               + ".log");
           InetAddress bindAddr = null;
           try {
-            bindAddr = InetAddress.getByName(NetworkSupport.getServerHostName(vm.getHost()));
+            bindAddr = InetAddress.getByName(NetworkUtils.getServerHostName(vm.getHost()));
           } catch (UnknownHostException uhe) {
             Assert.fail("While resolving bind address ", uhe);
           }
@@ -306,7 +306,7 @@ public abstract class LocatorTestBase  extends DistributedTestCase {
   public String getLocatorString(Host host, int[] locatorPorts) {
     StringBuffer str = new StringBuffer();
     for(int i = 0; i < locatorPorts.length; i++) {
-      str.append(NetworkSupport.getServerHostName(host))
+      str.append(NetworkUtils.getServerHostName(host))
           .append("[")
           .append(locatorPorts[i])
           .append("]");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java
index 03a170c..d0b2991 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java
@@ -59,7 +59,7 @@ import com.gemstone.gemfire.internal.cache.PoolStats;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ServerQueueStatus;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.internal.logging.LocalLogWriter;
-import com.gemstone.gemfire.test.dunit.Threads;
+import com.gemstone.gemfire.test.dunit.ThreadUtils;
 import com.gemstone.gemfire.test.dunit.Wait;
 import com.gemstone.gemfire.test.dunit.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
@@ -427,7 +427,7 @@ public class ConnectionManagerJUnitTest {
     }
     
     for(int i = 0; i < updaterCount; i++) {
-      Threads.join(updaters[i], 30 * 1000, null);
+      ThreadUtils.join(updaters[i], 30 * 1000);
     }
 
     if(exception.get() !=null) {
@@ -491,7 +491,7 @@ public class ConnectionManagerJUnitTest {
     }
     
     for(int i = 0; i < updaterCount; i++) {
-      Threads.join(updaters[i], 30 * 1000, null);
+      ThreadUtils.join(updaters[i], 30 * 1000);
     }
 
     if(exception.get() !=null) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
index 4c10044..4e4b10f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
@@ -82,12 +82,12 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
-import com.gemstone.gemfire.test.dunit.DistributedTestSupport;
+import com.gemstone.gemfire.test.dunit.DistributedTestUtils;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.IgnoredException;
 import com.gemstone.gemfire.test.dunit.Invoke;
-import com.gemstone.gemfire.test.dunit.LogWriterSupport;
-import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -481,7 +481,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
     verifyListenerValue(server1, MemoryState.EVICTION, 2, true);
     verifyListenerValue(server1, MemoryState.NORMAL, 1, true);
     
-    LogWriterSupport.getLogWriter().info("before NORMAL->CRITICAL->NORMAL");
+    LogWriterUtils.getLogWriter().info("before NORMAL->CRITICAL->NORMAL");
     //NORMAL -> EVICTION -> NORMAL
     server2.invoke(new SerializableCallable("NORMAL->CRITICAL->NORMAL") {
       public Object call() throws Exception {
@@ -491,7 +491,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
         return null;
       }
     });
-    LogWriterSupport.getLogWriter().info("after NORMAL->CRITICAL->NORMAL");
+    LogWriterUtils.getLogWriter().info("after NORMAL->CRITICAL->NORMAL");
 
     verifyListenerValue(server2, MemoryState.CRITICAL, 2, true);
     verifyListenerValue(server2, MemoryState.EVICTION, 3, true);
@@ -668,7 +668,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
       server1.invoke(new SerializableCallable("local destroy sick member") {
         public Object call() throws Exception {
           Region r = getRootRegion().getSubregion(regionName);
-          LogWriterSupport.getLogWriter().info("PRLocalDestroy");
+          LogWriterUtils.getLogWriter().info("PRLocalDestroy");
           r.localDestroyRegion();
           return null;
         }
@@ -1287,7 +1287,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
         getCache();
 
         PoolFactory pf = PoolManager.createFactory();
-        pf.addServer(NetworkSupport.getServerHostName(server.getHost()), serverPort);
+        pf.addServer(NetworkUtils.getServerHostName(server.getHost()), serverPort);
         pf.create("pool1");
         
         AttributesFactory af = new AttributesFactory();
@@ -1358,7 +1358,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
             assertFalse("Key " + me + " should not exist", r.containsKey(me));
           }
         } catch (LowMemoryException low) {
-          LogWriterSupport.getLogWriter().info("Caught LowMemoryException", low);
+          LogWriterUtils.getLogWriter().info("Caught LowMemoryException", low);
           if (!catchLowMemoryException) {
             Assert.fail("Unexpected exception: ", low);
           }
@@ -1577,7 +1577,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
 
   protected Properties getServerProperties() {
     Properties p = new Properties();
-    p.setProperty(DistributionConfig.LOCATORS_NAME, "localhost["+DistributedTestSupport.getDUnitLocatorPort()+"]");
+    p.setProperty(DistributionConfig.LOCATORS_NAME, "localhost["+DistributedTestUtils.getDUnitLocatorPort()+"]");
     return p;
   }
 
@@ -1664,7 +1664,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
       }
     };
     final String tenuredPoolName = HeapMemoryMonitor.getTenuredMemoryPoolMXBean().getName();
-    LogWriterSupport.getLogWriter().info("TenuredPoolName:"+tenuredPoolName);
+    LogWriterUtils.getLogWriter().info("TenuredPoolName:"+tenuredPoolName);
     final List list = internalSystem.getStatsList();
     assertFalse(list.isEmpty());
     
@@ -1674,10 +1674,10 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
         int i=0;
         synchronized (list) {
           for (Object o : list) {
-            LogWriterSupport.getLogWriter().info("List:"+(++i)+":"+o);
+            LogWriterUtils.getLogWriter().info("List:"+(++i)+":"+o);
             if (o instanceof StatisticsImpl) {
               StatisticsImpl si = (StatisticsImpl)o;
-              LogWriterSupport.getLogWriter().info("stat:"+si.getTextId());
+              LogWriterUtils.getLogWriter().info("stat:"+si.getTextId());
               if (si.getTextId().contains(tenuredPoolName)) {
                 sampler.addLocalStatListener(l, si, "currentUsedMemory");
                 return true;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
index d67d8bc..4a205f3 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
@@ -71,12 +71,12 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
-import com.gemstone.gemfire.test.dunit.DistributedTestSupport;
+import com.gemstone.gemfire.test.dunit.DistributedTestUtils;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.IgnoredException;
 import com.gemstone.gemfire.test.dunit.Invoke;
-import com.gemstone.gemfire.test.dunit.LogWriterSupport;
-import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -869,7 +869,7 @@ public class MemoryThresholdsOffHeapDUnitTest extends ClientServerTestCase {
         vm.invoke(new SerializableCallable("local destroy sick member") {
           public Object call() throws Exception {
             Region r = getRootRegion().getSubregion(regionName);
-            LogWriterSupport.getLogWriter().info("PRLocalDestroy");
+            LogWriterUtils.getLogWriter().info("PRLocalDestroy");
             r.localDestroyRegion();
             return null;
           }
@@ -1371,7 +1371,7 @@ public class MemoryThresholdsOffHeapDUnitTest extends ClientServerTestCase {
             assertFalse("Key " + me + " should not exist", r.containsKey(me));
           }
         } catch (LowMemoryException low) {
-          LogWriterSupport.getLogWriter().info("Caught LowMemoryException", low);
+          LogWriterUtils.getLogWriter().info("Caught LowMemoryException", low);
           if (!catchLowMemoryException) {
             Assert.fail("Unexpected exception: ", low);
           }
@@ -1655,7 +1655,7 @@ public class MemoryThresholdsOffHeapDUnitTest extends ClientServerTestCase {
         getCache();
 
         PoolFactory pf = PoolManager.createFactory();
-        pf.addServer(NetworkSupport.getServerHostName(server.getHost()), serverPort);
+        pf.addServer(NetworkUtils.getServerHostName(server.getHost()), serverPort);
         pf.create("pool1");
         
         AttributesFactory af = new AttributesFactory();
@@ -1816,7 +1816,7 @@ public class MemoryThresholdsOffHeapDUnitTest extends ClientServerTestCase {
   
   private Properties getOffHeapProperties() {
     Properties p = new Properties();
-    p.setProperty(DistributionConfig.LOCATORS_NAME, "localhost["+DistributedTestSupport.getDUnitLocatorPort()+"]");
+    p.setProperty(DistributionConfig.LOCATORS_NAME, "localhost["+DistributedTestUtils.getDUnitLocatorPort()+"]");
     p.setProperty(DistributionConfig.OFF_HEAP_MEMORY_SIZE_NAME, "1m");
     return p;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java
index 76313d9..2f9be54 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java
@@ -36,7 +36,7 @@ import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.test.dunit.Threads;
+import com.gemstone.gemfire.test.dunit.ThreadUtils;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
 @Category(IntegrationTest.class)
@@ -79,7 +79,7 @@ public class PutAllGlobalLockJUnitTest {
         }
         try {
             testRegion.putAll(trialMap);
-            Threads.join(this.thread, 30 * 1000, null);
+            ThreadUtils.join(this.thread, 30 * 1000);
             assertTrue(this.testOK);
         } catch (Exception e) {
             fail("Test has failed due to "+e);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java
index 4e4f4b6..d09c6e0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java
@@ -47,7 +47,7 @@ import com.gemstone.gemfire.internal.cache.partitioned.fixed.FixedPartitioningTe
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.dunit.LogWriterSupport;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -469,7 +469,7 @@ public class PartitionRegionHelperDUnitTest extends CacheTestCase {
           assertTrue(buk0.getBucketAdvisor().isPrimary());
         }
         catch (ForceReattemptException e) {
-          LogWriterSupport.getLogWriter().severe(e);
+          LogWriterUtils.getLogWriter().severe(e);
           fail();
         }
       }
@@ -486,14 +486,14 @@ public class PartitionRegionHelperDUnitTest extends CacheTestCase {
           assertNotNull(k1e);
         }
         catch (ForceReattemptException e) {
-          LogWriterSupport.getLogWriter().severe(e);
+          LogWriterUtils.getLogWriter().severe(e);
           fail();
         }
       }
     };
     for (DistributedMember bom: buk0AllMems) {
       VM v = d2v.get(bom);
-      LogWriterSupport.getLogWriter().info("Visiting bucket owner member " + bom + " for key " + buk0Key1);
+      LogWriterUtils.getLogWriter().info("Visiting bucket owner member " + bom + " for key " + buk0Key1);
       v.invoke(assertHasBucket);
     }
 
@@ -508,14 +508,14 @@ public class PartitionRegionHelperDUnitTest extends CacheTestCase {
           assertFalse(buk0.getBucketAdvisor().isPrimary());
         }
         catch (ForceReattemptException e) {
-          LogWriterSupport.getLogWriter().severe(e);
+          LogWriterUtils.getLogWriter().severe(e);
           fail();
         }
       }
     };
     for (DistributedMember redm: buk0Redundants) {
       VM v = d2v.get(redm);
-      LogWriterSupport.getLogWriter().info("Visiting redundant member " + redm + " for key " + buk0Key1);
+      LogWriterUtils.getLogWriter().info("Visiting redundant member " + redm + " for key " + buk0Key1);
       v.invoke(assertRed);
     }
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java
index b4988c0..3ce0ce2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java
@@ -28,7 +28,7 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable.CacheSerializableR
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
-import com.gemstone.gemfire.test.dunit.DistributedTestSupport;
+import com.gemstone.gemfire.test.dunit.DistributedTestUtils;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.Invoke;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
@@ -55,7 +55,7 @@ public class CompactRangeIndexDUnitTest extends DistributedTestCase{
     Host host = Host.getHost(0);
     vm0 = host.getVM(0);
     utils = new QueryTestUtils();
-    utils.createServer(vm0, DistributedTestSupport.getAllDistributedSystemProperties(new Properties()));
+    utils.createServer(vm0, DistributedTestUtils.getAllDistributedSystemProperties(new Properties()));
     utils.createReplicateRegion("exampleRegion", vm0);
     utils.createIndex(vm0,"type", "\"type\"", "/exampleRegion");
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java
index a5ed9a2..c73aa80 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java
@@ -22,7 +22,7 @@ import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.query.QueryTestUtils;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
-import com.gemstone.gemfire.test.dunit.DistributedTestSupport;
+import com.gemstone.gemfire.test.dunit.DistributedTestUtils;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.Invoke;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
@@ -48,7 +48,7 @@ public class HashIndexDUnitTest extends DistributedTestCase{
     Host host = Host.getHost(0);
     vm0 = host.getVM(0);
     utils = new QueryTestUtils();
-    utils.createServer(vm0, DistributedTestSupport.getAllDistributedSystemProperties(new Properties()));
+    utils.createServer(vm0, DistributedTestUtils.getAllDistributedSystemProperties(new Properties()));
     utils.createReplicateRegion("exampleRegion", vm0);
     utils.createHashIndex(vm0,"ID", "r.ID", "/exampleRegion r");
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c05f6798/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java
index 6461333..f4132da 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java
@@ -46,7 +46,7 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
-import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -240,7 +240,7 @@ public class HelperTestCase extends CacheTestCase {
         
         final ClientCacheFactory ccf = new ClientCacheFactory(properties);
         for (int i = 0; i < servers.length; i++) {
-          ccf.addPoolServer(NetworkSupport.getServerHostName(servers[i].getHost()), ports[i]);
+          ccf.addPoolServer(NetworkUtils.getServerHostName(servers[i].getHost()), ports[i]);
         }
         ccf.setPoolSubscriptionEnabled(true);
         ccf.setPoolSubscriptionRedundancy(redundancyLevel);