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

[51/51] [abbrv] [partial] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-917

Merge remote-tracking branch 'origin/develop' into feature/GEODE-917


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

Branch: refs/heads/feature/GEODE-917
Commit: 5beaaedcebdd08f17a9a4cc169178b9c4af5f567
Parents: 8780b5c 110a5b4
Author: Dan Smith <up...@apache.org>
Authored: Fri Feb 19 11:31:08 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Fri Feb 19 11:39:33 2016 -0800

----------------------------------------------------------------------
 LICENSE                                         |    6 +
 NOTICE                                          |   10 +
 geode-assembly/build.gradle                     |    7 +-
 geode-assembly/src/main/dist/LICENSE            |    5 +
 geode-assembly/src/src/dist/gradlew             |  221 ++
 .../management/internal/AgentUtilJUnitTest.java |   52 +-
 .../cache/FailedSynchronizationException.java   |   10 +-
 .../cache/client/internal/AbstractOp.java       |    2 +-
 .../cache/client/internal/AddPDXEnumOp.java     |    2 +-
 .../cache/client/internal/AddPDXTypeOp.java     |    4 +-
 .../client/internal/AuthenticateUserOp.java     |    4 +-
 .../client/internal/CloseConnectionOp.java      |    2 +-
 .../gemfire/cache/client/internal/CommitOp.java |    2 +-
 .../client/internal/GetClientPRMetaDataOp.java  |    2 +-
 .../GetClientPartitionAttributesOp.java         |    2 +-
 .../cache/client/internal/GetEventValueOp.java  |    2 +-
 .../client/internal/GetFunctionAttributeOp.java |    2 +-
 .../cache/client/internal/GetPDXEnumByIdOp.java |    4 +-
 .../cache/client/internal/GetPDXEnumsOp.java    |    2 +-
 .../client/internal/GetPDXIdForEnumOp.java      |    4 +-
 .../client/internal/GetPDXIdForTypeOp.java      |    4 +-
 .../cache/client/internal/GetPDXTypeByIdOp.java |    4 +-
 .../cache/client/internal/GetPDXTypesOp.java    |    2 +-
 .../cache/client/internal/MakePrimaryOp.java    |    2 +-
 .../gemfire/cache/client/internal/PingOp.java   |    2 +-
 .../cache/client/internal/PrimaryAckOp.java     |    2 +-
 .../client/internal/ProxyCacheCloseOp.java      |    2 +-
 .../cache/client/internal/ReadyForEventsOp.java |    2 +-
 .../internal/RegisterDataSerializersOp.java     |    2 +-
 .../internal/RegisterInstantiatorsOp.java       |    2 +-
 .../cache/client/internal/RollbackOp.java       |    2 +-
 .../gemfire/cache/client/internal/SizeOp.java   |    2 +-
 .../cache/client/internal/TXFailoverOp.java     |    2 +-
 .../client/internal/TXSynchronizationOp.java    |    2 +-
 .../cache/hdfs/internal/cardinality/Bits.java   |   54 -
 .../cardinality/CardinalityMergeException.java  |   42 -
 .../hdfs/internal/cardinality/HyperLogLog.java  |  313 ---
 .../hdfs/internal/cardinality/IBuilder.java     |   41 -
 .../hdfs/internal/cardinality/ICardinality.java |   87 -
 .../hdfs/internal/cardinality/MurmurHash.java   |  261 ---
 .../hdfs/internal/cardinality/RegisterSet.java  |  136 --
 .../hdfs/internal/hoplog/AbstractHoplog.java    |    2 +-
 .../hdfs/internal/hoplog/HFileSortedOplog.java  |    4 +-
 .../hoplog/HdfsSortedOplogOrganizer.java        |    8 +-
 .../cache/hdfs/internal/hoplog/Hoplog.java      |    3 +-
 .../internal/hoplog/SequenceFileHoplog.java     |    2 +-
 .../query/internal/index/IndexElemArray.java    |   94 +-
 .../query/internal/index/IndexManager.java      |    5 +-
 .../index/PrimaryKeyIndexCreationHelper.java    |   25 +-
 .../gemfire/distributed/LocatorLauncher.java    |    7 +-
 .../gemfire/distributed/ServerLauncher.java     |   12 +-
 .../gemfire/distributed/internal/DMStats.java   |    3 +
 .../distributed/internal/DistributionStats.java |   14 +
 .../internal/InternalDistributedSystem.java     |   53 +-
 .../internal/LonerDistributionManager.java      |    4 +
 .../membership/InternalDistributedMember.java   |    2 +-
 .../gms/messenger/JGroupsMessenger.java         |  105 +-
 .../gms/mgr/GMSMembershipManager.java           |    9 +-
 .../gemfire/internal/cache/BucketAdvisor.java   |    2 +-
 .../gemfire/internal/cache/BucketRegion.java    |   26 +-
 .../gemfire/internal/cache/CacheServerImpl.java |   11 +
 .../internal/cache/CacheServerLauncher.java     |    4 +-
 .../internal/cache/DistributedRegion.java       |   22 +-
 .../gemfire/internal/cache/EntryEventImpl.java  |    7 +
 .../gemfire/internal/cache/EventTracker.java    |   11 +-
 .../internal/cache/GemFireCacheImpl.java        |    0
 .../gemfire/internal/cache/TXManagerImpl.java   |    2 +-
 .../cache/tier/sockets/BaseCommand.java         |    2 +-
 .../cache/tier/sockets/CacheClientProxy.java    |    2 +
 .../cache/tier/sockets/CacheServerHelper.java   |   46 +-
 .../internal/cache/tier/sockets/Message.java    |  236 +-
 .../internal/cache/tier/sockets/Part.java       |    9 +-
 .../command/ExecuteRegionFunction66.java        |    9 +-
 .../cache/xmlcache/AsyncEventQueueCreation.java |    1 +
 .../internal/cache/xmlcache/CacheCreation.java  |    9 +-
 .../cache/xmlcache/CacheXmlGenerator.java       |   37 +-
 .../com/gemstone/gemfire/internal/hll/Bits.java |   48 +
 .../internal/hll/CardinalityMergeException.java |   26 +
 .../gemfire/internal/hll/HyperLogLog.java       |  345 +++
 .../gemfire/internal/hll/HyperLogLogPlus.java   | 1053 +++++++++
 .../gemstone/gemfire/internal/hll/IBuilder.java |   24 +
 .../gemfire/internal/hll/ICardinality.java      |   72 +
 .../gemfire/internal/hll/MurmurHash.java        |  245 ++
 .../gemfire/internal/hll/RegisterSet.java       |  110 +
 .../gemfire/internal/redis/RegionProvider.java  |    2 +-
 .../internal/redis/executor/hll/Bits.java       |   65 -
 .../executor/hll/CardinalityMergeException.java |   42 -
 .../redis/executor/hll/HyperLogLog.java         |  360 ---
 .../redis/executor/hll/HyperLogLogPlus.java     | 1068 ---------
 .../internal/redis/executor/hll/IBuilder.java   |   41 -
 .../redis/executor/hll/ICardinality.java        |   89 -
 .../internal/redis/executor/hll/MurmurHash.java |  234 --
 .../redis/executor/hll/PFAddExecutor.java       |    1 +
 .../redis/executor/hll/PFCountExecutor.java     |    2 +
 .../redis/executor/hll/PFMergeExecutor.java     |    2 +
 .../redis/executor/hll/RegisterSet.java         |  126 -
 .../gemfire/internal/tcp/Connection.java        |    5 +-
 .../gemfire/redis/GemFireRedisServer.java       |    2 +-
 .../cache/CacheRegionClearStatsDUnitTest.java   |   38 +-
 .../cache/ClientServerTimeSyncDUnitTest.java    |    4 +-
 .../internal/AutoConnectionSourceDUnitTest.java |    2 +-
 .../CacheServerSSLConnectionDUnitTest.java      |   44 +-
 .../internal/LocatorLoadBalancingDUnitTest.java |   15 +-
 .../cache/client/internal/LocatorTestBase.java  |    6 +-
 .../internal/SSLNoClientAuthDUnitTest.java      |   14 +-
 .../management/MemoryThresholdsDUnitTest.java   |   10 +-
 .../MemoryThresholdsOffHeapDUnitTest.java       |   10 +-
 .../query/dunit/PdxStringQueryDUnitTest.java    |   42 +-
 .../dunit/QueryDataInconsistencyDUnitTest.java  |   12 +-
 .../QueryUsingFunctionContextDUnitTest.java     |   41 +-
 .../query/dunit/QueryUsingPoolDUnitTest.java    |   32 +-
 .../cache/query/dunit/RemoteQueryDUnitTest.java |   18 +-
 ...ueryFromClauseCanonicalizationJUnitTest.java |    7 -
 .../query/internal/ResultsBagJUnitTest.java     |    7 -
 ...rrentIndexInitOnOverflowRegionDUnitTest.java |    3 +-
 .../query/internal/index/IndexUseJUnitTest.java |  452 +---
 .../index/PutAllWithIndexPerfDUnitTest.java     |    2 +-
 .../gemfire/cache30/Bug34387DUnitTest.java      |    2 +-
 .../gemfire/cache30/CacheMapTxnDUnitTest.java   |   20 +-
 .../cache30/CachedAllEventsDUnitTest.java       |    2 +-
 .../gemfire/cache30/CallbackArgDUnitTest.java   |    2 +-
 .../cache30/ClearMultiVmCallBkDUnitTest.java    |   18 +-
 .../gemfire/cache30/ClearMultiVmDUnitTest.java  |   22 +-
 .../cache30/ClientMembershipDUnitTest.java      |   30 +-
 .../ClientRegisterInterestDUnitTest.java        |    9 +-
 .../cache30/DistAckMapMethodsDUnitTest.java     |   52 +-
 .../DistributedNoAckRegionCCEDUnitTest.java     |   28 +-
 .../gemfire/cache30/MultiVMRegionTestCase.java  |   68 +-
 .../cache30/PartitionedRegionDUnitTest.java     |    2 +-
 .../gemfire/cache30/ProxyDUnitTest.java         |    2 +-
 .../cache30/PutAllCallBkRemoteVMDUnitTest.java  |    8 +-
 .../cache30/PutAllCallBkSingleVMDUnitTest.java  |   10 +-
 .../gemfire/cache30/PutAllMultiVmDUnitTest.java |    8 +-
 .../gemfire/cache30/ReconnectDUnitTest.java     |    6 +-
 .../ReconnectedCacheServerDUnitTest.java        |   27 +
 .../RegionMembershipListenerDUnitTest.java      |    2 +-
 .../cache30/RegionReliabilityTestCase.java      |   21 +-
 .../cache30/RemoveAllMultiVmDUnitTest.java      |    8 +-
 .../cache30/RolePerformanceDUnitTest.java       |    3 +-
 .../gemfire/cache30/SearchAndLoadDUnitTest.java |    4 +-
 .../gemfire/cache30/TXDistributedDUnitTest.java |   12 +-
 .../gemfire/cache30/TXOrderDUnitTest.java       |    2 +-
 .../gemfire/distributed/LocatorDUnitTest.java   |   59 +-
 .../distributed/LocatorLauncherJUnitTest.java   |   27 +-
 .../LocatorLauncherLocalJUnitTest.java          |    4 +-
 .../LocatorLauncherRemoteJUnitTest.java         |    2 +-
 .../distributed/ServerLauncherJUnitTest.java    |   26 +-
 .../ServerLauncherLocalJUnitTest.java           |    4 +-
 .../ServerLauncherRemoteJUnitTest.java          |    2 +-
 .../ConsoleDistributionManagerDUnitTest.java    |    7 +-
 .../messenger/JGroupsMessengerJUnitTest.java    |   86 +-
 .../gemfire/disttx/CacheMapDistTXDUnitTest.java |    8 +-
 .../gemfire/disttx/DistTXDebugDUnitTest.java    |   20 +-
 .../disttx/DistributedTransactionDUnitTest.java |    3 +-
 .../internal/cache/BucketRegionJUnitTest.java   |  208 ++
 .../internal/cache/Bug33359DUnitTest.java       |    8 +-
 .../internal/cache/Bug33726DUnitTest.java       |   10 +-
 .../internal/cache/Bug37241DUnitTest.java       |   26 +-
 .../internal/cache/Bug39079DUnitTest.java       |   21 +-
 .../internal/cache/Bug41733DUnitTest.java       |    2 +-
 .../internal/cache/ClearDAckDUnitTest.java      |   26 +-
 .../internal/cache/ClearGlobalDUnitTest.java    |    6 +-
 .../cache/DeltaPropagationDUnitTest.java        |  324 ++-
 .../cache/DeltaPropagationStatsDUnitTest.java   |  120 +-
 .../cache/DiskRegByteArrayDUnitTest.java        |   14 +-
 .../cache/DistributedCacheTestCase.java         |    5 +-
 .../internal/cache/EventTrackerDUnitTest.java   |    6 +-
 .../internal/cache/EvictionStatsDUnitTest.java  |   12 +-
 .../internal/cache/EvictionTestBase.java        |    9 +-
 .../cache/FixedPRSinglehopDUnitTest.java        |  140 +-
 .../internal/cache/GIIDeltaDUnitTest.java       |   84 +-
 .../internal/cache/HABug36773DUnitTest.java     |  370 ---
 .../HAOverflowMemObjectSizerDUnitTest.java      |   54 +-
 .../internal/cache/MapClearGIIDUnitTest.java    |   17 +-
 .../cache/P2PDeltaPropagationDUnitTest.java     |  105 +-
 .../PartitionedRegionCreationDUnitTest.java     |    2 +-
 .../PartitionedRegionSingleHopDUnitTest.java    |  460 ++--
 ...RegionSingleHopWithServerGroupDUnitTest.java |  243 +-
 .../internal/cache/PutAllDAckDUnitTest.java     |   12 +-
 .../internal/cache/PutAllGlobalDUnitTest.java   |   12 +-
 .../internal/cache/RemoveAllDAckDUnitTest.java  |   12 +-
 .../internal/cache/RemoveDAckDUnitTest.java     |   10 +-
 .../internal/cache/RemoveGlobalDUnitTest.java   |   12 +-
 .../internal/cache/SingleHopStatsDUnitTest.java |   60 +-
 .../internal/cache/SystemFailureDUnitTest.java  |    4 +-
 .../control/RebalanceOperationDUnitTest.java    |    6 +-
 .../cache/execute/Bug51193DUnitTest.java        |   18 +-
 .../ClientServerFunctionExecutionDUnitTest.java |  148 +-
 .../execute/ColocationFailoverDUnitTest.java    |   43 +-
 ...ributedRegionFunctionExecutionDUnitTest.java |  875 +++----
 .../cache/execute/LocalDataSetDUnitTest.java    |   26 +-
 .../LocalFunctionExecutionDUnitTest.java        |   16 +-
 .../MemberFunctionExecutionDUnitTest.java       |   59 +-
 .../MultiRegionFunctionExecutionDUnitTest.java  |    8 +-
 ...ntServerFunctionExecutionNoAckDUnitTest.java |   20 +-
 ...tServerRegionFunctionExecutionDUnitTest.java |  102 +-
 ...egionFunctionExecutionFailoverDUnitTest.java |  236 +-
 ...onFunctionExecutionNoSingleHopDUnitTest.java |  176 +-
 ...onExecutionSelectorNoSingleHopDUnitTest.java |  164 +-
 ...gionFunctionExecutionSingleHopDUnitTest.java |  132 +-
 .../cache/execute/PRClientServerTestBase.java   |  155 +-
 .../cache/execute/PRColocationDUnitTest.java    |  219 +-
 .../execute/PRCustomPartitioningDUnitTest.java  |    8 +-
 .../execute/PRFunctionExecutionDUnitTest.java   |    8 +-
 .../execute/PRPerformanceTestDUnitTest.java     |    8 +-
 .../cache/execute/PRTransactionDUnitTest.java   |   50 +-
 .../execute/SingleHopGetAllPutAllDUnitTest.java |    6 +-
 .../cache/ha/Bug36853EventsExpiryDUnitTest.java |   17 +-
 .../internal/cache/ha/Bug48571DUnitTest.java    |   22 +-
 .../internal/cache/ha/Bug48879DUnitTest.java    |   20 +-
 .../cache/ha/EventIdOptimizationDUnitTest.java  |   44 +-
 .../internal/cache/ha/FailoverDUnitTest.java    |   18 +-
 .../internal/cache/ha/HABugInPutDUnitTest.java  |   28 +-
 .../internal/cache/ha/HAClearDUnitTest.java     |   41 +-
 .../cache/ha/HAConflationDUnitTest.java         |   18 +-
 .../internal/cache/ha/HADuplicateDUnitTest.java |   30 +-
 .../cache/ha/HAEventIdPropagationDUnitTest.java |  107 +-
 .../internal/cache/ha/HAExpiryDUnitTest.java    |   56 +-
 .../internal/cache/ha/HAGIIBugDUnitTest.java    |   12 +-
 .../internal/cache/ha/HAGIIDUnitTest.java       |   37 +-
 .../cache/ha/HARQueueNewImplDUnitTest.java      |  440 ++--
 .../internal/cache/ha/HARegionDUnitTest.java    |   68 +-
 .../cache/ha/HARegionQueueDUnitTest.java        |   83 +-
 .../cache/ha/HASlowReceiverDUnitTest.java       |   32 +-
 .../ha/OperationsPropagationDUnitTest.java      |   36 +-
 .../internal/cache/ha/PutAllDUnitTest.java      |   59 +-
 .../internal/cache/ha/StatsBugDUnitTest.java    |   28 +-
 .../cache/locks/TXLockServiceDUnitTest.java     |   28 +-
 .../cache/partitioned/Bug43684DUnitTest.java    |   38 +-
 .../cache/partitioned/Bug47388DUnitTest.java    |   29 +-
 .../cache/partitioned/Bug51400DUnitTest.java    |   23 +-
 .../PartitionedRegionLoaderWriterDUnitTest.java |   54 +-
 .../fixed/FixedPartitioningDUnitTest.java       | 1251 +++++-----
 .../fixed/FixedPartitioningTestBase.java        |   10 +-
 ...ngWithColocationAndPersistenceDUnitTest.java | 1368 +++++------
 .../internal/cache/tier/Bug40396DUnitTest.java  |   21 +-
 ...mpatibilityHigherVersionClientDUnitTest.java |   31 +-
 .../cache/tier/sockets/Bug36269DUnitTest.java   |   14 +-
 .../cache/tier/sockets/Bug36457DUnitTest.java   |   31 +-
 .../cache/tier/sockets/Bug36805DUnitTest.java   |   34 +-
 .../cache/tier/sockets/Bug36829DUnitTest.java   |   23 +-
 .../cache/tier/sockets/Bug36995DUnitTest.java   |   35 +-
 .../cache/tier/sockets/Bug37210DUnitTest.java   |   22 +-
 .../cache/tier/sockets/Bug37805DUnitTest.java   |   16 +-
 .../CacheServerTransactionsDUnitTest.java       |  222 +-
 .../tier/sockets/ClearPropagationDUnitTest.java |   48 +-
 .../tier/sockets/ClientConflationDUnitTest.java |   30 +-
 .../sockets/ClientInterestNotifyDUnitTest.java  |   88 +-
 .../tier/sockets/ClientServerMiscDUnitTest.java |   35 +-
 .../cache/tier/sockets/ConflationDUnitTest.java |  106 +-
 .../DataSerializerPropogationDUnitTest.java     |  337 ++-
 .../DestroyEntryPropagationDUnitTest.java       |   96 +-
 .../DurableClientQueueSizeDUnitTest.java        |  106 +-
 .../DurableClientReconnectDUnitTest.java        |   40 +-
 .../sockets/DurableClientStatsDUnitTest.java    |   72 +-
 .../sockets/DurableRegistrationDUnitTest.java   |  335 +--
 .../sockets/DurableResponseMatrixDUnitTest.java |   86 +-
 .../sockets/EventIDVerificationDUnitTest.java   |   71 +-
 .../EventIDVerificationInP2PDUnitTest.java      |   51 +-
 .../cache/tier/sockets/HABug36738DUnitTest.java |   18 +-
 .../tier/sockets/HAInterestPart1DUnitTest.java  |  100 +-
 .../tier/sockets/HAInterestPart2DUnitTest.java  |  114 +-
 .../cache/tier/sockets/HAInterestTestCase.java  |   32 +-
 .../sockets/HAStartupAndFailoverDUnitTest.java  |  108 +-
 .../InstantiatorPropagationDUnitTest.java       |  236 +-
 .../tier/sockets/InterestListDUnitTest.java     |  300 +--
 .../sockets/InterestListEndpointDUnitTest.java  |   66 +-
 .../sockets/InterestListFailoverDUnitTest.java  |   50 +-
 .../sockets/InterestListRecoveryDUnitTest.java  |   26 +-
 .../sockets/InterestRegrListenerDUnitTest.java  |   82 +-
 .../sockets/InterestResultPolicyDUnitTest.java  |   35 +-
 .../cache/tier/sockets/MessageJUnitTest.java    |   75 +
 .../sockets/NewRegionAttributesDUnitTest.java   |   28 +-
 .../sockets/RedundancyLevelPart1DUnitTest.java  |   36 +-
 .../sockets/RedundancyLevelPart2DUnitTest.java  |   67 +-
 .../sockets/RedundancyLevelPart3DUnitTest.java  |  100 +-
 .../tier/sockets/RedundancyLevelTestBase.java   |   20 +-
 .../tier/sockets/RegionCloseDUnitTest.java      |   20 +-
 ...erInterestBeforeRegionCreationDUnitTest.java |   20 +-
 .../sockets/RegisterInterestKeysDUnitTest.java  |   32 +-
 .../sockets/ReliableMessagingDUnitTest.java     |   22 +-
 .../sockets/UnregisterInterestDUnitTest.java    |   62 +-
 .../sockets/UpdatePropagationDUnitTest.java     |   91 +-
 .../sockets/UpdatePropagationPRDUnitTest.java   |    3 -
 .../VerifyEventIDGenerationInP2PDUnitTest.java  |   13 +-
 ...UpdatesFromNonInterestEndPointDUnitTest.java |   29 +-
 .../cache/wan/AsyncEventQueueTestBase.java      |  233 +-
 .../asyncqueue/AsyncEventListenerDUnitTest.java | 2185 +++++++-----------
 .../AsyncEventQueueStatsDUnitTest.java          |  321 ++-
 .../ConcurrentAsyncEventQueueDUnitTest.java     |  354 ++-
 .../CommonParallelAsyncEventQueueDUnitTest.java |   15 +-
 .../internal/jta/dunit/ExceptionsDUnitTest.java |   10 +-
 .../jta/dunit/IdleTimeOutDUnitTest.java         |    7 +-
 .../jta/dunit/LoginTimeOutDUnitTest.java        |    8 +-
 .../jta/dunit/MaxPoolSizeDUnitTest.java         |    5 +-
 .../jta/dunit/TransactionTimeOutDUnitTest.java  |   24 +-
 .../dunit/TxnManagerMultiThreadDUnitTest.java   |   14 +-
 .../internal/jta/dunit/TxnTimeOutDUnitTest.java |    9 +-
 .../internal/offheap/FragmentJUnitTest.java     |  280 +++
 .../statistics/StatisticsDUnitTest.java         |   11 +-
 .../management/CacheManagementDUnitTest.java    |   16 +-
 .../management/ClientHealthStatsDUnitTest.java  |   58 +-
 .../gemfire/management/QueryDataDUnitTest.java  |   20 +-
 ...ersalMembershipListenerAdapterDUnitTest.java |   54 +-
 .../cli/commands/FunctionCommandsDUnitTest.java |    4 +-
 .../commands/GemfireDataCommandsDUnitTest.java  |    4 +-
 ...WithCacheLoaderDuringCacheMissDUnitTest.java |    8 +-
 ...stAndDescribeDiskStoreCommandsDUnitTest.java |    4 +-
 .../cli/commands/ListIndexCommandDUnitTest.java |    8 +-
 .../MiscellaneousCommandsDUnitTest.java         |    6 +-
 ...laneousCommandsExportLogsPart3DUnitTest.java |    2 +-
 .../internal/pulse/TestFunctionsDUnitTest.java  |    3 +-
 .../internal/pulse/TestHeapDUnitTest.java       |    5 +-
 .../internal/pulse/TestLocatorsDUnitTest.java   |    3 +-
 .../web/controllers/RestAPITestBase.java        |    8 +-
 .../security/ClientAuthenticationDUnitTest.java |  502 ++--
 .../security/ClientAuthorizationDUnitTest.java  |  272 ++-
 .../security/ClientAuthorizationTestBase.java   |   23 +-
 .../security/ClientMultiUserAuthzDUnitTest.java |   52 +-
 .../DeltaClientAuthorizationDUnitTest.java      |   69 +-
 .../DeltaClientPostAuthorizationDUnitTest.java  |   40 +-
 .../security/P2PAuthenticationDUnitTest.java    |  127 +-
 .../gemfire/test/dunit/AsyncInvocation.java     |    4 +-
 .../gemfire/test/dunit/IgnoredException.java    |   12 +-
 .../gemfire/test/dunit/RMIException.java        |    2 +-
 .../test/dunit/SerializableRunnableIF.java      |    3 +-
 .../com/gemstone/gemfire/test/dunit/VM.java     |  927 +-------
 .../gemfire/test/dunit/rules/RemoteInvoker.java |    6 +-
 .../test/dunit/tests/BasicDUnitTest.java        |   12 +-
 .../gemfire/test/dunit/tests/VMDUnitTest.java   |   51 +-
 .../gemfire/codeAnalysis/excludedClasses.txt    |    3 +
 .../codeAnalysis/sanctionedSerializables.txt    |   23 +-
 .../cache/query/cq/dunit/CqDataDUnitTest.java   |   33 +-
 .../cq/dunit/CqDataUsingPoolDUnitTest.java      |   91 +-
 .../cache/query/cq/dunit/CqPerfDUnitTest.java   |   19 +-
 .../cq/dunit/CqPerfUsingPoolDUnitTest.java      |   17 +-
 .../cache/query/cq/dunit/CqQueryDUnitTest.java  |   94 +-
 .../dunit/CqQueryOptimizedExecuteDUnitTest.java |   12 +-
 .../cq/dunit/CqQueryUsingPoolDUnitTest.java     |   49 +-
 .../cq/dunit/CqResultSetUsingPoolDUnitTest.java |   34 +-
 ...ltSetUsingPoolOptimizedExecuteDUnitTest.java |    4 +-
 .../cache/query/cq/dunit/CqStatsDUnitTest.java  |    4 +-
 .../cq/dunit/CqStatsUsingPoolDUnitTest.java     |    4 +-
 .../PartitionedRegionCqQueryDUnitTest.java      |   34 +-
 ...dRegionCqQueryOptimizedExecuteDUnitTest.java |    6 +-
 .../query/cq/dunit/PrCqUsingPoolDUnitTest.java  |   28 +-
 .../cache/query/dunit/PdxQueryCQDUnitTest.java  |   14 +-
 .../cache/query/dunit/PdxQueryCQTestBase.java   |    2 +-
 .../dunit/QueryIndexUpdateRIDUnitTest.java      |   24 +-
 .../query/dunit/QueryMonitorDUnitTest.java      |    7 +-
 .../cache/PRDeltaPropagationDUnitTest.java      |  192 +-
 .../internal/cache/ha/CQListGIIDUnitTest.java   |  138 +-
 .../cache/ha/HADispatcherDUnitTest.java         |   50 +-
 .../sockets/ClientToServerDeltaDUnitTest.java   |  282 +--
 .../DeltaPropagationWithCQDUnitTest.java        |   41 +-
 ...ToRegionRelationCQRegistrationDUnitTest.java |  144 +-
 .../sockets/DurableClientCrashDUnitTest.java    |    4 +-
 .../sockets/DurableClientNetDownDUnitTest.java  |   10 +-
 .../sockets/DurableClientSimpleDUnitTest.java   |  442 ++--
 .../tier/sockets/DurableClientTestCase.java     |  206 +-
 .../CacheServerManagementDUnitTest.java         |    3 +-
 .../cli/commands/ClientCommandsDUnitTest.java   |    8 +-
 .../DurableClientCommandsDUnitTest.java         |    6 +-
 .../internal/pulse/TestCQDUnitTest.java         |    6 +-
 .../internal/pulse/TestClientsDUnitTest.java    |    6 +-
 .../internal/pulse/TestServerDUnitTest.java     |    3 +-
 .../ClientAuthorizationTwoDUnitTest.java        |   20 +-
 .../security/ClientAuthzObjectModDUnitTest.java |   23 +-
 .../ClientCQPostAuthorizationDUnitTest.java     |   62 +-
 .../ClientPostAuthorizationDUnitTest.java       |   49 +-
 .../gemfire/security/MultiuserAPIDUnitTest.java |   41 +-
 .../MultiuserDurableCQAuthzDUnitTest.java       |   52 +-
 geode-pulse/build.gradle                        |    8 +-
 .../src/main/resources/gemfire.properties       |    4 +-
 geode-pulse/src/main/webapp/DataBrowser.html    |   52 +-
 geode-pulse/src/main/webapp/Login.html          |   46 +-
 geode-pulse/src/main/webapp/MemberDetails.html  |   35 +-
 .../src/main/webapp/QueryStatistics.html        |   31 +-
 geode-pulse/src/main/webapp/clusterDetail.html  |   36 +-
 .../src/main/webapp/css/grips/horizontal.png    |  Bin 0 -> 2753 bytes
 .../src/main/webapp/css/grips/vertical.png      |  Bin 0 -> 91 bytes
 geode-pulse/src/main/webapp/css/style.css       |   44 +-
 .../src/main/webapp/images/about-geode.png      |  Bin 0 -> 7640 bytes
 .../main/webapp/images/apache_geode_logo.png    |  Bin 0 -> 23616 bytes
 .../src/main/webapp/images/pivotal-logo.png     |  Bin 4302 -> 3500 bytes
 .../main/webapp/properties/gemfire.properties   |    4 +-
 .../webapp/properties/gemfire_en.properties     |    4 +-
 .../main/webapp/properties/gemfirexd.properties |    2 +-
 .../webapp/properties/gemfirexd_en.properties   |    2 +-
 geode-pulse/src/main/webapp/regionDetail.html   |   33 +-
 .../src/main/webapp/scripts/lib/split.js        |  375 +++
 .../scripts/pulsescript/pages/DataBrowser.js    |   13 +-
 .../client/internal/GatewaySenderBatchOp.java   |    2 +-
 .../cache/CacheXml80GatewayDUnitTest.java       |   72 +-
 .../internal/cache/UpdateVersionDUnitTest.java  |   88 +-
 .../gemfire/internal/cache/wan/WANTestBase.java |   33 +-
 ...oncurrentParallelGatewaySenderDUnitTest.java | 1164 +++++-----
 ...allelGatewaySenderOperation_1_DUnitTest.java | 1063 +++++----
 ...allelGatewaySenderOperation_2_DUnitTest.java |   63 +-
 .../ConcurrentWANPropogation_1_DUnitTest.java   |  644 +++---
 .../ConcurrentWANPropogation_2_DUnitTest.java   |  699 +++---
 .../cache/wan/disttx/DistTXWANDUnitTest.java    |  258 +--
 .../CommonParallelGatewaySenderDUnitTest.java   |  459 ++--
 ...wWANConcurrencyCheckForDestroyDUnitTest.java |  168 +-
 .../cache/wan/misc/PDXNewWanDUnitTest.java      |  744 +++---
 ...dRegion_ParallelWANPersistenceDUnitTest.java |  767 +++---
 ...dRegion_ParallelWANPropogationDUnitTest.java | 1014 ++++----
 .../SenderWithTransportFilterDUnitTest.java     |   66 +-
 ...downAllPersistentGatewaySenderDUnitTest.java |   48 +-
 .../wan/misc/WANLocatorServerDUnitTest.java     |   40 +-
 .../cache/wan/misc/WANSSLDUnitTest.java         |   98 +-
 .../wan/misc/WanAutoDiscoveryDUnitTest.java     |  284 +--
 .../cache/wan/misc/WanValidationsDUnitTest.java | 1594 ++++++-------
 ...arallelGatewaySenderOperationsDUnitTest.java |  273 ++-
 ...llelGatewaySenderQueueOverflowDUnitTest.java |  476 ++--
 ...ersistenceEnabledGatewaySenderDUnitTest.java | 1851 +++++++--------
 ...llelWANPropagationClientServerDUnitTest.java |   94 +-
 ...lelWANPropagationConcurrentOpsDUnitTest.java |  264 ++-
 .../ParallelWANPropagationDUnitTest.java        | 2015 ++++++++--------
 ...ParallelWANPropagationLoopBackDUnitTest.java |  438 ++--
 .../wan/parallel/ParallelWANStatsDUnitTest.java |  366 ++-
 ...tewaySenderDistributedDeadlockDUnitTest.java |  171 +-
 ...rialGatewaySenderEventListenerDUnitTest.java |  312 ++-
 .../SerialGatewaySenderOperationsDUnitTest.java |   26 +-
 .../SerialGatewaySenderQueueDUnitTest.java      |  224 +-
 ...ersistenceEnabledGatewaySenderDUnitTest.java |  707 +++---
 .../SerialWANPropagationLoopBackDUnitTest.java  |  547 ++---
 .../serial/SerialWANPropogationDUnitTest.java   | 1674 +++++++-------
 ...NPropogation_PartitionedRegionDUnitTest.java |  693 +++---
 .../SerialWANPropogationsFeatureDUnitTest.java  |  562 +++--
 .../wan/serial/SerialWANStatsDUnitTest.java     |  733 +++---
 .../wan/wancommand/WANCommandTestBase.java      |   16 +-
 ...anCommandCreateGatewayReceiverDUnitTest.java |  274 +--
 .../WanCommandCreateGatewaySenderDUnitTest.java |  302 +--
 ...WanCommandGatewayReceiverStartDUnitTest.java |  171 +-
 .../WanCommandGatewayReceiverStopDUnitTest.java |  175 +-
 .../WanCommandGatewaySenderStartDUnitTest.java  |  289 ++-
 .../WanCommandGatewaySenderStopDUnitTest.java   |  273 +--
 .../wan/wancommand/WanCommandListDUnitTest.java |  172 +-
 .../WanCommandPauseResumeDUnitTest.java         |  630 +++--
 .../wancommand/WanCommandStatusDUnitTest.java   |  234 +-
 .../management/WANManagementDUnitTest.java      |  108 +-
 .../pulse/TestRemoteClusterDUnitTest.java       |   46 +-
 443 files changed, 23025 insertions(+), 29264 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5beaaedc/geode-assembly/build.gradle
----------------------------------------------------------------------
diff --cc geode-assembly/build.gradle
index 2c7e365,0000000..2a46147
mode 100755,000000..100755
--- a/geode-assembly/build.gradle
+++ b/geode-assembly/build.gradle
@@@ -1,340 -1,0 +1,345 @@@
 +/*
 + * Licensed to the Apache Software Foundation (ASF) under one or more
 + * contributor license agreements.  See the NOTICE file distributed with
 + * this work for additional information regarding copyright ownership.
 + * The ASF licenses this file to You under the Apache License, Version 2.0
 + * (the "License"); you may not use this file except in compliance with
 + * the License.  You may obtain a copy of the License at
 + *
 + *      http://www.apache.org/licenses/LICENSE-2.0
 + *
 + * Unless required by applicable law or agreed to in writing, software
 + * distributed under the License is distributed on an "AS IS" BASIS,
 + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 + * See the License for the specific language governing permissions and
 + * limitations under the License.
 + */
 +import org.gradle.api.internal.artifacts.publish.ArchivePublishArtifact;
 +
 +apply plugin: 'distribution'
 +
 +// disable artifact generation for this project
 +jar.enabled = false
 +extraArchive {
 +  sources = false
 +  javadoc = false
 +  tests = false
 +}
 +
 +disableMavenPublishing()
 +
 +// Gradle doesn't automatically remove the jar artifact even though we disabled it
 +// this causes publishing to fail.  So we nuke all the disabled artifacts from all configurations.
 +configurations.all {
 +  artifacts.removeAll artifacts.findAll { it instanceof ArchivePublishArtifact && !it.archiveTask.enabled }
 +}
 +
 +gradle.taskGraph.whenReady( { graph ->
 +  tasks.withType(Tar).each { tar ->
 +    tar.compression = Compression.GZIP
 +    tar.extension = 'tar.gz'
 +  }
 +})
 +
 +dependencies {
 +  provided project(':geode-core')
 +  
 +  archives project(':geode-common')  
 +  archives project(':geode-json')  
 +  archives project(':geode-joptsimple')  
 +  archives project(':geode-core')  
 +  archives project(':geode-lucene')
 +  archives project(':geode-web')
 +  archives project(':geode-web-api')
 +  archives project(':geode-pulse')
 +  archives project(':geode-wan')
 +  archives project(':geode-cq')
 +
 +  testCompile project(':geode-junit')
 +  testCompile project(path: ':geode-core', configuration: 'testOutput')
 +
 +  testRuntime files("${System.getProperty('java.home')}/../lib/tools.jar")
 +}
 +
 +sourceSets {
 +  // need to remove this since we use the dependencies jar out of the install dir
 +  //test.runtimeClasspath -= configurations.provided
 +}
 +
 +test {
 +  // test from the actual classpath not the gradle classpath
 +  dependsOn installDist
 +  // @TODO: this doesn't seem to be working need to get basename first.
 +  classpath += files "$buildDir/install/apache-geode/lib/geode-dependencies.jar"
 +}
 +
 +tasks.withType(Test){
 +  environment 'GEMFIRE', "$buildDir/install/${distributions.main.baseName}/lib"
 +}
 +
 +task defaultDistributionConfig(type: JavaExec, dependsOn: classes) {
 +  outputs.file file("$buildDir/gemfire.properties")
 +  main 'com.gemstone.gemfire.distributed.internal.DistributionConfigImpl'
 +  classpath project(':geode-core').sourceSets.main.runtimeClasspath
 +  workingDir buildDir
 +  
 +  doFirst {
 +    buildDir.mkdirs()
 +  }
 +}
 +
 +task defaultCacheConfig(type: JavaExec, dependsOn: classes) {
 +  outputs.file file("$buildDir/cache.xml")
 +  main 'com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator'
 +  classpath project(':geode-core').sourceSets.main.runtimeClasspath
 +  workingDir buildDir
 +
 +  doFirst {
 +    buildDir.mkdirs()
 +  }
 +}
 +
 +// This closure sets the gemfire classpath.  If we add another jar to the classpath it must
 +// be included in the filter logic below.
 +def cp = {
 +  // first add all the dependent project jars
 +  def jars = configurations.archives.dependencies.collect { it.dependencyProject }
 +    .findAll { !it.name.contains('web') }
 +    .collect { it.jar.archiveName }
 +    .join(' ')
 +
 +  // then add all the dependencies of the dependent jars
 +  jars += ' ' + configurations.archives.dependencies.collect { 
 +    it.dependencyProject.configurations.runtime.collect { it.getName() }.findAll {
 +      // depedencies from geode-core
 +      it.contains('antlr') ||
 +      it.contains('commons-io') ||
 +      it.contains('commons-lang') ||
 +      it.contains('commons-logging') ||
 +      it.contains('fastutil') ||
 +      it.contains('jackson-annotations') ||
 +      it.contains('jackson-core') ||
 +      it.contains('jackson-databind') ||
 +      it.contains('jansi') ||
 +      it.contains('javax.resource-api') ||
 +      it.contains('javax.servlet-api') ||
 +      it.contains('javax.transaction-api') ||
 +      it.contains('jetty-http') ||
 +      it.contains('jetty-io') ||
 +      it.contains('jetty-security') ||
 +      it.contains('jetty-server') ||
 +      it.contains('jetty-servlet') ||
 +      it.contains('jetty-webapp') ||
 +      it.contains('jetty-util') ||
 +      it.contains('jetty-xml') ||
 +      it.contains('jline') ||
 +      it.contains('jna') ||
 +      it.contains('log4j-api') ||
 +      it.contains('log4j-core') ||
 +      it.contains('log4j-jcl') ||
 +      it.contains('log4j-jul') ||
 +      it.contains('log4j-slf4j-impl') ||
 +      it.contains('slf4j-api') ||
 +      it.contains('spring-core') ||
 +      it.contains('spring-shell') ||
 +      it.contains('snappy-java') ||
 +      it.contains('hbase') ||
 +      it.contains('jgroups') ||
 +      it.contains('netty') ||
 +      
 +      // dependencies from geode-lucene
 +      it.contains('lucene-analyzers-common') ||
 +      it.contains('lucene-core') ||
 +      it.contains('lucene-queries') ||
 +      it.contains('lucene-queryparser')
 +    }
 +  }.flatten().unique().join(' ')
 +
 +  return jars
 +}
 +
 +// Note: this dependency doesn't work if you change a library version from
 +// a dependent project.  Please fix me.
 +task depsJar (type: Jar, dependsOn: ':geode-core:classes') {
 +  description 'Assembles the jar archive that defines the gemfire classpath.'
 +  archiveName 'geode-dependencies.jar'
 +  doFirst {
 +    manifest { 
 +      attributes("Class-Path": cp())
 +    }
 +  }
 +}
 +
 +// Note: this dependency doesn't work if you change a library version from
 +// a dependent project.  Please fix me.
 +task gfshDepsJar (type: Jar, dependsOn: ':geode-core:classes') {
 +  description 'Assembles the jar archive that defines the gfsh classpath.'
 +  def springWeb = configurations.runtime.collect { it.getName() }.find { it.contains('spring-web') }
 +  archiveName 'gfsh-dependencies.jar'
 +  doFirst {
 +    manifest {
 +      attributes("Class-Path": cp() + 
 +        ' ' + project(':geode-core').webJar.archiveName +
 +        ' ' + springWeb
 +      )
 +    }
 +  }
 +}
 +
 +
 +def docsDir = file("$buildDir/javadocs")
 +task docs(type: Javadoc) {
 +    options.addStringOption('Xdoclint:none', '-quiet')
 +    options.encoding='UTF-8'
 +    source parent.subprojects*.javadoc*.source
 +    classpath = files(parent.subprojects*.javadoc*.classpath)
 +    title = "Apache Geode ${project.version}"
 +    include 'com/gemstone/gemfire/**/'
 +    exclude 'com/gemstone/gemfire/internal/**/'
 +    exclude 'com/gemstone/gemfire/**/internal/**/'
 +    exclude 'com/gemstone/gemfire/**/xml/**/'
 +    exclude 'com/gemstone/gemfire/distributed/**/util/**/'
 +    exclude 'com/gemstone/gemfire/test/**/'
 +    destinationDir = docsDir
 +}
 +
 +gradle.taskGraph.whenReady( { graph ->
 +  tasks.withType(AbstractArchiveTask).findAll {
 +    it.name.toLowerCase().contains("dist")
 +  }.each { archive ->
 +    archive.doLast {
 +      ant.checksum file:"${archive.archivePath}", algorithm:"md5"
 +      ant.checksum file:"${archive.archivePath}", algorithm:"sha-256"
 +    }
 +  }
 +})
 +
 +distributions {
 +  src {
 +    baseName = 'apache-geode-src'
 +    contents {
 +      from (rootDir) {
 +        exclude 'KEYS'
 +        exclude 'gradlew'
 +        exclude 'gradlew.bat'
 +        exclude 'gradle/wrapper/gradle-wrapper.jar'
-         exclude 'gradle/wrapper/gradle-wrapper.properties'
 +        exclude '.gradle'
 +        exclude '**/build/**'
 +        exclude '**/.project'
 +        exclude '**/.classpath'
 +        exclude '**/.settings/**'
 +        exclude '**/build-eclipse/**'
 +        exclude '.idea/**'
 +        exclude '**/*.iml'
 +        exclude '**/*.ipr'
 +        exclude '**/*.iws'
 +        exclude '**/tags'
++
++        //These directories are generated on the jenkins server by gradle
++        exclude 'caches'
++        exclude 'daemon'
++        exclude 'native'
++        exclude 'wrapper'
 +      }
 +    }
 +  }
 +
 +  main {
 +    baseName = 'apache-geode' //TODO rootProject.name
 +    contents {
 +      duplicatesStrategy 'exclude'
 +      exclude '*.asc'
 +      
 +      exclude '*.asc'
 +      exclude '*-sources.jar'
 +      exclude '*-javadoc.jar'
 +
 +      into ('config') {
 +        from defaultCacheConfig
 +        from defaultDistributionConfig
 +        from (project(':geode-core').sourceSets.main.resources.files.find {
 +          it.name == 'log4j2.xml' 
 +        })
 +      }
 +      
 +      into ('lib') {
 +        from project(":geode-common").configurations.runtime
 +        from project(":geode-common").configurations.archives.allArtifacts.files
 +
 +        from project(":geode-json").configurations.runtime
 +        from project(":geode-json").configurations.archives.allArtifacts.files
 +
 +        from project(":geode-joptsimple").configurations.runtime
 +        from project(":geode-joptsimple").configurations.archives.allArtifacts.files
 +
 +        from project(":geode-wan").configurations.runtime
 +        from project(":geode-wan").configurations.archives.allArtifacts.files
 +
 +        from project(":geode-cq").configurations.runtime
 +        from project(":geode-cq").configurations.archives.allArtifacts.files
 +
 +        from project(":geode-core").configurations.runtime
 +        // Copying from provided configuration is only for supporting Spring Data GemFire.
 +        // If there are more dependencies added to provided configuration, this will need
 +        // to change
 +        from (project(":geode-core").configurations.provided) {
 +          include 'spring-data-gemfire-*'
 +        }
 +        from project(":geode-core").configurations.archives.allArtifacts.files
 +        from project(":geode-core").webJar
 +        from project(":geode-core").raJar
 +        from project(":geode-core").jcaJar
 +        
 +        from project(":geode-lucene").configurations.runtime
 +        from project(":geode-lucene").configurations.archives.allArtifacts.files
 +
 +        // include this jar        
 +        from project(":geode-web-api").jar
 +        
 +        // dependency jars
 +        from depsJar
 +        from gfshDepsJar
 +      }
 +
 +      into ('tools/Extensions') {
 +        from (project(":geode-web").configurations.archives.allArtifacts.files) {
 +          exclude '*.jar'
 +        }
 +        from (project(":geode-web-api").configurations.archives.allArtifacts.files) {
 +          exclude '*.jar'
 +        }
 +      }
 +
 +      into ('javadoc') {
 +        from docs
 +      }
 +
 +      into ('tools/Pulse') {
 +        from (project(":geode-pulse").configurations.archives.allArtifacts.files) {
 +          exclude '*.jar'
 +        }
 +      }
 +
 +      into ('tools/Modules') {
 +        from (project(':extensions/geode-modules-assembly').configurations.moduleDistOutputs.files)
 +      }
 +    }
 +  }
 +}
 +
 +// Create a configuration closure to configure test targets with the install directory
 +def dependOnInstalledProduct = {
 +  dependsOn installDist
 +  def install = file("$buildDir/install/${distributions.main.baseName}")
 +  environment ('GEMFIRE', install)
 +}
 +
 +// Add the configuration closure to the test targets so they depend on the install directory
 +test dependOnInstalledProduct
 +distributedTest dependOnInstalledProduct
 +integrationTest dependOnInstalledProduct
 +
 +// Make build final task to generate all test and product resources
 +build.dependsOn installDist
 +
 +installDist.dependsOn ':extensions/geode-modules-assembly:dist'

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5beaaedc/geode-assembly/src/main/dist/LICENSE
----------------------------------------------------------------------
diff --cc geode-assembly/src/main/dist/LICENSE
index 12ffb42,0000000..2f1374b
mode 100644,000000..100644
--- a/geode-assembly/src/main/dist/LICENSE
+++ b/geode-assembly/src/main/dist/LICENSE
@@@ -1,429 -1,0 +1,434 @@@
 +                                 Apache License
 +                           Version 2.0, January 2004
 +                        http://www.apache.org/licenses/
 +
 +   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
 +
 +   1. Definitions.
 +
 +      "License" shall mean the terms and conditions for use, reproduction,
 +      and distribution as defined by Sections 1 through 9 of this document.
 +
 +      "Licensor" shall mean the copyright owner or entity authorized by
 +      the copyright owner that is granting the License.
 +
 +      "Legal Entity" shall mean the union of the acting entity and all
 +      other entities that control, are controlled by, or are under common
 +      control with that entity. For the purposes of this definition,
 +      "control" means (i) the power, direct or indirect, to cause the
 +      direction or management of such entity, whether by contract or
 +      otherwise, or (ii) ownership of fifty percent (50%) or more of the
 +      outstanding shares, or (iii) beneficial ownership of such entity.
 +
 +      "You" (or "Your") shall mean an individual or Legal Entity
 +      exercising permissions granted by this License.
 +
 +      "Source" form shall mean the preferred form for making modifications,
 +      including but not limited to software source code, documentation
 +      source, and configuration files.
 +
 +      "Object" form shall mean any form resulting from mechanical
 +      transformation or translation of a Source form, including but
 +      not limited to compiled object code, generated documentation,
 +      and conversions to other media types.
 +
 +      "Work" shall mean the work of authorship, whether in Source or
 +      Object form, made available under the License, as indicated by a
 +      copyright notice that is included in or attached to the work
 +      (an example is provided in the Appendix below).
 +
 +      "Derivative Works" shall mean any work, whether in Source or Object
 +      form, that is based on (or derived from) the Work and for which the
 +      editorial revisions, annotations, elaborations, or other modifications
 +      represent, as a whole, an original work of authorship. For the purposes
 +      of this License, Derivative Works shall not include works that remain
 +      separable from, or merely link (or bind by name) to the interfaces of,
 +      the Work and Derivative Works thereof.
 +
 +      "Contribution" shall mean any work of authorship, including
 +      the original version of the Work and any modifications or additions
 +      to that Work or Derivative Works thereof, that is intentionally
 +      submitted to Licensor for inclusion in the Work by the copyright owner
 +      or by an individual or Legal Entity authorized to submit on behalf of
 +      the copyright owner. For the purposes of this definition, "submitted"
 +      means any form of electronic, verbal, or written communication sent
 +      to the Licensor or its representatives, including but not limited to
 +      communication on electronic mailing lists, source code control systems,
 +      and issue tracking systems that are managed by, or on behalf of, the
 +      Licensor for the purpose of discussing and improving the Work, but
 +      excluding communication that is conspicuously marked or otherwise
 +      designated in writing by the copyright owner as "Not a Contribution."
 +
 +      "Contributor" shall mean Licensor and any individual or Legal Entity
 +      on behalf of whom a Contribution has been received by Licensor and
 +      subsequently incorporated within the Work.
 +
 +   2. Grant of Copyright License. Subject to the terms and conditions of
 +      this License, each Contributor hereby grants to You a perpetual,
 +      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
 +      copyright license to reproduce, prepare Derivative Works of,
 +      publicly display, publicly perform, sublicense, and distribute the
 +      Work and such Derivative Works in Source or Object form.
 +
 +   3. Grant of Patent License. Subject to the terms and conditions of
 +      this License, each Contributor hereby grants to You a perpetual,
 +      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
 +      (except as stated in this section) patent license to make, have made,
 +      use, offer to sell, sell, import, and otherwise transfer the Work,
 +      where such license applies only to those patent claims licensable
 +      by such Contributor that are necessarily infringed by their
 +      Contribution(s) alone or by combination of their Contribution(s)
 +      with the Work to which such Contribution(s) was submitted. If You
 +      institute patent litigation against any entity (including a
 +      cross-claim or counterclaim in a lawsuit) alleging that the Work
 +      or a Contribution incorporated within the Work constitutes direct
 +      or contributory patent infringement, then any patent licenses
 +      granted to You under this License for that Work shall terminate
 +      as of the date such litigation is filed.
 +
 +   4. Redistribution. You may reproduce and distribute copies of the
 +      Work or Derivative Works thereof in any medium, with or without
 +      modifications, and in Source or Object form, provided that You
 +      meet the following conditions:
 +
 +      (a) You must give any other recipients of the Work or
 +          Derivative Works a copy of this License; and
 +
 +      (b) You must cause any modified files to carry prominent notices
 +          stating that You changed the files; and
 +
 +      (c) You must retain, in the Source form of any Derivative Works
 +          that You distribute, all copyright, patent, trademark, and
 +          attribution notices from the Source form of the Work,
 +          excluding those notices that do not pertain to any part of
 +          the Derivative Works; and
 +
 +      (d) If the Work includes a "NOTICE" text file as part of its
 +          distribution, then any Derivative Works that You distribute must
 +          include a readable copy of the attribution notices contained
 +          within such NOTICE file, excluding those notices that do not
 +          pertain to any part of the Derivative Works, in at least one
 +          of the following places: within a NOTICE text file distributed
 +          as part of the Derivative Works; within the Source form or
 +          documentation, if provided along with the Derivative Works; or,
 +          within a display generated by the Derivative Works, if and
 +          wherever such third-party notices normally appear. The contents
 +          of the NOTICE file are for informational purposes only and
 +          do not modify the License. You may add Your own attribution
 +          notices within Derivative Works that You distribute, alongside
 +          or as an addendum to the NOTICE text from the Work, provided
 +          that such additional attribution notices cannot be construed
 +          as modifying the License.
 +
 +      You may add Your own copyright statement to Your modifications and
 +      may provide additional or different license terms and conditions
 +      for use, reproduction, or distribution of Your modifications, or
 +      for any such Derivative Works as a whole, provided Your use,
 +      reproduction, and distribution of the Work otherwise complies with
 +      the conditions stated in this License.
 +
 +   5. Submission of Contributions. Unless You explicitly state otherwise,
 +      any Contribution intentionally submitted for inclusion in the Work
 +      by You to the Licensor shall be under the terms and conditions of
 +      this License, without any additional terms or conditions.
 +      Notwithstanding the above, nothing herein shall supersede or modify
 +      the terms of any separate license agreement you may have executed
 +      with Licensor regarding such Contributions.
 +
 +   6. Trademarks. This License does not grant permission to use the trade
 +      names, trademarks, service marks, or product names of the Licensor,
 +      except as required for reasonable and customary use in describing the
 +      origin of the Work and reproducing the content of the NOTICE file.
 +
 +   7. Disclaimer of Warranty. Unless required by applicable law or
 +      agreed to in writing, Licensor provides the Work (and each
 +      Contributor provides its Contributions) on an "AS IS" BASIS,
 +      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
 +      implied, including, without limitation, any warranties or conditions
 +      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
 +      PARTICULAR PURPOSE. You are solely responsible for determining the
 +      appropriateness of using or redistributing the Work and assume any
 +      risks associated with Your exercise of permissions under this License.
 +
 +   8. Limitation of Liability. In no event and under no legal theory,
 +      whether in tort (including negligence), contract, or otherwise,
 +      unless required by applicable law (such as deliberate and grossly
 +      negligent acts) or agreed to in writing, shall any Contributor be
 +      liable to You for damages, including any direct, indirect, special,
 +      incidental, or consequential damages of any character arising as a
 +      result of this License or out of the use or inability to use the
 +      Work (including but not limited to damages for loss of goodwill,
 +      work stoppage, computer failure or malfunction, or any and all
 +      other commercial damages or losses), even if such Contributor
 +      has been advised of the possibility of such damages.
 +
 +   9. Accepting Warranty or Additional Liability. While redistributing
 +      the Work or Derivative Works thereof, You may choose to offer,
 +      and charge a fee for, acceptance of support, warranty, indemnity,
 +      or other liability obligations and/or rights consistent with this
 +      License. However, in accepting such obligations, You may act only
 +      on Your own behalf and on Your sole responsibility, not on behalf
 +      of any other Contributor, and only if You agree to indemnify,
 +      defend, and hold each Contributor harmless for any liability
 +      incurred by, or claims asserted against, such Contributor by reason
 +      of your accepting any such warranty or additional liability.
 +
 +   END OF TERMS AND CONDITIONS
 +
 +   APPENDIX: How to apply the Apache License to your work.
 +
 +      To apply the Apache License to your work, attach the following
 +      boilerplate notice, with the fields enclosed by brackets "[]"
 +      replaced with your own identifying information. (Don't include
 +      the brackets!)  The text should be enclosed in the appropriate
 +      comment syntax for the file format. We also recommend that a
 +      file or class name and description of purpose be included on the
 +      same "printed page" as the copyright notice for easier
 +      identification within third-party archives.
 +
 +   Copyright [yyyy] [name of copyright owner]
 +
 +   Licensed under the Apache License, Version 2.0 (the "License");
 +   you may not use this file except in compliance with the License.
 +   You may obtain a copy of the License at
 +
 +       http://www.apache.org/licenses/LICENSE-2.0
 +
 +   Unless required by applicable law or agreed to in writing, software
 +   distributed under the License is distributed on an "AS IS" BASIS,
 +   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 +   See the License for the specific language governing permissions and
 +   limitations under the License.
 +
 +===========================================================================
 +
 +Apache Geode includes a number of components and libraries with separate 
 +copyright notices and license terms. Your use of those components are 
 +subject to the terms and conditions of the following licenses. 
 +
 +
 +---------------------------------------------------------------------------
 +Antlr (http://www.antlr.org/) antlr:antlr:2.7.7
 +---------------------------------------------------------------------------
 +This product bundles Antlr which is available under a BSD license.  
 +For details see http://www.antlr.org/license.html.
 +
 +---------------------------------------------------------------------------
 +Backbone (http://backbonejs.org)
 +---------------------------------------------------------------------------
 +This product bundles Backbone which is available under an MIT license.  
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +CompactConcurrentHashSet2 (http://gee.cs.oswego.edu/dl/concurrency-interest)
 +---------------------------------------------------------------------------
 +This product bundles CompactConcurrentHashSet2 derived from JSR-166 
 +ConcurrentHashMap v1.43 which is available in the public domain.  
 +
 +---------------------------------------------------------------------------
 +Handlebars (http://handlebarsjs.com)
 +---------------------------------------------------------------------------
 +This product bundles Handlebars which is available under an MIT license.  
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +highlight.js (https://highlightjs.org)
 +---------------------------------------------------------------------------
 +This product bundles highlight.js which is available under a BSD 3 clauses license.  
 +For details see http://opensource.org/licenses/BSD-3-Clause.
 +
 +---------------------------------------------------------------------------
 +javax.activation (http://java.sun.com/javase/technologies/desktop/javabeans/jaf/index.jsp) javax.activation:activation:1.1.1
 +---------------------------------------------------------------------------
 +This product bundles javax.activation which is available under a CDDL license.  
 +For details see https://glassfish.dev.java.net/public/CDDLv1.0.html.
 +
 +---------------------------------------------------------------------------
 +javax.mail (http://www.oracle.com/) javax.mail:javax.mail-api:1.4.5
 +---------------------------------------------------------------------------
 +This product bundles javax.mail which is available under a CDDL or GPLv2+CE license.  
 +For details see http://www.sun.com/cddl or https://glassfish.dev.java.net/public/CDDL+GPL.html.
 +
 +---------------------------------------------------------------------------
 +javax.resource (https://glassfish.java.net/) javax.resource:javax.resource-api:1.7
 +---------------------------------------------------------------------------
 +This product bundles javax.resource which is available under a CDDL or GPLv2+CE license.  
 +For details see https://glassfish.dev.java.net/public/CDDL+GPL.html.
 +
 +---------------------------------------------------------------------------
 +javax.servlet (https://glassfish.java.net/) javax.servlet:javax.servlet-api:3.1.0
 +---------------------------------------------------------------------------
 +This product bundles javax.servlet which is available under a CDDL or GPLv2+CE license.  
 +For details see https://glassfish.dev.java.net/public/CDDL+GPL.html.
 +
 +---------------------------------------------------------------------------
 +javax.transaction (https://glassfish.java.net/) javax.transaction:javax.transaction-api:1.2
 +---------------------------------------------------------------------------
 +This product bundles javax.transaction which is available under a CDDL or GPLv2+CE license.  
 +For details see https://glassfish.dev.java.net/public/CDDL+GPL.html.
 +
 +---------------------------------------------------------------------------
 +JLine (http://jline.sourceforge.net) jline:jline:2.12
 +---------------------------------------------------------------------------
 +This product bundles JLine which is available under a BSD license.  
 +For details see http://www.opensource.org/licenses/bsd-license.php.
 +
 +---------------------------------------------------------------------------
 +JOpt Simple (http://pholser.github.io/jopt-simple/)
 +---------------------------------------------------------------------------
 +This product bundles JOpt Simple which is available under an MIT license.  
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jQuery (https://jquery.com)
 +---------------------------------------------------------------------------
 +This product bundles jQuery which is available under an MIT license.  
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jQuery BBQ (http://benalman.com/projects/jquery-bbq-plugin/)
 +---------------------------------------------------------------------------
 +This product bundles jQuery BBQ which is available under an MIT and GPL dual license.  
 +For details see http://benalman.com/about/license.
 +
 +---------------------------------------------------------------------------
 +jQuery-slideto (https://github.com/Sleavely/jQuery-slideto)
 +---------------------------------------------------------------------------
 +This product bundles jQuery-slideto which is available under an MIT license.  
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jQuery Wiggle (https://github.com/wilhelm-murdoch/jQuery-Wiggle)
 +---------------------------------------------------------------------------
 +This product bundles jQuery Wiggle which is available under an MIT license.  
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +JSON (http://json.org)
 +---------------------------------------------------------------------------
 +This product bundles JSON which is available under a BSD-like license.  
 +For details see http://json.org/license.html.
 +
 +---------------------------------------------------------------------------
 +Paranamer (https://github.com/paul-hammant/paranamer) com.thoughtworks.paranamer:paranamer:2.3
 +---------------------------------------------------------------------------
 +This product bundles Paranamer which is available under a BSD license.  
 +For details see http://www.opensource.org/licenses/bsd-license.php.
 +
 +---------------------------------------------------------------------------
 +reset.css (http://meyerweb.com/eric/tools/css/reset/)
 +---------------------------------------------------------------------------
 +This product bundles reset.css which is available in the public domain.
 +
 +---------------------------------------------------------------------------
 +tooltip.js (http://flowplayer.org/tools/tooltip/)
 +---------------------------------------------------------------------------
 +This product bundles tooltip.css which is available in the public domain.
 +
 +---------------------------------------------------------------------------
 +scala-reflect (http://www.scala-lang.org/) org.scala-lang:scala-reflect:2.10.0
 +---------------------------------------------------------------------------
 +This product bundles scala-reflect which is available under a BSD-like license.  
 +For details see http://www.scala-lang.org/downloads/license.html.
 +
 +---------------------------------------------------------------------------
 +scala-library (http://www.scala-lang.org/) org.scala-lang:scala-library:2.10.0
 +---------------------------------------------------------------------------
 +This product bundles scala-library which is available under a BSD-like license.  
 +For details see http://www.scala-lang.org/downloads/license.html.
 +
 +---------------------------------------------------------------------------
 +shred (https://github.com/pandastrike/shred)
 +---------------------------------------------------------------------------
 +This product bundles shred which is available under an MIT or ISC license.  
 +For details see https://github.com/pandastrike/shred/blob/master/LICENSE.
 +
 +---------------------------------------------------------------------------
 +SLF4J API (http://www.slf4j.org) org.slf4j:slf4j-api:jar:1.7.7
 +---------------------------------------------------------------------------
 +This product bundles SLF4J API which is available under an MIT license.  
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +underscore (http://underscorejs.org)
 +---------------------------------------------------------------------------
 +This product bundles underscore which is available under an MIT license.  
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery jqGrid (https://plugins.jquery.com/jqGrid/)
 +---------------------------------------------------------------------------
 +This product bundles jqGrid which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +html5.js (https://github.com/aFarkas/html5shiv)
 +---------------------------------------------------------------------------
 +This product bundles html5 which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.i18n.properties (https://github.com/jquery-i18n-properties/jquery-i18n-properties)
 +---------------------------------------------------------------------------
 +This product bundles jQuery i18n which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.jscrollpane (http://jscrollpane.kelvinluck.com/)
 +---------------------------------------------------------------------------
 +This product bundles jquery.jscrollpane which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.mousewheel (http://brandonaaron.net)
 +---------------------------------------------------------------------------
 +This product bundles jquery.mousewheel which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.placeholder (http://webcloud.se)
 +---------------------------------------------------------------------------
 +This product bundles jquery.placeholder which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.tablednd (https://github.com/isocra/TableDnD)
 +---------------------------------------------------------------------------
 +This product bundles jquery.tablednd which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.timeago (http://timeago.yarp.com/)
 +---------------------------------------------------------------------------
 +This product bundles jquery.timeago which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.ztree (http://zTree.me/)
 +---------------------------------------------------------------------------
 +This product bundles jquery.ztree which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.multiselect (http://www.erichynds.com/jquery/jquery-ui-multiselect-widget/)
 +---------------------------------------------------------------------------
 +This product bundles jQuery.multiselect which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.ui (http://jqueryui.com/about)
 +---------------------------------------------------------------------------
 +This product bundles jquery UI which is available under an MIT license.
 +For details see http://www.opensource.org/licenses/mit-license.php.
 +
 +---------------------------------------------------------------------------
 +jquery.sparkline.js (http://omnipotent.net/jquery.sparkline/)
 +---------------------------------------------------------------------------
 +This product bundles jquery.sparkline which is available under a BSD-like license.
 +For details see http://opensource.org/licenses/BSD-3-Clause.
 +
++---------------------------------------------------------------------------
++split.js (https://github.com/nathancahill/Split.js)
++---------------------------------------------------------------------------
++This product bundles split.js which is available under an MIT license.
++For details see http://www.opensource.org/licenses/mit-license.php.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5beaaedc/geode-assembly/src/src/dist/gradlew
----------------------------------------------------------------------
diff --cc geode-assembly/src/src/dist/gradlew
index 0000000,0000000..de155c6
new file mode 100755
--- /dev/null
+++ b/geode-assembly/src/src/dist/gradlew
@@@ -1,0 -1,0 +1,221 @@@
++#!/usr/bin/env bash
++
++# Licensed to the Apache Software Foundation (ASF) under one or more
++# contributor license agreements.  See the NOTICE file distributed with
++# this work for additional information regarding copyright ownership.
++# The ASF licenses this file to You under the Apache License, Version 2.0
++# (the "License"); you may not use this file except in compliance with
++# the License.  You may obtain a copy of the License at
++#
++#     http://www.apache.org/licenses/LICENSE-2.0
++#
++# Unless required by applicable law or agreed to in writing, software
++# distributed under the License is distributed on an "AS IS" BASIS,
++# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
++# See the License for the specific language governing permissions and
++# limitations under the License.
++
++##
++## Tries to recreate Gradle's gradlew command in pure bash.
++## This way you don't have to worry about binaries in your build.
++##
++## Depdencies
++## unzip
++##
++
++set -e
++set -o pipefail
++
++APP_NAME="Gradle"
++APP_BASE_NAME=`basename "$0"`
++
++# Use the maximum available, or set MAX_FD != -1 to use that value.
++    MAX_FD="maximum"
++
++# Add default JVM options here. You can also use JAVA_OPTS and GRADLE_OPTS to pass JVM options to this script.
++DEFAULT_JVM_OPTS="-Dorg.gradle.appname=$APP_BASE_NAME"
++
++bin=`dirname "$0"`
++bin=`cd "$bin">/dev/null; pwd`
++
++if [ -e "$bin/gradle/wrapper/gradle-wrapper.properties" ]; then
++  . "$bin/gradle/wrapper/gradle-wrapper.properties"
++else
++  # the location that the wrapper is at doesn't have a properties
++  # check PWD, gradlew may be shared
++  if [ -e "$PWD/gradle/wrapper/gradle-wrapper.properties" ]; then
++    . "$PWD/gradle/wrapper/gradle-wrapper.properties"
++  else
++    echo "Unable to locate gradle-wrapper.properties.  Not at $PWD/gradle/wrapper/gradle-wrapper.properties or $bin/gradle/wrapper/gradle-wrapper.properties" 1>&2
++    exit 1
++  fi
++fi
++
++warn ( ) {
++    echo "$*"
++}
++
++die ( ) {
++    echo
++    echo "$*"
++    echo
++    exit 1
++}
++
++# OS specific support (must be 'true' or 'false').
++darwin=false
++case "`uname`" in
++  Darwin* )
++    darwin=true
++    ;;
++esac
++
++# Attempt to set APP_HOME
++# Resolve links: $0 may be a link
++PRG="$0"
++# Need this for relative symlinks.
++while [ -h "$PRG" ] ; do
++    ls=`ls -ld "$PRG"`
++    link=`expr "$ls" : '.*-> \(.*\)$'`
++    if expr "$link" : '/.*' > /dev/null; then
++        PRG="$link"
++    else
++        PRG=`dirname "$PRG"`"/$link"
++    fi
++done
++SAVED="`pwd`"
++cd "`dirname \"$PRG\"`/" >&-
++APP_HOME="`pwd -P`"
++cd "$SAVED" >&-
++
++CLASSPATH=$APP_HOME/gradle/wrapper/gradle-wrapper.jar
++
++# Determine the Java command to use to start the JVM.
++if [ -n "$JAVA_HOME" ] ; then
++    if [ -x "$JAVA_HOME/jre/sh/java" ] ; then
++        # IBM's JDK on AIX uses strange locations for the executables
++        JAVACMD="$JAVA_HOME/jre/sh/java"
++    else
++        JAVACMD="$JAVA_HOME/bin/java"
++    fi
++    if [ ! -x "$JAVACMD" ] ; then
++        die "ERROR: JAVA_HOME is set to an invalid directory: $JAVA_HOME
++
++Please set the JAVA_HOME variable in your environment to match the
++location of your Java installation."
++    fi
++else
++    JAVACMD="java"
++    which java >/dev/null 2>&1 || die "ERROR: JAVA_HOME is not set and no 'java' command could be found in your PATH.
++
++Please set the JAVA_HOME variable in your environment to match the
++location of your Java installation."
++fi
++
++# Increase the maximum file descriptors if we can.
++if [ "$darwin" = "false" ] ; then
++    MAX_FD_LIMIT=`ulimit -H -n`
++    if [ $? -eq 0 ] ; then
++        if [ "$MAX_FD" = "maximum" -o "$MAX_FD" = "max" ] ; then
++            MAX_FD="$MAX_FD_LIMIT"
++        fi
++        ulimit -n $MAX_FD
++        if [ $? -ne 0 ] ; then
++            warn "Could not set maximum file descriptor limit: $MAX_FD"
++        fi
++    else
++        warn "Could not query maximum file descriptor limit: $MAX_FD_LIMIT"
++    fi
++fi
++
++# For Darwin, add options to specify how the application appears in the dock
++if $darwin; then
++    GRADLE_OPTS="$GRADLE_OPTS \"-Xdock:name=$APP_NAME\" \"-Xdock:icon=$APP_HOME/media/gradle.icns\""
++fi
++
++# does not match gradle's hash
++# waiting for http://stackoverflow.com/questions/26642077/java-biginteger-in-bash-rewrite-gradlew
++hash() {
++  local input="$1"
++  if $darwin; then
++    md5 -q -s "$1"
++  else
++    echo -n "$1" | md5sum  | cut -d" " -f1
++  fi
++}
++
++dist_path() {
++  local dir=$(basename $distributionUrl | sed 's;.zip;;g')
++  local id=$(hash "$distributionUrl")
++
++  echo "$HOME/.gradle/${distributionPath:-wrapper/dists}/$dir/$id"
++}
++
++zip_path() {
++  local dir=$(basename $distributionUrl | sed 's;.zip;;g')
++  local id=$(hash "$distributionUrl")
++
++  echo "$HOME/.gradle/${zipStorePath:-wrapper/dists}/$dir/$id"
++}
++
++download() {
++  local base_path=$(dist_path)
++  local file_name=$(basename $distributionUrl)
++  local dir_name=$(echo "$file_name" | sed 's;-bin.zip;;g' | sed 's;-src.zip;;g' |sed 's;-all.zip;;g')
++
++  if [ ! -d "$base_path" ]; then
++    mkdir -p "$base_path"
++  else
++    # if data already exists, it means we failed to do this before
++    # so cleanup last run and try again
++    rm -rf $base_path/*
++  fi
++
++  # download dist. curl on mac doesn't like the cert provided...
++  local zip_path=$(zip_path)
++  curl --insecure -L -o "$zip_path/$file_name" "$distributionUrl"
++
++  pushd "$base_path"
++    touch "$file_name.lck"
++    unzip "$zip_path/$file_name" 1> /dev/null
++    touch "$file_name.ok"
++  popd
++}
++
++is_cached() {
++  local file_name=$(basename $distributionUrl)
++
++  [ -e "$(dist_path)/$file_name.ok" ]
++}
++
++lib_path() {
++  local base_path=$(dist_path)
++  local file_name=$(basename $distributionUrl | sed 's;-bin.zip;;g' | sed 's;-src.zip;;g' |sed 's;-all.zip;;g')
++
++  echo "$base_path/$file_name/lib"
++}
++
++classpath() {
++  local dir=$(lib_path)
++  local cp=$(ls -1 $dir/*.jar | tr '\n' ':')
++  echo "$dir:$cp"
++}
++
++# Split up the JVM_OPTS And GRADLE_OPTS values into an array, following the shell quoting and substitution rules
++function splitJvmOpts() {
++    JVM_OPTS=("$@")
++}
++
++main() {
++  if ! is_cached; then
++    download
++  fi
++
++  eval splitJvmOpts $DEFAULT_JVM_OPTS $JAVA_OPTS $GRADLE_OPTS
++  JVM_OPTS[${#JVM_OPTS[*]}]="-Dorg.gradle.appname=$APP_BASE_NAME"
++
++  $JAVACMD "${JVM_OPTS[@]}" -cp $(classpath) org.gradle.launcher.GradleMain "$@"
++}
++
++main "$@"
++

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5beaaedc/geode-assembly/src/test/java/com/gemstone/gemfire/management/internal/AgentUtilJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-assembly/src/test/java/com/gemstone/gemfire/management/internal/AgentUtilJUnitTest.java
index 9a446cc,0000000..59da3cf
mode 100644,000000..100644
--- a/geode-assembly/src/test/java/com/gemstone/gemfire/management/internal/AgentUtilJUnitTest.java
+++ b/geode-assembly/src/test/java/com/gemstone/gemfire/management/internal/AgentUtilJUnitTest.java
@@@ -1,98 -1,0 +1,50 @@@
 +/*
 + * Licensed to the Apache Software Foundation (ASF) under one or more
 + * contributor license agreements.  See the NOTICE file distributed with
 + * this work for additional information regarding copyright ownership.
 + * The ASF licenses this file to You under the Apache License, Version 2.0
 + * (the "License"); you may not use this file except in compliance with
 + * the License.  You may obtain a copy of the License at
 + *
 + *      http://www.apache.org/licenses/LICENSE-2.0
 + *
 + * Unless required by applicable law or agreed to in writing, software
 + * distributed under the License is distributed on an "AS IS" BASIS,
 + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 + * See the License for the specific language governing permissions and
 + * limitations under the License.
 + */
 +package com.gemstone.gemfire.management.internal;
 +
++import com.gemstone.gemfire.internal.GemFireVersion;
 +import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 +import org.junit.Before;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
 +
- import java.io.File;
- import java.io.FileInputStream;
- import java.io.FileNotFoundException;
- import java.io.IOException;
- import java.io.InputStream;
- import java.util.Properties;
- 
 +import static org.junit.Assert.assertNotNull;
 +
 +@Category(IntegrationTest.class)
 +public class AgentUtilJUnitTest {
 +
 +  private AgentUtil agentUtil;
 +  private String version;
 +
 +  @Before
 +  public void setUp() {
-     version = getGemfireVersion();
++    version = GemFireVersion.getGemFireVersion();
 +    agentUtil = new AgentUtil(version);
 +  }
 +
 +  @Test
 +  public void testRESTApiExists() {
 +    String gemFireWarLocation = agentUtil.findWarLocation("geode-web-api");
 +    assertNotNull("GemFire REST API WAR File was not found", gemFireWarLocation);
 +  }
 +
 +  @Test
 +  public void testPulseWarExists() {
 +    String gemFireWarLocation = agentUtil.findWarLocation("geode-pulse");
 +    assertNotNull("Pulse WAR File was not found", gemFireWarLocation);
 +  }
- 
-   private String getGemfireVersion() {
-     String version = null;
- 
-     Properties prop = new Properties();
-     InputStream inputStream = null;
-     String pathPrefix = null;
-     try {
-       pathPrefix = calculatePathPrefixToProjectRoot("geode-assembly/");
-       inputStream = new FileInputStream(pathPrefix + "gradle.properties");
-     } catch (FileNotFoundException e1) {
-       try {
-         pathPrefix = calculatePathPrefixToProjectRoot("geode-core/");
-         inputStream = new FileInputStream(pathPrefix + "gradle.properties");
-       } catch (FileNotFoundException e) {
-       }
-     }
- 
-     if (inputStream != null) {
-       try {
-         prop.load(inputStream);
-         version = prop.getProperty("versionNumber") + prop.getProperty("releaseType");
-       } catch (FileNotFoundException e) {
-       } catch (IOException e) {
-       }
-     }
-     return version;
-   }
- 
-   private String calculatePathPrefixToProjectRoot(String subDirectory) {
-     String pathPrefix = "";
- 
-     String currentDirectoryPath = new File(".").getAbsolutePath();
-     int gemfireCoreLocationIx = currentDirectoryPath.indexOf(subDirectory);
-     if (gemfireCoreLocationIx < 0) {
-       return pathPrefix;
-     }
- 
-     return currentDirectoryPath.substring(0, gemfireCoreLocationIx);
-   }
- 
- 
 +}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5beaaedc/geode-core/src/main/java/com/gemstone/gemfire/cache/FailedSynchronizationException.java
----------------------------------------------------------------------
diff --cc geode-core/src/main/java/com/gemstone/gemfire/cache/FailedSynchronizationException.java
index d7fd2fc,0000000..4842324
mode 100644,000000..100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/cache/FailedSynchronizationException.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/cache/FailedSynchronizationException.java
@@@ -1,55 -1,0 +1,59 @@@
 +/*
 + * Licensed to the Apache Software Foundation (ASF) under one or more
 + * contributor license agreements.  See the NOTICE file distributed with
 + * this work for additional information regarding copyright ownership.
 + * The ASF licenses this file to You under the Apache License, Version 2.0
 + * (the "License"); you may not use this file except in compliance with
 + * the License.  You may obtain a copy of the License at
 + *
 + *      http://www.apache.org/licenses/LICENSE-2.0
 + *
 + * Unless required by applicable law or agreed to in writing, software
 + * distributed under the License is distributed on an "AS IS" BASIS,
 + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 + * See the License for the specific language governing permissions and
 + * limitations under the License.
 + */
 +
 +package com.gemstone.gemfire.cache;
 +
++import javax.transaction.Status;
++import javax.transaction.Transaction;
++import javax.transaction.UserTransaction;
++
 +/** Thrown when a cache transaction fails to register with the
 + * <code>UserTransaction</code> (aka JTA transaction), most likely the
 + * cause of the <code>UserTransaction</code>'s
 + * <code>javax.transaction.Status#STATUS_MARKED_ROLLBACK</code>
 + * status.
 + *
 + * @author Mitch Thomas
 + *
-  * @see javax.transaction.UserTransaction#setRollbackOnly
-  * @see javax.transaction.Transaction#registerSynchronization
-  * @see javax.transaction.Status
++ * @see UserTransaction#setRollbackOnly
++ * @see Transaction#registerSynchronization
++ * @see Status
 + * @since 4.0
 + */
 +public class FailedSynchronizationException extends CacheRuntimeException {
 +private static final long serialVersionUID = -6225053492344591496L;
 +  /**
 +   * Constructs an instance of
 +   * <code>FailedSynchronizationException</code> with the
 +   * specified detail message.
 +   * @param msg the detail message
 +   */
 +  public FailedSynchronizationException(String msg) {
 +    super(msg);
 +  }
 +  
 +  /**
 +   * Constructs an instance of
 +   * <code>FailedSynchronizationException</code> with the
 +   * specified detail message and cause.
 +   * @param msg the detail message
 +   * @param cause the causal Throwable
 +   */
 +  public FailedSynchronizationException(String msg, Throwable cause) {
 +    super(msg, cause);
 +  }
 +}